/** * Licensed to the Apache Software Foundation (ASF) under one * or more contributor license agreements. See the NOTICE file * distributed with this work for additional information * regarding copyright ownership. The ASF licenses this file * to you under the Apache License, Version 2.0 (the * "License"); you may not use this file except in compliance * with the License. You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package org.apache.hadoop.yarn.api.impl.pb.service; import org.apache.hadoop.yarn.api.ClientRMProtocol; import org.apache.hadoop.yarn.api.protocolrecords.GetAllApplicationsResponse; import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportResponse; import org.apache.hadoop.yarn.api.protocolrecords.GetClusterMetricsResponse; import org.apache.hadoop.yarn.api.protocolrecords.GetClusterNodesResponse; import org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenResponse; import org.apache.hadoop.yarn.api.protocolrecords.GetNewApplicationResponse; import org.apache.hadoop.yarn.api.protocolrecords.GetQueueInfoResponse; import org.apache.hadoop.yarn.api.protocolrecords.GetQueueUserAclsInfoResponse; import org.apache.hadoop.yarn.api.protocolrecords.KillApplicationResponse; import org.apache.hadoop.yarn.api.protocolrecords.SubmitApplicationResponse; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetAllApplicationsRequestPBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetAllApplicationsResponsePBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetApplicationReportRequestPBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetApplicationReportResponsePBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetClusterMetricsRequestPBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetClusterMetricsResponsePBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetClusterNodesRequestPBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetClusterNodesResponsePBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetDelegationTokenRequestPBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetDelegationTokenResponsePBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetNewApplicationRequestPBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetNewApplicationResponsePBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetQueueInfoRequestPBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetQueueInfoResponsePBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetQueueUserAclsInfoRequestPBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.GetQueueUserAclsInfoResponsePBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.KillApplicationRequestPBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.KillApplicationResponsePBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.SubmitApplicationRequestPBImpl; import org.apache.hadoop.yarn.api.protocolrecords.impl.pb.SubmitApplicationResponsePBImpl; import org.apache.hadoop.yarn.exceptions.YarnRemoteException; import org.apache.hadoop.yarn.proto.ClientRMProtocol.ClientRMProtocolService.BlockingInterface; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetAllApplicationsRequestProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetAllApplicationsResponseProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetApplicationReportRequestProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetApplicationReportResponseProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetClusterMetricsRequestProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetClusterMetricsResponseProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetClusterNodesRequestProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetClusterNodesResponseProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetDelegationTokenRequestProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetDelegationTokenResponseProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetNewApplicationRequestProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetNewApplicationResponseProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetQueueInfoRequestProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetQueueInfoResponseProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetQueueUserAclsInfoRequestProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.GetQueueUserAclsInfoResponseProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.KillApplicationRequestProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.KillApplicationResponseProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.SubmitApplicationRequestProto; import org.apache.hadoop.yarn.proto.YarnServiceProtos.SubmitApplicationResponseProto; import com.google.protobuf.RpcController; import com.google.protobuf.ServiceException; public class ClientRMProtocolPBServiceImpl implements BlockingInterface { private ClientRMProtocol real; public ClientRMProtocolPBServiceImpl(ClientRMProtocol impl) { this.real = impl; } @Override public KillApplicationResponseProto forceKillApplication(RpcController arg0, KillApplicationRequestProto proto) throws ServiceException { KillApplicationRequestPBImpl request = new KillApplicationRequestPBImpl(proto); try { KillApplicationResponse response = real.forceKillApplication(request); return ((KillApplicationResponsePBImpl)response).getProto(); } catch (YarnRemoteException e) { throw new ServiceException(e); } } @Override public GetApplicationReportResponseProto getApplicationReport( RpcController arg0, GetApplicationReportRequestProto proto) throws ServiceException { GetApplicationReportRequestPBImpl request = new GetApplicationReportRequestPBImpl(proto); try { GetApplicationReportResponse response = real.getApplicationReport(request); return ((GetApplicationReportResponsePBImpl)response).getProto(); } catch (YarnRemoteException e) { throw new ServiceException(e); } } @Override public GetClusterMetricsResponseProto getClusterMetrics(RpcController arg0, GetClusterMetricsRequestProto proto) throws ServiceException { GetClusterMetricsRequestPBImpl request = new GetClusterMetricsRequestPBImpl(proto); try { GetClusterMetricsResponse response = real.getClusterMetrics(request); return ((GetClusterMetricsResponsePBImpl)response).getProto(); } catch (YarnRemoteException e) { throw new ServiceException(e); } } @Override public GetNewApplicationResponseProto getNewApplication( RpcController arg0, GetNewApplicationRequestProto proto) throws ServiceException { GetNewApplicationRequestPBImpl request = new GetNewApplicationRequestPBImpl(proto); try { GetNewApplicationResponse response = real.getNewApplication(request); return ((GetNewApplicationResponsePBImpl)response).getProto(); } catch (YarnRemoteException e) { throw new ServiceException(e); } } @Override public SubmitApplicationResponseProto submitApplication(RpcController arg0, SubmitApplicationRequestProto proto) throws ServiceException { SubmitApplicationRequestPBImpl request = new SubmitApplicationRequestPBImpl(proto); try { SubmitApplicationResponse response = real.submitApplication(request); return ((SubmitApplicationResponsePBImpl)response).getProto(); } catch (YarnRemoteException e) { throw new ServiceException(e); } } @Override public GetAllApplicationsResponseProto getAllApplications( RpcController controller, GetAllApplicationsRequestProto proto) throws ServiceException { GetAllApplicationsRequestPBImpl request = new GetAllApplicationsRequestPBImpl(proto); try { GetAllApplicationsResponse response = real.getAllApplications(request); return ((GetAllApplicationsResponsePBImpl)response).getProto(); } catch (YarnRemoteException e) { throw new ServiceException(e); } } @Override public GetClusterNodesResponseProto getClusterNodes(RpcController controller, GetClusterNodesRequestProto proto) throws ServiceException { GetClusterNodesRequestPBImpl request = new GetClusterNodesRequestPBImpl(proto); try { GetClusterNodesResponse response = real.getClusterNodes(request); return ((GetClusterNodesResponsePBImpl)response).getProto(); } catch (YarnRemoteException e) { throw new ServiceException(e); } } @Override public GetQueueInfoResponseProto getQueueInfo(RpcController controller, GetQueueInfoRequestProto proto) throws ServiceException { GetQueueInfoRequestPBImpl request = new GetQueueInfoRequestPBImpl(proto); try { GetQueueInfoResponse response = real.getQueueInfo(request); return ((GetQueueInfoResponsePBImpl)response).getProto(); } catch (YarnRemoteException e) { throw new ServiceException(e); } } @Override public GetQueueUserAclsInfoResponseProto getQueueUserAcls( RpcController controller, GetQueueUserAclsInfoRequestProto proto) throws ServiceException { GetQueueUserAclsInfoRequestPBImpl request = new GetQueueUserAclsInfoRequestPBImpl(proto); try { GetQueueUserAclsInfoResponse response = real.getQueueUserAcls(request); return ((GetQueueUserAclsInfoResponsePBImpl)response).getProto(); } catch (YarnRemoteException e) { throw new ServiceException(e); } } @Override public GetDelegationTokenResponseProto getDelegationToken( RpcController controller, GetDelegationTokenRequestProto proto) throws ServiceException { GetDelegationTokenRequestPBImpl request = new GetDelegationTokenRequestPBImpl(proto); try { GetDelegationTokenResponse response = real.getDelegationToken(request); return ((GetDelegationTokenResponsePBImpl)response).getProto(); } catch (YarnRemoteException e) { throw new ServiceException(e); } } }