Package | Description |
---|---|
org.apache.hadoop.yarn.api.records |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.client.api | |
org.apache.hadoop.yarn.client.api.async | |
org.apache.hadoop.yarn.logaggregation.filecontroller |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.security |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.util |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
Modifier and Type | Method and Description |
---|---|
static NodeId |
NodeId.fromString(String nodeIdStr) |
abstract NodeId |
ContainerReport.getAssignedNode()
Get the allocated
NodeId where container is running. |
abstract NodeId |
Container.getNodeId()
Get the identifier of the node on which the container is allocated.
|
abstract NodeId |
NodeReport.getNodeId()
Get the
NodeId of the node. |
abstract NodeId |
NMToken.getNodeId()
Get the
NodeId of the NodeManager for which the NMToken
is used to authenticate. |
static NodeId |
NodeId.newInstance(String host,
int port) |
Modifier and Type | Method and Description |
---|---|
int |
NodeId.compareTo(NodeId other) |
abstract void |
ContainerReport.setAssignedNode(NodeId nodeId) |
abstract void |
NMToken.setNodeId(NodeId nodeId) |
Modifier and Type | Method and Description |
---|---|
NodeId |
NMClient.getNodeIdOfStartedContainer(ContainerId containerId)
Get the NodeId of the node on which container is running.
|
Modifier and Type | Method and Description |
---|---|
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 Map<NodeId,Set<String>> |
YarnClient.getNodeToLabels()
The interface used by client to get node to labels mappings in existing cluster
|
Modifier and Type | Method and Description |
---|---|
abstract ContainerStatus |
NMClient.getContainerStatus(ContainerId containerId,
NodeId nodeId)
Query the status of a container.
|
List<LocalizationStatus> |
NMClient.getLocalizationStatuses(ContainerId containerId,
NodeId nodeId)
Get the localization statuses of a container.
|
void |
NMClient.localize(ContainerId containerId,
NodeId nodeId,
Map<String,LocalResource> localResources)
Localize resources for a container.
|
abstract void |
NMClient.stopContainer(ContainerId containerId,
NodeId nodeId)
Stop an started container.
|
Modifier and Type | Method and Description |
---|---|
abstract void |
NMClientAsync.getContainerStatusAsync(ContainerId containerId,
NodeId nodeId) |
abstract void |
NMClientAsync.stopContainerAsync(ContainerId containerId,
NodeId nodeId) |
Modifier and Type | Method and Description |
---|---|
protected void |
LogAggregationFileController.cleanOldLogs(Path remoteNodeLogFileForApp,
NodeId nodeId,
UserGroupInformation userUgi) |
Path |
LogAggregationFileController.getRemoteNodeLogFileForApp(ApplicationId appId,
String user,
NodeId nodeId)
Get the remote aggregated log path.
|
Modifier and Type | Method and Description |
---|---|
NodeId |
NMTokenIdentifier.getNodeId() |
Constructor and Description |
---|
NMTokenIdentifier(ApplicationAttemptId appAttemptId,
NodeId nodeId,
String applicationSubmitter,
int masterKeyId) |
Modifier and Type | Method and Description |
---|---|
static NodeId |
ConverterUtils.toNodeId(String nodeIdStr)
Deprecated.
|
Copyright © 2024 Apache Software Foundation. All rights reserved.