| Package | Description | 
|---|---|
| org.apache.hadoop.yarn.api | |
| org.apache.hadoop.yarn.applications.distributedshell | Licensed to the Apache Software Foundation (ASF) under one
 or more contributor license agreements. | 
| org.apache.hadoop.yarn.client.api | Licensed to the Apache Software Foundation (ASF) under one
 or more contributor license agreements. | 
| org.apache.hadoop.yarn.client.api.async | |
| org.apache.hadoop.yarn.exceptions | 
| Modifier and Type | Method and Description | 
|---|---|
| AllocateResponse | ApplicationMasterProtocol. allocate(AllocateRequest request)
 The main interface between an  ApplicationMasterand theResourceManager. | 
| CommitResponse | ContainerManagementProtocol. commitLastReInitialization(ContainerId containerId)Commit the Last ReInitialization if possible. | 
| ReservationDeleteResponse | ApplicationClientProtocol. deleteReservation(ReservationDeleteRequest request)
 The interface used by clients to remove an existing Reservation. | 
| FailApplicationAttemptResponse | ApplicationClientProtocol. failApplicationAttempt(FailApplicationAttemptRequest request)The interface used by clients to request the 
  ResourceManagerto fail an application attempt. | 
| FinishApplicationMasterResponse | ApplicationMasterProtocol. finishApplicationMaster(FinishApplicationMasterRequest request)The interface used by an  ApplicationMasterto notify theResourceManagerabout its completion (success or failed). | 
| KillApplicationResponse | ApplicationClientProtocol. forceKillApplication(KillApplicationRequest request)The interface used by clients to request the
  ResourceManagerto abort submitted application. | 
| GetClusterMetricsResponse | ApplicationClientProtocol. getClusterMetrics(GetClusterMetricsRequest request)The interface used by clients to get metrics about the cluster from
 the  ResourceManager. | 
| GetClusterNodeLabelsResponse | ApplicationClientProtocol. getClusterNodeLabels(GetClusterNodeLabelsRequest request)
 The interface used by client to get node labels in the cluster | 
| GetClusterNodesResponse | ApplicationClientProtocol. getClusterNodes(GetClusterNodesRequest request)The interface used by clients to get a report of all nodes
 in the cluster from the  ResourceManager. | 
| GetContainerStatusesResponse | ContainerManagementProtocol. getContainerStatuses(GetContainerStatusesRequest request)
 The API used by the  ApplicationMasterto request for current
 statuses ofContainers from theNodeManager. | 
| org.apache.hadoop.yarn.api.protocolrecords.GetLabelsToNodesResponse | ApplicationClientProtocol. getLabelsToNodes(org.apache.hadoop.yarn.api.protocolrecords.GetLabelsToNodesRequest request)
 The interface used by client to get labels to nodes mappings
 in existing cluster | 
| GetNewApplicationResponse | ApplicationClientProtocol. getNewApplication(GetNewApplicationRequest request)The interface used by clients to obtain a new  ApplicationIdfor 
 submitting new applications. | 
| GetNewReservationResponse | ApplicationClientProtocol. getNewReservation(GetNewReservationRequest request)The interface used by clients to obtain a new  ReservationIdfor
 submitting new reservations. | 
| org.apache.hadoop.yarn.api.protocolrecords.GetNodesToLabelsResponse | ApplicationClientProtocol. getNodeToLabels(org.apache.hadoop.yarn.api.protocolrecords.GetNodesToLabelsRequest request)
 The interface used by client to get node to labels mappings in existing cluster | 
| GetQueueInfoResponse | ApplicationClientProtocol. getQueueInfo(GetQueueInfoRequest request)The interface used by clients to get information about queues
 from the  ResourceManager. | 
| GetQueueUserAclsInfoResponse | ApplicationClientProtocol. getQueueUserAcls(GetQueueUserAclsInfoRequest request)The interface used by clients to get information about queue 
 acls for current user from the  ResourceManager. | 
