Package | Description |
---|---|
org.apache.hadoop.yarn.api | |
org.apache.hadoop.yarn.applications.distributedshell | |
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
ApplicationMaster and the
ResourceManager . |
ReservationDeleteResponse |
ApplicationClientProtocol.deleteReservation(ReservationDeleteRequest request)
The interface used by clients to remove an existing Reservation.
|
FinishApplicationMasterResponse |
ApplicationMasterProtocol.finishApplicationMaster(FinishApplicationMasterRequest request)
The interface used by an
ApplicationMaster to notify the
ResourceManager about its completion (success or failed). |
KillApplicationResponse |
ApplicationClientProtocol.forceKillApplication(KillApplicationRequest request)
The interface used by clients to request the
ResourceManager to 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
ApplicationMaster to request for current
statuses of Container s from the NodeManager . |
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
ApplicationId for
submitting new applications. |
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 . |
MoveApplicationAcrossQueuesResponse |
ApplicationClientProtocol.moveApplicationAcrossQueues(MoveApplicationAcrossQueuesRequest request)
Move an application to a new queue.
|
RegisterApplicationMasterResponse |
ApplicationMasterProtocol.registerApplicationMaster(RegisterApplicationMasterRequest request)
The interface used by a new
ApplicationMaster to register with
the ResourceManager . |
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. |
StartContainersResponse |
ContainerManagementProtocol.startContainers(StartContainersRequest request)
The
ApplicationMaster provides a list of
StartContainerRequest s to a NodeManager to
start Container s allocated to it using this interface. |
StopContainersResponse |
ContainerManagementProtocol.stopContainers(StopContainersRequest request)
The
ApplicationMaster requests a NodeManager to
stop a list of Container s 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 . |
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 an ApplicationId to identify which application will be
using the resource. |
Modifier and Type | Method and Description |
---|---|
boolean |
Client.run()
Main run function for the client
|
void |
ApplicationMaster.run()
Main run function for the application master
|
Modifier and Type | Method and Description |
---|---|
abstract AllocateResponse |
AMRMClient.allocate(float progressIndicator)
Request additional containers and receive new container allocations.
|
abstract void |
TimelineClient.cancelDelegationToken(org.apache.hadoop.security.token.Token<TimelineDelegationTokenIdentifier> timelineDT)
Cancel a timeline delegation token.
|
abstract YarnClientApplication |
YarnClient.createApplication()
Obtain a
YarnClientApplication for a new application,
which in turn contains the ApplicationSubmissionContext and
GetNewApplicationResponse
objects. |
abstract ReservationDeleteResponse |
YarnClient.deleteReservation(ReservationDeleteRequest request)
The interface used by clients to remove an existing Reservation.
|
abstract List<QueueInfo> |
YarnClient.getAllQueues()
Get information (
QueueInfo ) about all queues, recursively if there
is a hierarchy |
abstract org.apache.hadoop.security.token.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.
|
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<QueueInfo> |
YarnClient.getChildQueueInfos(String parent)
Get information (
QueueInfo ) about all the immediate children queues
of the given queue |
abstract Set<String> |
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 org.apache.hadoop.security.token.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 |
YarnClient.killApplication(ApplicationId applicationId)
Kill an application identified by given ID.
|
abstract void |
YarnClient.moveApplicationAcrossQueues(ApplicationId appId,
String queue)
Attempts to move the given application to the given queue.
|
abstract void |
TimelineClient.putDomain(TimelineDomain domain)
Send the information of a domain 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 |
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(org.apache.hadoop.security.token.Token<TimelineDelegationTokenIdentifier> timelineDT)
Renew a timeline delegation token.
|
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 return ApplicationId until 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 ReservationUpdateResponse |
YarnClient.updateReservation(ReservationUpdateRequest request)
The interface used by clients to update an existing Reservation.
|
abstract Path |
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 an
ApplicationId to 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.
|
abstract void |
AMRMClientAsync.unregisterApplicationMaster(FinalApplicationStatus appStatus,
String appMessage,
String appTrackingUrl)
Unregister the application master.
|
Modifier and Type | Class and Description |
---|---|
class |
ApplicationAttemptNotFoundException
This exception is thrown on
(GetApplicationAttemptReportRequest)
API when the Application Attempt doesn't exist in Application History Server or
ApplicationMasterProtocol.allocate(AllocateRequest) if application
doesn't exist in RM. |
class |
ApplicationIdNotProvidedException
Exception to be thrown when Client submit an application without
providing
ApplicationId in ApplicationSubmissionContext . |
class |
ApplicationNotFoundException
This exception is thrown on
(GetApplicationReportRequest) API
when the Application doesn't exist in RM and AHS |
class |
ContainerNotFoundException
This exception is thrown on
(GetContainerReportRequest)
API when the container doesn't exist in AHS |
Copyright © 2016 Apache Software Foundation. All rights reserved.