- 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
- 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.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.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.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.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() - 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.
- getApplicationSubmissionContext() - Method in class org.apache.hadoop.yarn.client.api.YarnClientApplication
-
- 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
-
- 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
-
Get labels for nodes in the cluster
- getContainer() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.StartContainerEvent
-
- 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.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.YarnClientImpl
-
- getContainerReport(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.YarnClient
-
Get a report of the given Container.
- 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.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
-
- getMatchingRequests(Priority, String, Resource) - Method in class org.apache.hadoop.yarn.client.api.AMRMClient
-
Get outstanding ContainerRequest
s matching the given
parameters.
- getMatchingRequests(Priority, String, Resource) - Method in class org.apache.hadoop.yarn.client.api.async.AMRMClientAsync
-
- getMatchingRequests(Priority, String, Resource) - Method in class org.apache.hadoop.yarn.client.api.async.impl.AMRMClientAsyncImpl
-
- getMatchingRequests(Priority, String, 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
.
- 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
-
- 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
-
- getPriority() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-
- getProgress() - Method in interface org.apache.hadoop.yarn.client.api.async.AMRMClientAsync.CallbackHandler
-
- 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.
- getRacks() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-
- getRelaxLocality() - Method in class org.apache.hadoop.yarn.client.api.AMRMClient.ContainerRequest
-
- 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.
- 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.
- getStartedContainer(ContainerId) - Method in class org.apache.hadoop.yarn.client.api.impl.NMClientImpl
-
- getState() - Method in class org.apache.hadoop.yarn.client.api.async.impl.NMClientAsyncImpl.StatefulContainer
-
- getToken(String) - Method in class org.apache.hadoop.yarn.client.api.NMTokenCache
-
Returns NMToken, null if absent
- 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.