public static class NodeManager.NMContext extends Object implements Context
Modifier and Type | Field and Description |
---|---|
protected ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,Application> |
applications |
protected ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,Container> |
containers |
protected ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,org.apache.hadoop.yarn.api.records.Container> |
increasedContainers |
Constructor and Description |
---|
NMContext(NMContainerTokenSecretManager containerTokenSecretManager,
NMTokenSecretManagerInNM nmTokenSecretManager,
LocalDirsHandlerService dirsHandler,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager,
NMStateStoreService stateStore,
boolean isDistSchedulingEnabled,
org.apache.hadoop.conf.Configuration conf) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.yarn.server.security.ApplicationACLsManager |
getApplicationACLsManager() |
ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,Application> |
getApplications() |
AuxServices |
getAuxServices() |
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()
Return the NM's
DeletionService . |
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()
Usable only after ContainerManager is started.
|
NodeManagerMetrics |
getNodeManagerMetrics()
Returns the
NodeManagerMetrics instance of this node. |
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 |
setAuxServices(AuxServices auxServices) |
void |
setContainerExecutor(ContainerExecutor executor) |
void |
setContainerManager(ContainerManager containerManager) |
void |
setContainerStateTransitionListener(ContainerStateTransitionListener transitionListener) |
void |
setDecommissioned(boolean isDecommissioned) |
void |
setDeletionService(DeletionService deletionService)
Set the NM's
DeletionService . |
void |
setNMLogAggregationStatusTracker(NMLogAggregationStatusTracker nmLogAggregationStatusTracker) |
void |
setNMTimelinePublisher(NMTimelinePublisher nmMetricsPublisher) |
void |
setNodeId(org.apache.hadoop.yarn.api.records.NodeId nodeId) |
void |
setNodeManagerMetrics(NodeManagerMetrics nmMetrics) |
void |
setNodeResourceMonitor(NodeResourceMonitor nodeResourceMonitor) |
void |
setNodeStatusUpdater(NodeStatusUpdater nodeStatusUpdater) |
void |
setQueueableContainerAllocator(org.apache.hadoop.yarn.server.scheduler.OpportunisticContainerAllocator containerAllocator) |
void |
setResourcePluginManager(ResourcePluginManager resourcePluginManager) |
void |
setSystemCrendentialsForApps(Map<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.security.Credentials> systemCredentials) |
void |
setWebServer(WebServer webServer) |
protected final ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,Application> applications
protected final ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,Container> containers
protected final ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,org.apache.hadoop.yarn.api.records.Container> increasedContainers
public NMContext(NMContainerTokenSecretManager containerTokenSecretManager, NMTokenSecretManagerInNM nmTokenSecretManager, LocalDirsHandlerService dirsHandler, org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager, NMStateStoreService stateStore, boolean isDistSchedulingEnabled, org.apache.hadoop.conf.Configuration conf)
public org.apache.hadoop.yarn.api.records.NodeId getNodeId()
public int getHttpPort()
Context
getHttpPort
in interface Context
public ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,Application> getApplications()
getApplications
in interface Context
public org.apache.hadoop.conf.Configuration getConf()
public ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,Container> getContainers()
getContainers
in interface Context
public ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,org.apache.hadoop.yarn.api.records.Container> getIncreasedContainers()
getIncreasedContainers
in interface Context
public NMContainerTokenSecretManager getContainerTokenSecretManager()
getContainerTokenSecretManager
in interface Context
public NMTokenSecretManagerInNM getNMTokenSecretManager()
getNMTokenSecretManager
in interface Context
public org.apache.hadoop.yarn.server.api.records.NodeHealthStatus getNodeHealthStatus()
getNodeHealthStatus
in interface Context
public NodeResourceMonitor getNodeResourceMonitor()
getNodeResourceMonitor
in interface Context
public void setNodeResourceMonitor(NodeResourceMonitor nodeResourceMonitor)
public ContainerManager getContainerManager()
getContainerManager
in interface Context
public void setContainerManager(ContainerManager containerManager)
public void setWebServer(WebServer webServer)
public void setNodeId(org.apache.hadoop.yarn.api.records.NodeId nodeId)
public LocalDirsHandlerService getLocalDirsHandler()
getLocalDirsHandler
in interface Context
public org.apache.hadoop.yarn.server.security.ApplicationACLsManager getApplicationACLsManager()
getApplicationACLsManager
in interface Context
public NMStateStoreService getNMStateStore()
getNMStateStore
in interface Context
public boolean getDecommissioned()
getDecommissioned
in interface Context
public void setDecommissioned(boolean isDecommissioned)
setDecommissioned
in interface Context
public Map<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.security.Credentials> getSystemCredentialsForApps()
getSystemCredentialsForApps
in interface Context
public void setSystemCrendentialsForApps(Map<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.security.Credentials> systemCredentials)
public ConcurrentLinkedQueue<org.apache.hadoop.yarn.server.api.protocolrecords.LogAggregationReport> getLogAggregationStatusForApps()
getLogAggregationStatusForApps
in interface Context
public NodeStatusUpdater getNodeStatusUpdater()
getNodeStatusUpdater
in interface Context
public void setNodeStatusUpdater(NodeStatusUpdater nodeStatusUpdater)
public boolean isDistributedSchedulingEnabled()
isDistributedSchedulingEnabled
in interface Context
public void setQueueableContainerAllocator(org.apache.hadoop.yarn.server.scheduler.OpportunisticContainerAllocator containerAllocator)
public org.apache.hadoop.yarn.server.scheduler.OpportunisticContainerAllocator getContainerAllocator()
getContainerAllocator
in interface Context
public ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.yarn.server.api.records.AppCollectorData> getRegisteringCollectors()
Context
getRegisteringCollectors
in interface Context
public ConcurrentMap<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.yarn.server.api.records.AppCollectorData> getKnownCollectors()
Context
getKnownCollectors
in interface Context
public void setNMTimelinePublisher(NMTimelinePublisher nmMetricsPublisher)
setNMTimelinePublisher
in interface Context
public NMTimelinePublisher getNMTimelinePublisher()
getNMTimelinePublisher
in interface Context
public ContainerExecutor getContainerExecutor()
getContainerExecutor
in interface Context
public void setContainerExecutor(ContainerExecutor executor)
public ContainerStateTransitionListener getContainerStateTransitionListener()
getContainerStateTransitionListener
in interface Context
public void setContainerStateTransitionListener(ContainerStateTransitionListener transitionListener)
public ResourcePluginManager getResourcePluginManager()
getResourcePluginManager
in interface Context
public NodeManagerMetrics getNodeManagerMetrics()
NodeManagerMetrics
instance of this node.
This might return a null if the instance was not set to the context.getNodeManagerMetrics
in interface Context
public void setNodeManagerMetrics(NodeManagerMetrics nmMetrics)
public void setResourcePluginManager(ResourcePluginManager resourcePluginManager)
public DeletionService getDeletionService()
DeletionService
.getDeletionService
in interface Context
DeletionService
.public void setDeletionService(DeletionService deletionService)
DeletionService
.deletionService
- the DeletionService
to add to the Context.public void setNMLogAggregationStatusTracker(NMLogAggregationStatusTracker nmLogAggregationStatusTracker)
public NMLogAggregationStatusTracker getNMLogAggregationStatusTracker()
getNMLogAggregationStatusTracker
in interface Context
public void setAuxServices(AuxServices auxServices)
setAuxServices
in interface Context
public AuxServices getAuxServices()
getAuxServices
in interface Context
Copyright © 2008–2024 Apache Software Foundation. All rights reserved.