| IncreaseContainersResourceResponse | ContainerManagementProtocol. increaseContainersResource(IncreaseContainersResourceRequest request)Deprecated.  | 
| ReservationListResponse | ApplicationClientProtocol. listReservations(ReservationListRequest request)
 The interface used by clients to get the list of reservations in a plan. | 
| ResourceLocalizationResponse | ContainerManagementProtocol. localize(ResourceLocalizationRequest request)Localize resources required by the container. | 
| MoveApplicationAcrossQueuesResponse | ApplicationClientProtocol. moveApplicationAcrossQueues(MoveApplicationAcrossQueuesRequest request)Move an application to a new queue. | 
| RegisterApplicationMasterResponse | ApplicationMasterProtocol. registerApplicationMaster(RegisterApplicationMasterRequest request)
 The interface used by a new  ApplicationMasterto register with
 theResourceManager. | 
| ReInitializeContainerResponse | ContainerManagementProtocol. reInitializeContainer(ReInitializeContainerRequest request)ReInitialize the Container with a new Launch Context. | 
| ReleaseSharedCacheResourceResponse | ClientSCMProtocol. release(ReleaseSharedCacheResourceRequest request)
 The interface used by clients to release a resource with the
  SharedCacheManager.This method is called once an application
 is no longer using a claimed resource in the shared cache. | 
| RestartContainerResponse | ContainerManagementProtocol. restartContainer(ContainerId containerId)Restart the container. | 
| RollbackResponse | ContainerManagementProtocol. rollbackLastReInitialization(ContainerId containerId)Rollback the Last ReInitialization if possible. | 
| SignalContainerResponse | ApplicationClientProtocol. signalToContainer(SignalContainerRequest request)The interface used by clients to request the
  ResourceManagerto signal a container. | 
| SignalContainerResponse | ContainerManagementProtocol. signalToContainer(SignalContainerRequest request) | 
| StartContainersResponse | ContainerManagementProtocol. startContainers(StartContainersRequest request)
 The  ApplicationMasterprovides a list ofStartContainerRequests to aNodeManagerto
 startContainers allocated to it using this interface. | 
| StopContainersResponse | ContainerManagementProtocol. stopContainers(StopContainersRequest request)
 The  ApplicationMasterrequests aNodeManagerto
 stop a list ofContainers allocated to it using this
 interface. | 
| SubmitApplicationResponse | ApplicationClientProtocol. submitApplication(SubmitApplicationRequest request)The interface used by clients to submit a new application to the
  ResourceManager. | 
| ReservationSubmissionResponse | ApplicationClientProtocol. submitReservation(ReservationSubmissionRequest request)
 The interface used by clients to submit a new reservation to the
  ResourceManager. | 
| UpdateApplicationPriorityResponse | ApplicationClientProtocol. updateApplicationPriority(UpdateApplicationPriorityRequest request)
 The interface used by client to set priority of an application. | 
| UpdateApplicationTimeoutsResponse | ApplicationClientProtocol. updateApplicationTimeouts(UpdateApplicationTimeoutsRequest request)
 The interface used by client to set ApplicationTimeouts of an application. | 
| ContainerUpdateResponse | ContainerManagementProtocol. updateContainer(ContainerUpdateRequest request)
 The API used by the  ApplicationMasterto request for
 resource update of running containers on theNodeManager. | 
| ReservationUpdateResponse | ApplicationClientProtocol. updateReservation(ReservationUpdateRequest request)
 The interface used by clients to update an existing Reservation. | 
| UseSharedCacheResourceResponse | ClientSCMProtocol. use(UseSharedCacheResourceRequest request)
 The interface used by clients to claim a resource with the
  SharedCacheManager.The client uses a checksum to identify the
 resource and anApplicationIdto identify which application will be
 using the resource. | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ApplicationMaster. run()Main run function for the application master | 
| boolean | Client. run()Main run function for the client | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract AllocateResponse | AMRMClient. allocate(float progressIndicator)Request additional containers and receive new container allocations. | 
| abstract void | TimelineClient. cancelDelegationToken(Token<TimelineDelegationTokenIdentifier> timelineDT)
 Cancel a timeline delegation token. | 
