| Modifier and Type | Method and Description | 
|---|---|
| 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) | 
| 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 | Field and Description | 
|---|---|
| protected LocalDirsHandlerService | ContainerManagerImpl. dirsHandler | 
| Constructor and Description | 
|---|
| ContainerManagerImpl(Context context,
                    ContainerExecutor exec,
                    DeletionService deletionContext,
                    NodeStatusUpdater nodeStatusUpdater,
                    NodeManagerMetrics metrics,
                    LocalDirsHandlerService dirsHandler) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected LocalDirsHandlerService | ContainerLaunch. dirsHandler | 
| Modifier and Type | Method and Description | 
|---|---|
| void | ContainersLauncher. init(Context nmContext,
    org.apache.hadoop.yarn.event.Dispatcher nmDispatcher,
    ContainerExecutor containerExec,
    LocalDirsHandlerService nmDirsHandler,
    ContainerManagerImpl nmContainerManager) | 
| void | AbstractContainersLauncher. init(Context context,
    org.apache.hadoop.yarn.event.Dispatcher dispatcher,
    ContainerExecutor exec,
    LocalDirsHandlerService dirsHandler,
    ContainerManagerImpl containerManager) | 
| 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) | 
| ContainerRelaunch(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) | 
| RecoverPausedContainerLaunch(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,
                           NodeManagerMetrics metrics) | 
| 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,
                    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,
                    long rollingMonitorInterval) | 
| 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,
                    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,
                    long rollingMonitorInterval,
                    long recoveredLogInitedTime) | 
| 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,
                    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,
                    long rollingMonitorInterval,
                    long recoveredLogInitedTime,
                    org.apache.hadoop.yarn.logaggregation.filecontroller.LogAggregationFileController logAggregationFileController) | 
| 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) | 
| Modifier and Type | Method and Description | 
|---|---|
| LocalDirsHandlerService | LocalizerStartContext. getDirsHandler() | 
| LocalDirsHandlerService | ContainerExecContext. getLocalDirsHandlerService() | 
| Modifier and Type | Method and Description | 
|---|---|
| LocalizerStartContext.Builder | LocalizerStartContext.Builder. setDirsHandler(LocalDirsHandlerService dirsHandler) | 
| ContainerExecContext.Builder | ContainerExecContext.Builder. setNMLocalPath(LocalDirsHandlerService ldhs) | 
| Modifier and Type | Method and Description | 
|---|---|
| LocalDirsHandlerService | NodeHealthCheckerService. getDiskHandler() | 
| Constructor and Description | 
|---|
| NodeHealthCheckerService(LocalDirsHandlerService dirHandlerService) | 
| Constructor and Description | 
|---|
| 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 © 2008–2023 Apache Software Foundation. All rights reserved.