Modifier and Type | Method and Description |
---|---|
LocalDirsHandlerService |
NodeHealthCheckerService.getDiskHandler() |
LocalDirsHandlerService |
Context.getLocalDirsHandler() |
LocalDirsHandlerService |
NodeManager.NMContext.getLocalDirsHandler() |
Modifier and Type | Method and Description |
---|---|
protected ContainerManagerImpl |
NodeManager.createContainerManager(Context context,
ContainerExecutor exec,
DeletionService del,
NodeStatusUpdater nodeStatusUpdater,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager,
LocalDirsHandlerService dirsHandler) |
protected WebServer |
NodeManager.createWebServer(Context nmContext,
ResourceView resourceView,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager,
LocalDirsHandlerService dirsHandler) |
abstract void |
ContainerExecutor.startLocalizer(org.apache.hadoop.fs.Path nmPrivateContainerTokens,
org.apache.hadoop.fs.Path nmPrivateExtTokensPath,
String extTokensEnvVar,
InetSocketAddress nmAddr,
String user,
String appId,
String locId,
LocalDirsHandlerService dirsHandler)
Prepare the environment for containers in this application to execute.
|
void |
LinuxContainerExecutor.startLocalizer(org.apache.hadoop.fs.Path nmPrivateContainerTokensPath,
org.apache.hadoop.fs.Path nmPrivateExtTokensPath,
String extTokensEnvVar,
InetSocketAddress nmAddr,
String user,
String appId,
String locId,
LocalDirsHandlerService dirsHandler) |
void |
DockerContainerExecutor.startLocalizer(org.apache.hadoop.fs.Path nmPrivateContainerTokensPath,
org.apache.hadoop.fs.Path nmPrivateExtTokensPath,
String extTokensEnvVar,
InetSocketAddress nmAddr,
String user,
String appId,
String locId,
LocalDirsHandlerService dirsHandler) |
void |
WindowsSecureContainerExecutor.startLocalizer(org.apache.hadoop.fs.Path nmPrivateContainerTokens,
org.apache.hadoop.fs.Path nmPrivateExtTokensPath,
String extTokensEnvVar,
InetSocketAddress nmAddr,
String user,
String appId,
String locId,
LocalDirsHandlerService dirsHandler) |
void |
DefaultContainerExecutor.startLocalizer(org.apache.hadoop.fs.Path nmPrivateContainerTokensPath,
org.apache.hadoop.fs.Path nmPrivateExtTokensPath,
String extTokensEnvVar,
InetSocketAddress nmAddr,
String user,
String appId,
String locId,
LocalDirsHandlerService dirsHandler) |
Constructor and Description |
---|
NodeManager.NMContext(NMContainerTokenSecretManager containerTokenSecretManager,
NMTokenSecretManagerInNM nmTokenSecretManager,
LocalDirsHandlerService dirsHandler,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager,
NMStateStoreService stateStore) |
Modifier and Type | Field and Description |
---|---|
protected LocalDirsHandlerService |
ContainerManagerImpl.dirsHandler |
Constructor and Description |
---|
ContainerManagerImpl(Context context,
ContainerExecutor exec,
DeletionService deletionContext,
NodeStatusUpdater nodeStatusUpdater,
NodeManagerMetrics metrics,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager,
LocalDirsHandlerService dirsHandler) |
Constructor and Description |
---|
ContainerLaunch(Context context,
org.apache.hadoop.conf.Configuration configuration,
org.apache.hadoop.yarn.event.Dispatcher dispatcher,
ContainerExecutor exec,
Application app,
Container container,
LocalDirsHandlerService dirsHandler,
ContainerManagerImpl containerManager) |
ContainersLauncher(Context context,
org.apache.hadoop.yarn.event.Dispatcher dispatcher,
ContainerExecutor exec,
LocalDirsHandlerService dirsHandler,
ContainerManagerImpl containerManager) |
RecoveredContainerLaunch(Context context,
org.apache.hadoop.conf.Configuration configuration,
org.apache.hadoop.yarn.event.Dispatcher dispatcher,
ContainerExecutor exec,
Application app,
Container container,
LocalDirsHandlerService dirsHandler,
ContainerManagerImpl containerManager) |
Constructor and Description |
---|
ResourceLocalizationService(org.apache.hadoop.yarn.event.Dispatcher dispatcher,
ContainerExecutor exec,
DeletionService delService,
LocalDirsHandlerService dirsHandler,
Context context) |
Constructor and Description |
---|
AppLogAggregatorImpl(org.apache.hadoop.yarn.event.Dispatcher dispatcher,
DeletionService deletionService,
org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.yarn.api.records.ApplicationId appId,
org.apache.hadoop.security.UserGroupInformation userUgi,
org.apache.hadoop.yarn.api.records.NodeId nodeId,
LocalDirsHandlerService dirsHandler,
org.apache.hadoop.fs.Path remoteNodeLogFileForApp,
org.apache.hadoop.yarn.logaggregation.ContainerLogsRetentionPolicy retentionPolicy,
Map<org.apache.hadoop.yarn.api.records.ApplicationAccessType,String> appAcls,
org.apache.hadoop.yarn.api.records.LogAggregationContext logAggregationContext,
Context context,
org.apache.hadoop.fs.FileContext lfs) |
LogAggregationService(org.apache.hadoop.yarn.event.Dispatcher dispatcher,
Context context,
DeletionService deletionService,
LocalDirsHandlerService dirsHandler) |
Constructor and Description |
---|
NonAggregatingLogHandler(org.apache.hadoop.yarn.event.Dispatcher dispatcher,
DeletionService delService,
LocalDirsHandlerService dirsHandler,
NMStateStoreService stateStore) |
Constructor and Description |
---|
WebServer.NMWebApp(ResourceView resourceView,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager,
LocalDirsHandlerService dirsHandler) |
WebServer(Context nmContext,
ResourceView resourceView,
org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager,
LocalDirsHandlerService dirsHandler) |
Copyright © 2017 Apache Software Foundation. All Rights Reserved.