| abstract void | NMClient. commitLastReInitialization(ContainerId containerId)Commit last reInitialization of the specified container. | 
| abstract YarnClientApplication | YarnClient. createApplication()
 Obtain a  YarnClientApplicationfor a new application,
 which in turn contains theApplicationSubmissionContextandGetNewApplicationResponseobjects. | 
| abstract GetNewReservationResponse | YarnClient. createReservation()
 Obtain a  GetNewReservationResponsefor a new reservation,
 which contains theReservationIdobject. | 
| abstract ReservationDeleteResponse | YarnClient. deleteReservation(ReservationDeleteRequest request)
 The interface used by clients to remove an existing Reservation. | 
| abstract void | YarnClient. failApplicationAttempt(ApplicationAttemptId applicationAttemptId)
 Fail an application attempt identified by given ID. | 
| abstract List<QueueInfo> | YarnClient. getAllQueues()
 Get information ( QueueInfo) about all queues, recursively if there
 is a hierarchy | 
| abstract Token<AMRMTokenIdentifier> | YarnClient. getAMRMToken(ApplicationId appId)Get the AMRM token of the application. | 
| abstract ApplicationAttemptReport | YarnClient. getApplicationAttemptReport(ApplicationAttemptId applicationAttemptId)
 Get a report of the given ApplicationAttempt. | 
| abstract ApplicationAttemptReport | AHSClient. getApplicationAttemptReport(ApplicationAttemptId applicationAttemptId)
 Get a report of the given ApplicationAttempt. | 
| abstract List<ApplicationAttemptReport> | YarnClient. getApplicationAttempts(ApplicationId applicationId)
 Get a report of all (ApplicationAttempts) of Application in the cluster. | 
| abstract List<ApplicationAttemptReport> | AHSClient. getApplicationAttempts(ApplicationId applicationId)
 Get a report of all (ApplicationAttempts) of Application in the cluster. | 
| abstract ApplicationReport | YarnClient. getApplicationReport(ApplicationId appId)
 Get a report of the given Application. | 
| abstract ApplicationReport | AHSClient. getApplicationReport(ApplicationId appId)Get a report of the given Application. | 
| abstract List<ApplicationReport> | YarnClient. getApplications()
 Get a report (ApplicationReport) of all Applications in the cluster. | 
| abstract List<ApplicationReport> | AHSClient. getApplications()
 Get a report (ApplicationReport) of all Applications in the cluster. | 
| abstract List<ApplicationReport> | YarnClient. getApplications(EnumSet<YarnApplicationState> applicationStates)
 Get a report (ApplicationReport) of Applications matching the given
 application states in the cluster. | 
| List<ApplicationReport> | YarnClient. getApplications(GetApplicationsRequest request)
 Get a list of ApplicationReports that match the given
  GetApplicationsRequest. | 
| abstract List<ApplicationReport> | YarnClient. getApplications(Set<String> applicationTypes)
 Get a report (ApplicationReport) of Applications
 matching the given application types in the cluster. | 
| abstract List<ApplicationReport> | YarnClient. getApplications(Set<String> applicationTypes,
               EnumSet<YarnApplicationState> applicationStates)
 Get a report (ApplicationReport) of Applications matching the given
 application types and application states in the cluster. | 
| abstract List<ApplicationReport> | YarnClient. getApplications(Set<String> applicationTypes,
               EnumSet<YarnApplicationState> applicationStates,
               Set<String> applicationTags)
 Get a report (ApplicationReport) of Applications matching the given
 application types, application states and application tags in the cluster. | 
| abstract List<ApplicationReport> | YarnClient. getApplications(Set<String> queues,
               Set<String> users,
               Set<String> applicationTypes,
               EnumSet<YarnApplicationState> applicationStates)
 Get a report (ApplicationReport) of Applications matching the given users,
 queues, application types and application states in the cluster. | 
| abstract List<QueueInfo> | YarnClient. getChildQueueInfos(String parent)
 Get information ( QueueInfo) about all the immediate children queues
 of the given queue | 
