- generateToken(String) - Static method in class org.apache.hadoop.yarn.client.util.YarnClientUtils
- 
Generate SPNEGO challenge request token. 
- getAdminCommandHandler() - Method in class org.apache.hadoop.yarn.client.cli.NodeAttributesCLI
-  
- getAllocationRequestId() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-  
- getAllQueues() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getAllQueues() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get information (QueueInfo) about all queues, recursively if there
 is a hierarchy
 
- getAMContainerInfoForRMWebService(Configuration, String) - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
-  
- getAMRMToken(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getAMRMToken(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
Get the AMRM token of the application. 
- getApplicationAttemptReport(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.AHSClient
- 
 Get a report of the given ApplicationAttempt. 
- getApplicationAttemptReport(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.impl.AHSClientImpl
-  
- getApplicationAttemptReport(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.impl.AHSv2ClientImpl
-  
- getApplicationAttemptReport(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getApplicationAttemptReport(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report of the given ApplicationAttempt. 
- getApplicationAttempts(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.AHSClient
- 
 Get a report of all (ApplicationAttempts) of Application in the cluster. 
- getApplicationAttempts(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.impl.AHSClientImpl
-  
- getApplicationAttempts(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.impl.AHSv2ClientImpl
-  
- getApplicationAttempts(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getApplicationAttempts(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report of all (ApplicationAttempts) of Application in the cluster. 
- getApplicationReport(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.AHSClient
- 
Get a report of the given Application. 
- getApplicationReport(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.impl.AHSClientImpl
-  
- getApplicationReport(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.impl.AHSv2ClientImpl
-  
- getApplicationReport(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getApplicationReport(ApplicationId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report of the given Application. 
- getApplications() - Method in class org.apache.hadoop.yarn.client.api.AHSClient
- 
 Get a report (ApplicationReport) of all Applications in the cluster. 
- getApplications() - Method in class org.apache.hadoop.yarn.client.api.impl.AHSClientImpl
-  
- getApplications() - Method in class org.apache.hadoop.yarn.client.api.impl.AHSv2ClientImpl
-  
- getApplications() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getApplications(Set<String>) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getApplications(EnumSet<YarnApplicationState>) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getApplications(Set<String>, EnumSet<YarnApplicationState>) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getApplications(Set<String>, EnumSet<YarnApplicationState>, Set<String>) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getApplications(Set<String>, Set<String>, Set<String>, EnumSet<YarnApplicationState>) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getApplications(GetApplicationsRequest) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getApplications() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report (ApplicationReport) of all Applications in the cluster. 
- getApplications(Set<String>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report (ApplicationReport) of Applications
 matching the given application types in the cluster. 
- getApplications(EnumSet<YarnApplicationState>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report (ApplicationReport) of Applications matching the given
 application states in the cluster. 
- getApplications(Set<String>, EnumSet<YarnApplicationState>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report (ApplicationReport) of Applications matching the given
 application types and application states in the cluster. 
- getApplications(Set<String>, EnumSet<YarnApplicationState>, Set<String>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report (ApplicationReport) of Applications matching the given
 application types, application states and application tags in the cluster. 
- getApplications(Set<String>, Set<String>, Set<String>, EnumSet<YarnApplicationState>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report (ApplicationReport) of Applications matching the given users,
 queues, application types and application states in the cluster. 
- getApplications(GetApplicationsRequest) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a list of ApplicationReports that match the given
 GetApplicationsRequest.
 
- getApplicationSubmissionContext() - Method in class org.apache.hadoop.yarn.client.api.YarnClientApplication
-  
- getAttributesToNodes(Set<NodeAttributeKey>) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getAttributesToNodes(Set<NodeAttributeKey>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 The interface used by client to get mapping of AttributeKey to associated
 NodeToAttributeValue list for specified node attributeKeys in the cluster. 
- getAvailableResources() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Get the currently available resources in the cluster. 
- getAvailableResources() - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Get the currently available resources in the cluster. 
- getAvailableResources() - Method in class org.apache.hadoop.yarn.client.api.async.impl.AMRMClientAsyncImpl
- 
Get the currently available resources in the cluster. 
- getAvailableResources() - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- getCallbackHandler() - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
-  
- getCapability() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-  
- getChildQueueInfos(String) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getChildQueueInfos(String) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get information (QueueInfo) about all the immediate children queues
 of the given queue
 
- getCleanupRunningContainers() - Method in class org.apache.hadoop.yarn.client.api.impl.NMClientImpl
-  
- getClient() - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
-  
- getClient() - Method in class org.apache.hadoop.yarn.client.cli.YarnCLI
-  
- getClientCommandHandler() - Method in class org.apache.hadoop.yarn.client.cli.NodeAttributesCLI
-  
- getClientResponseFromTimelineReader(Configuration, String) - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
-  
- getClusterAttributes() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getClusterAttributes() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 The interface used by client to get node attributes in the cluster. 
- getClusterNodeCount() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Get the current number of nodes in the cluster. 
- getClusterNodeCount() - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Get the current number of nodes in the cluster. 
- getClusterNodeCount() - Method in class org.apache.hadoop.yarn.client.api.async.impl.AMRMClientAsyncImpl
- 
Get the current number of nodes in the cluster. 
- getClusterNodeCount() - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- getClusterNodeLabels() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getClusterNodeLabels() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 The interface used by client to get node labels in the cluster 
- getContainer() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.StartContainerEvent
-  
- getContainer() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.UpdateContainerResourceEvent
-  
- getContainerEventProcessor(NMClientAsyncImpl.ContainerEvent) - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl
-  
- getContainerId() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.ContainerEvent
-  
- getContainerId() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.StatefulContainer
-  
- getContainerId() - Method in class org.apache.hadoop.yarn.client.api.impl.NMClientImpl.StartedContainer
-  
- getContainerLaunchContext() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.ReInitializeContainerEvevnt
-  
- getContainerLaunchContext() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.StartContainerEvent
-  
- getContainerManagementProtocol() - Method in class org.apache.hadoop.yarn.client.api.impl.ContainerManagementProtocolProxy.ContainerManagementProtocolProxyData
-  
- getContainerReport(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.AHSClient
- 
 Get a report of the given Container. 
- getContainerReport(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.impl.AHSClientImpl
-  
- getContainerReport(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.impl.AHSv2ClientImpl
-  
- getContainerReport(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getContainerReport(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report of the given Container. 
- getContainerReport(String) - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
-  
- getContainers(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.AHSClient
- 
 Get a report of all (Containers) of ApplicationAttempt in the cluster. 
- getContainers(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.impl.AHSClientImpl
-  
- getContainers(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.impl.AHSv2ClientImpl
-  
- getContainers(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getContainers(ApplicationAttemptId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report of all (Containers) of ApplicationAttempt in the cluster. 
- getContainerStatus(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.client.api.impl.NMClientImpl
-  
- getContainerStatus(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.client.api.NMClient
- 
Query the status of a container. 
- getContainerStatusAsync(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl
-  
- getContainerStatusAsync(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
-  
- getContainerToken() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.ContainerEvent
-  
- getExecutionTypeRequest() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-  
- getFileChecksum(Path) - Method in class org.apache.hadoop.yarn.client.api.impl.SharedCacheClientImpl
-  
- getFileChecksum(Path) - Method in class org.apache.hadoop.yarn.client.api.SharedCacheClient
- 
A convenience method to calculate the checksum of a specified file. 
- getHAClusterUrl(Configuration, String) - Method in class org.apache.hadoop.yarn.client.cli.TopCLI
-  
- getHelp(String, StringBuilder, boolean) - Method in class org.apache.hadoop.yarn.client.cli.NodeAttributesCLI.CommandHandler
-  
- getHelp(StringBuilder, boolean) - Method in class org.apache.hadoop.yarn.client.cli.NodeAttributesCLI.CommandHandler
-  
- getLabelsToNodes() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getLabelsToNodes(Set<String>) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getLabelsToNodes() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 The interface used by client to get labels to nodes mapping
 in existing cluster 
- getLabelsToNodes(Set<String>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 The interface used by client to get labels to nodes mapping
 for specified labels in existing cluster 
- getLocalizationStatuses(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.client.api.impl.NMClientImpl
-  
- getLocalizationStatuses(ContainerId, NodeId) - Method in class org.apache.hadoop.yarn.client.api.NMClient
- 
Get the localization statuses of a container. 
- getMatchedContainerLogFiles(ContainerLogsRequest, boolean, boolean) - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
-  
- getMatchedLogTypesForRunningApp(List<ContainerLogsRequest>, boolean, boolean) - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
-  
- getMatchedOptionForRunningApp(ContainerLogsRequest, boolean, boolean) - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
-  
- getMatchingRequests(Priority, String, Resource) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Get outstanding ContainerRequests matching the given 
 parameters.
 
- getMatchingRequests(Priority, String, ExecutionType, Resource) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Get outstanding ContainerRequests matching the given
 parameters.
 
- getMatchingRequests(Priority, String, ExecutionType, Resource, String) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
-  
- getMatchingRequests(long) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Get outstanding ContainerRequests matching the given
 allocationRequestId.
 
- getMatchingRequests(Priority, String, Resource) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
-  
- getMatchingRequests(Priority, String, ExecutionType, Resource) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Returns all matching ContainerRequests that match the given Priority,
 ResourceName, ExecutionType and Capability. 
- getMatchingRequests(long) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Returns all matching ContainerRequests that match the given
 AllocationRequestId. 
- getMatchingRequests(Priority, String, Resource) - Method in class org.apache.hadoop.yarn.client.api.async.impl.AMRMClientAsyncImpl
-  
- getMatchingRequests(long) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- getMatchingRequests(Priority, String, Resource) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- getMatchingRequests(Priority, String, ExecutionType, Resource, String) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- getMatchingRequests(Priority, String, ExecutionType, Resource) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- getNewApplicationResponse() - Method in class org.apache.hadoop.yarn.client.api.YarnClientApplication
-  
- getNMToken(String) - Static method in class org.apache.hadoop.yarn.client.api.NMTokenCache
- 
Returns NMToken, null if absent. 
- getNMTokenCache() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Get the NM token cache of the AMRMClient.
 
- getNMTokenCache() - Method in class org.apache.hadoop.yarn.client.api.NMClient
- 
Get the NM token cache of the NMClient.
 
- getNodeHttpAddressFromRMWebString(ContainerLogsRequest) - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
-  
- getNodeId() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.ContainerEvent
-  
- getNodeId() - Method in class org.apache.hadoop.yarn.client.api.impl.NMClientImpl.StartedContainer
-  
- getNodeIdOfStartedContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.impl.NMClientImpl
-  
- getNodeIdOfStartedContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.NMClient
- 
Get the NodeId of the node on which container is running. 
- getNodeLabelExpression() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-  
- getNodeLabelManagerInstance(Configuration) - Static method in class org.apache.hadoop.yarn.client.cli.RMAdminCLI
-  
- getNodeReports(NodeState...) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getNodeReports(NodeState...) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a report of nodes (NodeReport) in the cluster.
 
- getNodes() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-  
- getNodesInfo() - Method in class org.apache.hadoop.yarn.client.cli.TopCLI
-  
- getNodeToAttributes(Set<String>) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getNodeToAttributes(Set<String>) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 The interface used by client to get all node to attribute mapping in
 existing cluster. 
- getNodeToLabels() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getNodeToLabels() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 The interface used by client to get node to labels mappings in existing cluster 
- getOptions() - Method in class org.apache.hadoop.yarn.client.cli.NodeAttributesCLI.CommandHandler
-  
- getPriority() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-  
- getProgress() - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.AbstractCallbackHandler
-  
- getProgress() - Method in interface org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.CallbackHandler
- 
Deprecated. 
- getProxy(String, ContainerId) - Method in class org.apache.hadoop.yarn.client.api.impl.ContainerManagementProtocolProxy
-  
- getQueueAclsInfo() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getQueueAclsInfo() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get information about acls for current user on all the
 existing queues. 
- getQueueInfo(String) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getQueueInfo(String) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get information (QueueInfo) about a given queue.
 
- getQueueMetrics() - Method in class org.apache.hadoop.yarn.client.cli.TopCLI
-  
- getRacks() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-  
- getRegisteredTimelineV2Client() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Get registered timeline v2 client. 
- getRegisteredTimelineV2Client() - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Get registered timeline client. 
- getRelaxLocality() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-  
- getResourceProfile() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-  
- getResourceProfile(String) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getResourceProfile(String) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get the details of a specific resource profile from the RM. 
- getResourceProfiles() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getResourceProfiles() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get the resource profiles available in the RM. 
- getResourceTypeInfo() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getResourceTypeInfo() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get available resource types supported by RM. 
- getResponseFromNMWebService(Configuration, Client, ContainerLogsRequest, String) - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
-  
- getRMDelegationToken(Text) - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getRMDelegationToken(Text) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get a delegation token so as to be able to talk to YARN using those tokens. 
- getRmPrincipal(Configuration) - Static method in class org.apache.hadoop.yarn.client.util.YarnClientUtils
- 
Look up and return the resource manager's principal. 
- getRmPrincipal(String, Configuration) - Static method in class org.apache.hadoop.yarn.client.util.YarnClientUtils
- 
Perform the _HOSTreplacement in theprincipal,
 Returning the result.
 
- getRootQueueInfos() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getRootQueueInfos() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get information (QueueInfo) about top level queues.
 
- getSingleton() - Static method in class org.apache.hadoop.yarn.client.api.NMTokenCache
- 
Returns the singleton NM token cache. 
- getState() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.StatefulContainer
-  
- getTargetIds(String) - Method in class org.apache.hadoop.yarn.client.cli.RMAdminCLI
- 
returns the list of all resourcemanager ids for the given configuration. 
- getToken(String) - Method in class org.apache.hadoop.yarn.client.api.NMTokenCache
- 
Returns NMToken, null if absent 
- getUsageString() - Method in class org.apache.hadoop.yarn.client.cli.RMAdminCLI
-  
- getYarnClusterMetrics() - Method in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- getYarnClusterMetrics() - Method in class org.apache.hadoop.yarn.client.api.YarnClient
- 
 Get metrics (YarnClusterMetrics) about the cluster.
 
- onClose(Session, int, String) - Method in class org.apache.hadoop.yarn.client.api.ContainerShellWebSocket
-  
- onCommitLastReInitialization(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
Callback for commit of last re-initialization. 
- onCommitLastReInitializationError(ContainerId, Throwable) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
Error Callback for commit of last re-initialization. 
- onConnect(Session) - Method in class org.apache.hadoop.yarn.client.api.ContainerShellWebSocket
-  
- onContainerReInitialize(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
Callback for container re-initialization request. 
- onContainerReInitializeError(ContainerId, Throwable) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
Error Callback for container re-initialization request. 
- onContainerResourceIncreased(ContainerId, Resource) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
Deprecated. 
- onContainerResourceUpdated(ContainerId, Resource) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
The API is called when NodeManagerresponds to indicate
 the container resource has been successfully updated.
 
- onContainerRestart(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
Callback for container restart. 
- onContainerRestartError(ContainerId, Throwable) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
Error Callback for container restart. 
- onContainersAllocated(List<Container>) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.AbstractCallbackHandler
- 
Called when the ResourceManager responds to a heartbeat with allocated
 containers. 
- onContainersAllocated(List<Container>) - Method in interface org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.CallbackHandler
- 
Deprecated. Called when the ResourceManager responds to a heartbeat with allocated
 containers. 
- onContainersCompleted(List<ContainerStatus>) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.AbstractCallbackHandler
- 
Called when the ResourceManager responds to a heartbeat with completed
 containers. 
- onContainersCompleted(List<ContainerStatus>) - Method in interface org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.CallbackHandler
- 
Deprecated. Called when the ResourceManager responds to a heartbeat with completed
 containers. 
- onContainersReceivedFromPreviousAttempts(List<Container>) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.AbstractCallbackHandler
- 
Called when the ResourceManager responds to a heartbeat with containers
 from previous attempt. 
- onContainerStarted(ContainerId, Map<String, ByteBuffer>) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
The API is called when NodeManagerresponds to indicate its
 acceptance of the starting container request.
 
- onContainerStarted(ContainerId, Map<String, ByteBuffer>) - Method in interface org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler
- 
Deprecated. The API is called when NodeManagerresponds to indicate its
 acceptance of the starting container request
 
- onContainerStatusReceived(ContainerId, ContainerStatus) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
The API is called when NodeManagerresponds with the status
 of the container.
 
- onContainerStatusReceived(ContainerId, ContainerStatus) - Method in interface org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler
- 
Deprecated. The API is called when NodeManagerresponds with the status
 of the container
 
- onContainerStopped(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
The API is called when NodeManagerresponds to indicate the
 container is stopped.
 
- onContainerStopped(ContainerId) - Method in interface org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler
- 
Deprecated. The API is called when NodeManagerresponds to indicate the
 container is stopped.
 
- onContainersUpdated(List<UpdatedContainer>) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.AbstractCallbackHandler
- 
Called when the ResourceManager responds to a heartbeat with containers
 whose resource allocation has been changed. 
- onError(Throwable) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.AbstractCallbackHandler
- 
Called when error comes from RM communications as well as from errors in
 the callback itself from the app. 
- onError(Throwable) - Method in interface org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.CallbackHandler
- 
Deprecated. Called when error comes from RM communications as well as from errors in
 the callback itself from the app. 
- onGetContainerStatusError(ContainerId, Throwable) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
The API is called when an exception is raised in the process of
 querying the status of a container. 
- onGetContainerStatusError(ContainerId, Throwable) - Method in interface org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler
- 
Deprecated. The API is called when an exception is raised in the process of
 querying the status of a container 
- onIncreaseContainerResourceError(ContainerId, Throwable) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
Deprecated. 
- onNodesUpdated(List<NodeReport>) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.AbstractCallbackHandler
- 
Called when nodes tracked by the ResourceManager have changed in health,
 availability etc. 
- onNodesUpdated(List<NodeReport>) - Method in interface org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.CallbackHandler
- 
Deprecated. Called when nodes tracked by the ResourceManager have changed in health,
 availability etc. 
- onPreemptionMessageReceived(PreemptionMessage) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.AbstractCallbackHandler
- 
Called when the RM responds to a heartbeat with preemption message 
- onRequestsRejected(List<RejectedSchedulingRequest>) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.AbstractCallbackHandler
- 
Called when the RM has rejected Scheduling Requests. 
- onRollbackLastReInitialization(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
Callback for rollback of last re-initialization. 
- onRollbackLastReInitializationError(ContainerId, Throwable) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
Error Callback for rollback of last re-initialization. 
- onShutdownRequest() - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.AbstractCallbackHandler
- 
Called when the ResourceManager wants the ApplicationMaster to shutdown
 for being out of sync etc. 
- onShutdownRequest() - Method in interface org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.CallbackHandler
- 
Deprecated. Called when the ResourceManager wants the ApplicationMaster to shutdown
 for being out of sync etc. 
- onStartContainerError(ContainerId, Throwable) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
The API is called when an exception is raised in the process of
 starting a container. 
- onStartContainerError(ContainerId, Throwable) - Method in interface org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler
- 
Deprecated. The API is called when an exception is raised in the process of
 starting a container 
- onStopContainerError(ContainerId, Throwable) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
The API is called when an exception is raised in the process of
 stopping a container. 
- onStopContainerError(ContainerId, Throwable) - Method in interface org.apache.hadoop.yarn.client.api.async.NMClientAsync.CallbackHandler
- 
Deprecated. The API is called when an exception is raised in the process of
 stopping a container 
- onText(Session, String) - Method in class org.apache.hadoop.yarn.client.api.ContainerShellWebSocket
-  
- onUpdateContainerResourceError(ContainerId, Throwable) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync.AbstractCallbackHandler
- 
The API is called when an exception is raised in the process of
 updating container resource. 
- org.apache.hadoop.yarn.client - package org.apache.hadoop.yarn.client
-  
- org.apache.hadoop.yarn.client.api - package org.apache.hadoop.yarn.client.api
-  
- org.apache.hadoop.yarn.client.api.async - package org.apache.hadoop.yarn.client.api.async
-  
- org.apache.hadoop.yarn.client.api.async.impl - package org.apache.hadoop.yarn.client.api.async.impl
-  
- org.apache.hadoop.yarn.client.api.impl - package org.apache.hadoop.yarn.client.api.impl
-  
- org.apache.hadoop.yarn.client.cli - package org.apache.hadoop.yarn.client.cli
-  
- org.apache.hadoop.yarn.client.util - package org.apache.hadoop.yarn.client.util
-  
- OutOfOrderTransition() - Constructor for class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.StatefulContainer.OutOfOrderTransition
-  
- racks(String[]) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest.ContainerRequestBuilder
-  
- registerApplicationMaster(String, int, String) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Register the application master. 
- registerApplicationMaster(String, int, String, Map<Set<String>, PlacementConstraint>) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Register the application master. 
- registerApplicationMaster(String, int, String) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Registers this application master with the resource manager. 
- registerApplicationMaster(String, int, String, Map<Set<String>, PlacementConstraint>) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Register the application master. 
- registerApplicationMaster(String, int, String) - Method in class org.apache.hadoop.yarn.client.api.async.impl.AMRMClientAsyncImpl
- 
Registers this application master with the resource manager. 
- registerApplicationMaster(String, int, String, Map<Set<String>, PlacementConstraint>) - Method in class org.apache.hadoop.yarn.client.api.async.impl.AMRMClientAsyncImpl
- 
Registers this application master with the resource manager. 
- registerApplicationMaster(String, int, String) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- registerApplicationMaster(String, int, String, Map<Set<String>, PlacementConstraint>) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- registerTimelineV2Client(TimelineV2Client) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Register TimelineV2Client to AMRMClient. 
- registerTimelineV2Client(TimelineV2Client) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Register TimelineClient to AMRMClient. 
- reInitializeContainer(ContainerId, ContainerLaunchContext, boolean) - Method in class org.apache.hadoop.yarn.client.api.impl.NMClientImpl
-  
- reInitializeContainer(ContainerId, ContainerLaunchContext, boolean) - Method in class org.apache.hadoop.yarn.client.api.NMClient
- 
Re-Initialize the Container. 
- reInitializeContainerAsync(ContainerId, ContainerLaunchContext, boolean) - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl
-  
- reInitializeContainerAsync(ContainerId, ContainerLaunchContext, boolean) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
- 
Re-Initialize the Container. 
- ReInitializeContainerEvevnt(ContainerId, NodeId, ContainerLaunchContext, boolean) - Constructor for class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.ReInitializeContainerEvevnt
-  
- ReInitializeContainerTransition() - Constructor for class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.StatefulContainer.ReInitializeContainerTransition
-  
- relaxLocality(boolean) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest.ContainerRequestBuilder
-  
- release - Variable in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- release(ApplicationId, String) - Method in class org.apache.hadoop.yarn.client.api.impl.SharedCacheClientImpl
-  
- release(ApplicationId, String) - Method in class org.apache.hadoop.yarn.client.api.SharedCacheClient
- 
 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.
 
- releaseAssignedContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Release containers assigned by the Resource Manager. 
- releaseAssignedContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Release containers assigned by the Resource Manager. 
- releaseAssignedContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.impl.AMRMClientAsyncImpl
- 
Release containers assigned by the Resource Manager. 
- releaseAssignedContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- removeContainerRequest(T) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Remove previous container request. 
- removeContainerRequest(T) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Remove previous container request. 
- removeContainerRequest(T) - Method in class org.apache.hadoop.yarn.client.api.async.impl.AMRMClientAsyncImpl
- 
Remove previous container request. 
- removeContainerRequest(T) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- removePendingChangeRequests(List<UpdatedContainer>) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- removePendingReleaseRequests(List<ContainerStatus>) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- removeToken(String) - Method in class org.apache.hadoop.yarn.client.api.NMTokenCache
- 
Removes NMToken for specified node manager 
- requestContainerResourceChange(Container, Resource) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
- requestContainerResourceChange(Container, Resource) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
- requestContainerUpdate(Container, UpdateContainerRequest) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
- 
Request a container update before calling allocate.
 
- requestContainerUpdate(Container, UpdateContainerRequest) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
- 
Request a container update before calling allocate.
 
- requestContainerUpdate(Container, UpdateContainerRequest) - Method in class org.apache.hadoop.yarn.client.api.async.impl.AMRMClientAsyncImpl
-  
- requestContainerUpdate(Container, UpdateContainerRequest) - Method in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- ReservedContainersComparator - Static variable in class org.apache.hadoop.yarn.client.cli.TopCLI
-  
- ReservedMemoryComparator - Static variable in class org.apache.hadoop.yarn.client.cli.TopCLI
-  
- ReservedVCoresComparator - Static variable in class org.apache.hadoop.yarn.client.cli.TopCLI
-  
- resolveTarget(String) - Method in class org.apache.hadoop.yarn.client.cli.RMAdminCLI
-  
- resourceProfile(String) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest.ContainerRequestBuilder
-  
- resourceProfilesMap - Variable in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- restartContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.impl.NMClientImpl
-  
- restartContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.NMClient
- 
Restart the specified container. 
- restartContainerAsync(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl
-  
- restartContainerAsync(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
- 
Restart the specified container. 
- RMAdminCLI - Class in org.apache.hadoop.yarn.client.cli
-  
- RMAdminCLI() - Constructor for class org.apache.hadoop.yarn.client.cli.RMAdminCLI
-  
- RMAdminCLI(Configuration) - Constructor for class org.apache.hadoop.yarn.client.cli.RMAdminCLI
-  
- rmClient - Variable in class org.apache.hadoop.yarn.client.api.impl.AMRMClientImpl
-  
- rmClient - Variable in class org.apache.hadoop.yarn.client.api.impl.YarnClientImpl
-  
- rollbackLastReInitialization(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.impl.NMClientImpl
-  
- rollbackLastReInitialization(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.NMClient
- 
Rollback last reInitialization of the specified container. 
- rollbackLastReInitializationAsync(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl
-  
- rollbackLastReInitializationAsync(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.async.NMClientAsync
- 
Rollback last reInitialization of the specified container. 
- run() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.ContainerEventProcessor
-  
- run() - Method in class org.apache.hadoop.yarn.client.api.ContainerShellWebSocket
-  
- run(String[]) - Method in class org.apache.hadoop.yarn.client.cli.ApplicationCLI
-  
- run(String[]) - Method in class org.apache.hadoop.yarn.client.cli.ClusterCLI
-  
- run(String[]) - Method in class org.apache.hadoop.yarn.client.cli.LogsCLI
-  
- run(String[]) - Method in class org.apache.hadoop.yarn.client.cli.NodeAttributesCLI
-  
- run(String[]) - Method in class org.apache.hadoop.yarn.client.cli.NodeCLI
-  
- run(String[]) - Method in class org.apache.hadoop.yarn.client.cli.QueueCLI
-  
- run(String[]) - Method in class org.apache.hadoop.yarn.client.cli.RMAdminCLI
-  
- run(String[]) - Method in class org.apache.hadoop.yarn.client.cli.SchedConfCLI
-  
- run(String[]) - Method in class org.apache.hadoop.yarn.client.cli.TopCLI
-  
- run(String[]) - Method in class org.apache.hadoop.yarn.client.SCMAdmin
-  
- RunningTimeComparator - Static variable in class org.apache.hadoop.yarn.client.cli.TopCLI
-