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 |
Constructor and Description |
---|
NodeManager.NMContext(NMContainerTokenSecretManager containerTokenSecretManager,
NMTokenSecretManagerInNM nmTokenSecretManager,
LocalDirsHandlerService dirsHandler,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager,
NMStateStoreService stateStore) |
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.yarn.api.ContainerManagementProtocol |
getContainerManager() |
ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,Container> |
getContainers() |
NMContainerTokenSecretManager |
getContainerTokenSecretManager() |
boolean |
getDecommissioned() |
int |
getHttpPort()
Return the node http-address.
|
LocalDirsHandlerService |
getLocalDirsHandler() |
NMStateStoreService |
getNMStateStore() |
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.
|
Map<org.apache.hadoop.yarn.api.records.ApplicationId,org.apache.hadoop.security.Credentials> |
getSystemCredentialsForApps() |
void |
setContainerManager(org.apache.hadoop.yarn.api.ContainerManagementProtocol containerManager) |
void |
setDecommissioned(boolean isDecommissioned) |
void |
setNodeId(org.apache.hadoop.yarn.api.records.NodeId nodeId) |
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
public NodeManager.NMContext(NMContainerTokenSecretManager containerTokenSecretManager, NMTokenSecretManagerInNM nmTokenSecretManager, LocalDirsHandlerService dirsHandler, org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager, NMStateStoreService stateStore)
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 ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,Container> getContainers()
getContainers
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 org.apache.hadoop.yarn.api.ContainerManagementProtocol getContainerManager()
getContainerManager
in interface Context
public void setContainerManager(org.apache.hadoop.yarn.api.ContainerManagementProtocol 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)
Copyright © 2016 Apache Software Foundation. All Rights Reserved.