| abstract List<NodeLabel> | YarnClient. getClusterNodeLabels()
 The interface used by client to get node labels in the cluster | 
| abstract ContainerReport | YarnClient. getContainerReport(ContainerId containerId)
 Get a report of the given Container. | 
| abstract ContainerReport | AHSClient. getContainerReport(ContainerId containerId)
 Get a report of the given Container. | 
| abstract List<ContainerReport> | YarnClient. getContainers(ApplicationAttemptId applicationAttemptId)
 Get a report of all (Containers) of ApplicationAttempt in the cluster. | 
| abstract List<ContainerReport> | AHSClient. getContainers(ApplicationAttemptId applicationAttemptId)
 Get a report of all (Containers) of ApplicationAttempt in the cluster. | 
| abstract ContainerStatus | NMClient. getContainerStatus(ContainerId containerId,
                  NodeId nodeId)Query the status of a container. | 
| abstract Token<TimelineDelegationTokenIdentifier> | TimelineClient. getDelegationToken(String renewer)
 Get a delegation token so as to be able to talk to the timeline server in a
 secure way. | 
| abstract Map<String,Set<NodeId>> | YarnClient. getLabelsToNodes()
 The interface used by client to get labels to nodes mapping
 in existing cluster | 
| abstract Map<String,Set<NodeId>> | YarnClient. getLabelsToNodes(Set<String> labels)
 The interface used by client to get labels to nodes mapping
 for specified labels in existing cluster | 
| abstract List<NodeReport> | YarnClient. getNodeReports(NodeState... states)
 Get a report of nodes ( NodeReport) in the cluster. | 
| abstract Map<NodeId,Set<String>> | YarnClient. getNodeToLabels()
 The interface used by client to get node to labels mappings in existing cluster | 
| abstract List<QueueUserACLInfo> | YarnClient. getQueueAclsInfo()
 Get information about acls for current user on all the
 existing queues. | 
| abstract QueueInfo | YarnClient. getQueueInfo(String queueName)
 Get information ( QueueInfo) about a given queue. | 
| abstract Token | YarnClient. getRMDelegationToken(Text renewer)
 Get a delegation token so as to be able to talk to YARN using those tokens. | 
| abstract List<QueueInfo> | YarnClient. getRootQueueInfos()
 Get information ( QueueInfo) about top level queues. | 
| abstract YarnClusterMetrics | YarnClient. getYarnClusterMetrics()
 Get metrics ( YarnClusterMetrics) about the cluster. | 
| abstract void | NMClient. increaseContainerResource(Container container)Deprecated.  | 
| abstract void | YarnClient. killApplication(ApplicationId applicationId)
 Kill an application identified by given ID. | 
| abstract void | YarnClient. killApplication(ApplicationId applicationId,
               String diagnostics)
 Kill an application identified by given ID. | 
| abstract ReservationListResponse | YarnClient. listReservations(ReservationListRequest request)
 The interface used by clients to get the list of reservations in a plan. | 
| abstract void | YarnClient. moveApplicationAcrossQueues(ApplicationId appId,
                           String queue)
 Attempts to move the given application to the given queue. | 
| abstract void | TimelineClient. putDomain(ApplicationAttemptId appAttemptId,
         TimelineDomain domain)
 Send the information of a domain to the timeline server. | 
| abstract void | TimelineClient. putDomain(TimelineDomain domain)
 Send the information of a domain to the timeline server. | 
| abstract TimelinePutResponse | TimelineClient. putEntities(ApplicationAttemptId appAttemptId,
           TimelineEntityGroupId groupId,
           TimelineEntity... entities)
 Send the information of a number of conceptual entities to the timeline
 server. | 
| abstract TimelinePutResponse | TimelineClient. putEntities(TimelineEntity... entities)
 Send the information of a number of conceptual entities to the timeline
 server. | 
| abstract RegisterApplicationMasterResponse | AMRMClient. registerApplicationMaster(String appHostName,
                         int appHostPort,
                         String appTrackingUrl)Register the application master. | 
