| Package | Description | 
|---|---|
| org.apache.hadoop.yarn.server.nodemanager | |
| org.apache.hadoop.yarn.server.nodemanager.api.impl.pb | Package containing classes for working with Protobuf. | 
| org.apache.hadoop.yarn.server.nodemanager.containermanager | |
| org.apache.hadoop.yarn.server.nodemanager.containermanager.deletion.task | Package containing DeletionTasks for use with the DeletionService. | 
| org.apache.hadoop.yarn.server.nodemanager.containermanager.localizer | |
| org.apache.hadoop.yarn.server.nodemanager.containermanager.logaggregation | |
| org.apache.hadoop.yarn.server.nodemanager.containermanager.loghandler | 
| Modifier and Type | Method and Description | 
|---|---|
| protected DeletionService | NodeManager. createDeletionService(ContainerExecutor exec) | 
| DeletionService | Context. getDeletionService()Get the  DeletionServiceassociated with the NM. | 
| DeletionService | NodeManager.NMContext. getDeletionService()Return the NM's  DeletionService. | 
| 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) | 
| void | NodeManager.NMContext. setDeletionService(DeletionService deletionService)Set the NM's  DeletionService. | 
| Modifier and Type | Method and Description | 
|---|---|
| static DeletionTask | NMProtoUtils. convertProtoToDeletionTask(org.apache.hadoop.yarn.proto.YarnServerNodemanagerRecoveryProtos.DeletionServiceDeleteTaskProto proto,
                          DeletionService deletionService)Convert the Protobuf representation into a  DeletionTask. | 
| static DeletionTaskRecoveryInfo | NMProtoUtils. convertProtoToDeletionTaskRecoveryInfo(org.apache.hadoop.yarn.proto.YarnServerNodemanagerRecoveryProtos.DeletionServiceDeleteTaskProto proto,
                                      DeletionService deletionService)Convert the Protobuf representation to the  DeletionTaskRecoveryInforepresentation. | 
| static DockerContainerDeletionTask | NMProtoUtils. convertProtoToDockerContainerDeletionTask(org.apache.hadoop.yarn.proto.YarnServerNodemanagerRecoveryProtos.DeletionServiceDeleteTaskProto proto,
                                         DeletionService deletionService,
                                         int taskId)Convert the Protobuf format into the  DockerContainerDeletionTask. | 
| static FileDeletionTask | NMProtoUtils. convertProtoToFileDeletionTask(org.apache.hadoop.yarn.proto.YarnServerNodemanagerRecoveryProtos.DeletionServiceDeleteTaskProto proto,
                              DeletionService deletionService,
                              int taskId)Convert the Protobuf representation into the  FileDeletionTask. | 
| Modifier and Type | Method and Description | 
|---|---|
| protected LogHandler | ContainerManagerImpl. createLogHandler(org.apache.hadoop.conf.Configuration conf,
                Context context,
                DeletionService deletionService) | 
| protected ResourceLocalizationService | ContainerManagerImpl. createResourceLocalizationService(ContainerExecutor exec,
                                 DeletionService deletionContext,
                                 Context nmContext,
                                 NodeManagerMetrics nmMetrics) | 
| Constructor and Description | 
|---|
| ContainerManagerImpl(Context context,
                    ContainerExecutor exec,
                    DeletionService deletionContext,
                    NodeStatusUpdater nodeStatusUpdater,
                    NodeManagerMetrics metrics,
                    LocalDirsHandlerService dirsHandler) | 
| Modifier and Type | Method and Description | 
|---|---|
| DeletionService | DeletionTask. getDeletionService()Get the  DeletionServicefor this DeletionTask. | 
| Constructor and Description | 
|---|
| DeletionTask(int taskId,
            DeletionService deletionService,
            String user,
            AtomicInteger numberOfPendingPredecessorTasks,
            Set<DeletionTask> successorTaskSet,
            DeletionTaskType deletionTaskType)Deletion task with taskId and user supplied values. | 
| DeletionTask(int taskId,
            DeletionService deletionService,
            String user,
            DeletionTaskType deletionTaskType)Deletion task with taskId and default values. | 
| DockerContainerDeletionTask(DeletionService deletionService,
                           String user,
                           String containerId) | 
| DockerContainerDeletionTask(int taskId,
                           DeletionService deletionService,
                           String user,
                           String containerId) | 
| FileDeletionTask(DeletionService deletionService,
                String user,
                org.apache.hadoop.fs.Path subDir,
                List<org.apache.hadoop.fs.Path> baseDirs)Construct a FileDeletionTask with the default INVALID_TASK_ID. | 
| FileDeletionTask(int taskId,
                DeletionService deletionService,
                String user,
                org.apache.hadoop.fs.Path subDir,
                List<org.apache.hadoop.fs.Path> baseDirs)Construct a FileDeletionTask with the default INVALID_TASK_ID. | 
| 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) | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.