public interface Context
| Modifier and Type | Method and Description | 
|---|---|
| org.apache.hadoop.yarn.server.security.ApplicationACLsManager | getApplicationACLsManager() | 
| ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,Application> | getApplications() | 
| org.apache.hadoop.conf.Configuration | getConf() | 
| org.apache.hadoop.yarn.server.scheduler.OpportunisticContainerAllocator | getContainerAllocator() | 
| ContainerExecutor | getContainerExecutor() | 
| ContainerManager | getContainerManager() | 
| ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,Container> | getContainers() | 
| ContainerStateTransitionListener | getContainerStateTransitionListener() | 
| NMContainerTokenSecretManager | getContainerTokenSecretManager() | 
| boolean | getDecommissioned() | 
| DeletionService | getDeletionService()Get the  DeletionServiceassociated with the NM. | 
| int | getHttpPort()Return the node http-address. | 
| ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,org.apache.hadoop.yarn.api.records.Container> | getIncreasedContainers() | 
| ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.yarn.server.api.records.AppCollectorData> | getKnownCollectors()Get the list of collectors registered with the RM and known by this node. | 
| LocalDirsHandlerService | getLocalDirsHandler() | 
| ConcurrentLinkedQueue<org.apache.hadoop.yarn.server.api.protocolrecords.LogAggregationReport> | getLogAggregationStatusForApps() | 
| NMLogAggregationStatusTracker | getNMLogAggregationStatusTracker() | 
| NMStateStoreService | getNMStateStore() | 
| NMTimelinePublisher | getNMTimelinePublisher() | 
| NMTokenSecretManagerInNM | getNMTokenSecretManager() | 
| org.apache.hadoop.yarn.server.api.records.NodeHealthStatus | getNodeHealthStatus() | 
| org.apache.hadoop.yarn.api.records.NodeId | getNodeId()Return the nodeId. | 
| NodeManagerMetrics | getNodeManagerMetrics() | 
| NodeResourceMonitor | getNodeResourceMonitor() | 
| NodeStatusUpdater | getNodeStatusUpdater() | 
| ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.yarn.server.api.records.AppCollectorData> | getRegisteringCollectors()Get the list of collectors that are registering with the RM from this node. | 
| ResourcePluginManager | getResourcePluginManager() | 
| Map<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.security.Credentials> | getSystemCredentialsForApps() | 
| boolean | isDistributedSchedulingEnabled() | 
| void | setDecommissioned(boolean isDecommissioned) | 
| void | setNMTimelinePublisher(NMTimelinePublisher nmMetricsPublisher) | 
org.apache.hadoop.yarn.api.records.NodeId getNodeId()
int getHttpPort()
ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,Application> getApplications()
Map<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.security.Credentials> getSystemCredentialsForApps()
ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.yarn.server.api.records.AppCollectorData> getRegisteringCollectors()
ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.yarn.server.api.records.AppCollectorData> getKnownCollectors()
ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,Container> getContainers()
ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,org.apache.hadoop.yarn.api.records.Container> getIncreasedContainers()
NMContainerTokenSecretManager getContainerTokenSecretManager()
NMTokenSecretManagerInNM getNMTokenSecretManager()
org.apache.hadoop.yarn.server.api.records.NodeHealthStatus getNodeHealthStatus()
ContainerManager getContainerManager()
NodeResourceMonitor getNodeResourceMonitor()
LocalDirsHandlerService getLocalDirsHandler()
org.apache.hadoop.yarn.server.security.ApplicationACLsManager getApplicationACLsManager()
NMStateStoreService getNMStateStore()
boolean getDecommissioned()
org.apache.hadoop.conf.Configuration getConf()
void setDecommissioned(boolean isDecommissioned)
ConcurrentLinkedQueue<org.apache.hadoop.yarn.server.api.protocolrecords.LogAggregationReport> getLogAggregationStatusForApps()
NodeStatusUpdater getNodeStatusUpdater()
boolean isDistributedSchedulingEnabled()
org.apache.hadoop.yarn.server.scheduler.OpportunisticContainerAllocator getContainerAllocator()
void setNMTimelinePublisher(NMTimelinePublisher nmMetricsPublisher)
NMTimelinePublisher getNMTimelinePublisher()
NMLogAggregationStatusTracker getNMLogAggregationStatusTracker()
ContainerExecutor getContainerExecutor()
ContainerStateTransitionListener getContainerStateTransitionListener()
ResourcePluginManager getResourcePluginManager()
NodeManagerMetrics getNodeManagerMetrics()
DeletionService getDeletionService()
DeletionService associated with the NM.DeletionService.Copyright © 2008–2018 Apache Software Foundation. All rights reserved.