| abstract void | NMClient. reInitializeContainer(ContainerId containerId,
                     ContainerLaunchContext containerLaunchContex,
                     boolean autoCommit)Re-Initialize the Container. | 
| abstract void | SharedCacheClient. release(ApplicationId applicationId,
       String resourceKey)
 The method to release a resource with the  SharedCacheManager.This method is called once an application is no longer using a claimed
 resource in the shared cache. | 
| abstract long | TimelineClient. renewDelegationToken(Token<TimelineDelegationTokenIdentifier> timelineDT)
 Renew a timeline delegation token. | 
| abstract void | NMClient. restartContainer(ContainerId containerId)Restart the specified container. | 
| abstract void | NMClient. rollbackLastReInitialization(ContainerId containerId)Rollback last reInitialization of the specified container. | 
| abstract void | YarnClient. signalToContainer(ContainerId containerId,
                 SignalContainerCommand command)
 Signal a container identified by given ID. | 
| abstract Map<String,ByteBuffer> | NMClient. startContainer(Container container,
              ContainerLaunchContext containerLaunchContext)Start an allocated container. | 
| abstract void | NMClient. stopContainer(ContainerId containerId,
             NodeId nodeId)Stop an started container. | 
| abstract ApplicationId | YarnClient. submitApplication(ApplicationSubmissionContext appContext)
 Submit a new application to  YARN.It is a blocking call - it
 will not returnApplicationIduntil the submitted application is
 submitted successfully and accepted by the ResourceManager. | 
| abstract ReservationSubmissionResponse | YarnClient. submitReservation(ReservationSubmissionRequest request)
 The interface used by clients to submit a new reservation to the
  ResourceManager. | 
| abstract void | AMRMClient. unregisterApplicationMaster(FinalApplicationStatus appStatus,
                           String appMessage,
                           String appTrackingUrl)Unregister the application master. | 
| abstract Priority | YarnClient. updateApplicationPriority(ApplicationId applicationId,
                         Priority priority)
 The interface used by client to set priority of an application | 
| UpdateApplicationTimeoutsResponse | YarnClient. updateApplicationTimeouts(UpdateApplicationTimeoutsRequest request) | 
| abstract void | NMClient. updateContainerResource(Container container)Update the resources of a container. | 
| abstract ReservationUpdateResponse | YarnClient. updateReservation(ReservationUpdateRequest request)
 The interface used by clients to update an existing Reservation. | 
| abstract URL | SharedCacheClient. use(ApplicationId applicationId,
   String resourceKey)
 The method to claim a resource with the  SharedCacheManager.The client uses a checksum to identify the resource and anApplicationIdto identify which application will be using the
 resource. | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract RegisterApplicationMasterResponse | AMRMClientAsync. registerApplicationMaster(String appHostName,
                         int appHostPort,
                         String appTrackingUrl)Registers this application master with the resource manager. | 
| void | AMRMClientAsync. registerTimelineV2Client(org.apache.hadoop.yarn.client.api.TimelineV2Client timelineClient)Register TimelineClient to AMRMClient. | 
| abstract void | AMRMClientAsync. unregisterApplicationMaster(FinalApplicationStatus appStatus,
                           String appMessage,
                           String appTrackingUrl)Unregister the application master. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | ApplicationAttemptNotFoundExceptionThis exception is thrown on
  (GetApplicationAttemptReportRequest)API when the Application Attempt doesn't exist in Application History Server orApplicationMasterProtocol.allocate(AllocateRequest)if application
 doesn't exist in RM. | 
| class  | ApplicationIdNotProvidedExceptionException to be thrown when Client submit an application without
 providing  ApplicationIdinApplicationSubmissionContext. | 
| class  | ApplicationNotFoundExceptionThis exception is thrown on
  (GetApplicationReportRequest)API
 when the Application doesn't exist in RM and AHS | 
| class  | ConfigurationExceptionThis exception is thrown on unrecoverable configuration errors. | 
| class  | ContainerNotFoundExceptionThis exception is thrown on
  (GetContainerReportRequest)API when the container doesn't exist in AHS | 
Copyright © 2018 Apache Software Foundation. All rights reserved.