| Modifier and Type | Class and Description | 
|---|---|
| static class  | NodeManager.NMContext | 
| Modifier and Type | Method and Description | 
|---|---|
| Context | NodeManager. getNMContext() | 
| 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 NMCollectorService | NodeManager. createNMCollectorService(Context ctxt) | 
| protected NodeStatusUpdater | NodeManager. createNodeStatusUpdater(Context context,
                       org.apache.hadoop.yarn.event.Dispatcher dispatcher,
                       NodeHealthCheckerService healthChecker) | 
| protected WebServer | NodeManager. createWebServer(Context nmContext,
               ResourceView resourceView,
               org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager,
               LocalDirsHandlerService dirsHandler) | 
| void | LinuxContainerExecutor. init(Context context) | 
| abstract void | ContainerExecutor. init(Context nmContext)Run the executor initialization steps. | 
| void | DefaultContainerExecutor. init(Context nmContext) | 
| void | NodeManager.DefaultContainerStateListener. init(Context context) | 
| void | ContainerStateTransitionListener. init(Context context)Init method which will be invoked by the Node Manager to inject the
 NM  Context. | 
| void | LinuxContainerExecutor. updateYarnSysFS(Context ctx,
               String user,
               String appId,
               String spec) | 
| abstract void | ContainerExecutor. updateYarnSysFS(Context ctx,
               String user,
               String appId,
               String spec)Update cluster information inside container. | 
| void | DefaultContainerExecutor. updateYarnSysFS(Context ctx,
               String user,
               String appId,
               String spec) | 
| Constructor and Description | 
|---|
| NodeResourceMonitorImpl(Context context)Initialize the node resource monitor. | 
| NodeStatusUpdaterImpl(Context context,
                     org.apache.hadoop.yarn.event.Dispatcher dispatcher,
                     NodeHealthCheckerService healthChecker,
                     NodeManagerMetrics metrics) | 
| Modifier and Type | Method and Description | 
|---|---|
| Context | AMRMProxyApplicationContextImpl. getNMCotext() | 
| Context | AMRMProxyApplicationContext. getNMCotext()Gets the NMContext object. | 
| Constructor and Description | 
|---|
| AMRMProxyApplicationContextImpl(Context nmContext,
                               org.apache.hadoop.conf.Configuration conf,
                               org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
                               String user,
                               org.apache.hadoop.security.token.Token<org.apache.hadoop.yarn.security.AMRMTokenIdentifier> amrmToken,
                               org.apache.hadoop.security.token.Token<org.apache.hadoop.yarn.security.AMRMTokenIdentifier> localToken,
                               org.apache.hadoop.security.Credentials credentials,
                               org.apache.hadoop.registry.client.api.RegistryOperations registry)Create an instance of the AMRMProxyApplicationContext. | 
| AMRMProxyService(Context nmContext,
                org.apache.hadoop.yarn.event.AsyncDispatcher dispatcher)Creates an instance of the service. | 
| Constructor and Description | 
|---|
| NMCollectorService(Context context) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected Context | ContainerManagerImpl. context | 
| Modifier and Type | Method and Description | 
|---|---|
| Context | ContainerManagerImpl. getContext() | 
| Modifier and Type | Method and Description | 
|---|---|
| protected ContainerScheduler | ContainerManagerImpl. createContainerScheduler(Context cntxt) | 
| protected AbstractContainersLauncher | ContainerManagerImpl. createContainersLauncher(Context ctxt,
                        ContainerExecutor exec) | 
| protected LogHandler | ContainerManagerImpl. createLogHandler(org.apache.hadoop.conf.Configuration conf,
                Context context,
                DeletionService deletionService) | 
| protected NMTimelinePublisher | ContainerManagerImpl. createNMTimelinePublisher(Context ctxt) | 
| 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) | 
| Constructor and Description | 
|---|
| ApplicationImpl(org.apache.hadoop.yarn.event.Dispatcher dispatcher,
               String user,
               org.apache.hadoop.yarn.api.records.ApplicationId appId,
               org.apache.hadoop.security.Credentials credentials,
               Context context) | 
| ApplicationImpl(org.apache.hadoop.yarn.event.Dispatcher dispatcher,
               String user,
               ApplicationImpl.FlowContext flowContext,
               org.apache.hadoop.yarn.api.records.ApplicationId appId,
               org.apache.hadoop.security.Credentials credentials,
               Context context) | 
| ApplicationImpl(org.apache.hadoop.yarn.event.Dispatcher dispatcher,
               String user,
               ApplicationImpl.FlowContext flowContext,
               org.apache.hadoop.yarn.api.records.ApplicationId appId,
               org.apache.hadoop.security.Credentials credentials,
               Context context,
               long recoveredLogInitedTime) | 
| Constructor and Description | 
|---|
| ContainerImpl(org.apache.hadoop.conf.Configuration conf,
             org.apache.hadoop.yarn.event.Dispatcher dispatcher,
             org.apache.hadoop.yarn.api.records.ContainerLaunchContext launchContext,
             org.apache.hadoop.security.Credentials creds,
             NodeManagerMetrics metrics,
             org.apache.hadoop.yarn.security.ContainerTokenIdentifier containerTokenIdentifier,
             Context context) | 
| ContainerImpl(org.apache.hadoop.conf.Configuration conf,
             org.apache.hadoop.yarn.event.Dispatcher dispatcher,
             org.apache.hadoop.yarn.api.records.ContainerLaunchContext launchContext,
             org.apache.hadoop.security.Credentials creds,
             NodeManagerMetrics metrics,
             org.apache.hadoop.yarn.security.ContainerTokenIdentifier containerTokenIdentifier,
             Context context,
             long startTs) | 
| ContainerImpl(org.apache.hadoop.conf.Configuration conf,
             org.apache.hadoop.yarn.event.Dispatcher dispatcher,
             org.apache.hadoop.yarn.api.records.ContainerLaunchContext launchContext,
             org.apache.hadoop.security.Credentials creds,
             NodeManagerMetrics metrics,
             org.apache.hadoop.yarn.security.ContainerTokenIdentifier containerTokenIdentifier,
             Context context,
             NMStateStoreService.RecoveredContainerState rcs) | 
| 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 | 
|---|
| ContainerCleanup(Context context,
                org.apache.hadoop.conf.Configuration configuration,
                org.apache.hadoop.yarn.event.Dispatcher dispatcher,
                ContainerExecutor exec,
                Container container,
                ContainerLaunch containerLaunch) | 
| 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) | 
| Modifier and Type | Method and Description | 
|---|---|
| static ResourceHandlerChain | ResourceHandlerModule. getConfiguredResourceHandlerChain(org.apache.hadoop.conf.Configuration conf,
                                 Context nmContext) | 
| Constructor and Description | 
|---|
| CGroupElasticMemoryController(org.apache.hadoop.conf.Configuration conf,
                             Context context,
                             CGroupsHandler cgroups,
                             boolean controlPhysicalMemory,
                             boolean controlVirtualMemory,
                             long limit)Default constructor. | 
| DefaultOOMHandler(Context context,
                 boolean enforceVirtualMemory)Create an OOM handler. | 
| Constructor and Description | 
|---|
| FpgaResourceAllocator(Context ctx) | 
| FpgaResourceHandlerImpl(Context nmContext,
                       CGroupsHandler cGroupsHandler,
                       PrivilegedOperationExecutor privilegedOperationExecutor,
                       AbstractFpgaVendorPlugin plugin,
                       FpgaDiscoverer fpgaDiscoverer) | 
| Constructor and Description | 
|---|
| GpuResourceAllocator(Context ctx) | 
| GpuResourceHandlerImpl(Context nmContext,
                      CGroupsHandler cGroupsHandler,
                      PrivilegedOperationExecutor privilegedOperationExecutor,
                      GpuDiscoverer gpuDiscoverer) | 
| Constructor and Description | 
|---|
| NumaResourceAllocator(Context context) | 
| NumaResourceHandlerImpl(org.apache.hadoop.conf.Configuration conf,
                       Context nmContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| void | DelegatingLinuxContainerRuntime. initialize(org.apache.hadoop.conf.Configuration conf,
          Context nmContext) | 
| void | JavaSandboxLinuxContainerRuntime. initialize(org.apache.hadoop.conf.Configuration conf,
          Context nmContext) | 
| void | DockerLinuxContainerRuntime. initialize(org.apache.hadoop.conf.Configuration conf,
          Context nmContext) | 
| void | LinuxContainerRuntime. initialize(org.apache.hadoop.conf.Configuration conf,
          Context nmContext)Initialize the runtime. | 
| void | OCIContainerRuntime. initialize(org.apache.hadoop.conf.Configuration conf,
          Context nmContext) | 
| void | RuncContainerRuntime. initialize(org.apache.hadoop.conf.Configuration configuration,
          Context nmCtx) | 
| void | DefaultLinuxContainerRuntime. initialize(org.apache.hadoop.conf.Configuration conf,
          Context nmContext) | 
| Modifier and Type | Method and Description | 
|---|---|
| static String | DockerCommandExecutor. executeDockerCommand(DockerCommand dockerCommand,
                    String containerId,
                    Map<String,String> env,
                    PrivilegedOperationExecutor privilegedOperationExecutor,
                    boolean disableFailureLogging,
                    Context nmContext)Execute a docker command and return the output. | 
| static DockerCommandExecutor.DockerContainerStatus | DockerCommandExecutor. getContainerStatus(String containerId,
                  PrivilegedOperationExecutor privilegedOperationExecutor,
                  Context nmContext)Get the status of the docker container. | 
| PrivilegedOperation | DockerCommand. preparePrivilegedOperation(DockerCommand dockerCommand,
                          String containerName,
                          Map<String,String> env,
                          Context nmContext)Prepare the privileged operation object that will be used to invoke
 the container-executor. | 
| PrivilegedOperation | DockerInspectCommand. preparePrivilegedOperation(DockerCommand dockerCommand,
                          String containerName,
                          Map<String,String> env,
                          Context nmContext) | 
| PrivilegedOperation | DockerRmCommand. preparePrivilegedOperation(DockerCommand dockerCommand,
                          String containerName,
                          Map<String,String> env,
                          Context nmContext) | 
| String | DockerClient. writeCommandToTempFile(DockerCommand cmd,
                      org.apache.hadoop.yarn.api.records.ContainerId containerId,
                      Context nmContext) | 
| 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 | 
|---|
| ContainersMonitorImpl(ContainerExecutor exec,
                     org.apache.hadoop.yarn.event.AsyncDispatcher dispatcher,
                     Context context) | 
| Modifier and Type | Method and Description | 
|---|---|
| ResourceHandler | ResourcePlugin. createResourceHandler(Context nmContext,
                     CGroupsHandler cGroupsHandler,
                     PrivilegedOperationExecutor privilegedOperationExecutor)Plugin needs to return  ResourceHandlerwhen any special isolation
 required for the resource type. | 
| void | ResourcePlugin. initialize(Context context)Initialize the plugin, this will be invoked during NM startup. | 
| void | ResourcePluginManager. initialize(Context context) | 
| void | ResourcePluginManager. initializePluggableDevicePlugins(Context context,
                                org.apache.hadoop.conf.Configuration configuration,
                                Map<String,ResourcePlugin> pluginMap) | 
| Modifier and Type | Method and Description | 
|---|---|
| ResourceHandler | DevicePluginAdapter. createResourceHandler(Context nmContext,
                     CGroupsHandler cGroupsHandler,
                     PrivilegedOperationExecutor privilegedOperationExecutor) | 
| void | DevicePluginAdapter. initialize(Context context) | 
| Constructor and Description | 
|---|
| DeviceMappingManager(Context context) | 
| DeviceResourceHandlerImpl(String resName,
                         DevicePluginAdapter devPluginAdapter,
                         DeviceMappingManager devMappingManager,
                         CGroupsHandler cgHandler,
                         PrivilegedOperationExecutor operation,
                         Context ctx) | 
| DeviceResourceHandlerImpl(String resName,
                         DevicePluginAdapter devPluginAdapter,
                         DeviceMappingManager devMappingManager,
                         CGroupsHandler cgHandler,
                         PrivilegedOperationExecutor operation,
                         Context ctx,
                         ShellWrapper shell) | 
| Modifier and Type | Method and Description | 
|---|---|
| ResourceHandler | FpgaResourcePlugin. createResourceHandler(Context nmContext,
                     CGroupsHandler cGroupsHandler,
                     PrivilegedOperationExecutor privilegedOperationExecutor) | 
| void | FpgaResourcePlugin. initialize(Context context) | 
| Modifier and Type | Method and Description | 
|---|---|
| ResourceHandler | GpuResourcePlugin. createResourceHandler(Context context,
                     CGroupsHandler cGroupsHandler,
                     PrivilegedOperationExecutor privilegedOperationExecutor) | 
| void | GpuResourcePlugin. initialize(Context context) | 
| Constructor and Description | 
|---|
| ContainerScheduler(Context context,
                  org.apache.hadoop.yarn.event.AsyncDispatcher dispatcher,
                  NodeManagerMetrics metrics)Instantiate a Container Scheduler. | 
| ContainerScheduler(Context context,
                  org.apache.hadoop.yarn.event.AsyncDispatcher dispatcher,
                  NodeManagerMetrics metrics,
                  int qLength) | 
| Constructor and Description | 
|---|
| NMLogAggregationStatusTracker(Context context) | 
| Constructor and Description | 
|---|
| NMTimelinePublisher(Context context) | 
| Modifier and Type | Method and Description | 
|---|---|
| static List<File> | ContainerLogsUtils. getContainerLogDirs(org.apache.hadoop.yarn.api.records.ContainerId containerId,
                   String remoteUser,
                   Context context)Finds the local directories that logs for the given container are stored
 on. | 
| static File | ContainerLogsUtils. getContainerLogFile(org.apache.hadoop.yarn.api.records.ContainerId containerId,
                   String fileName,
                   String remoteUser,
                   Context context)Finds the log file with the given filename for the given container. | 
| static void | ContainerShellWebSocket. init(Context nm) | 
| static FileInputStream | ContainerLogsUtils. openLogFileForRead(String containerIdStr,
                  File logFile,
                  Context context) | 
| Constructor and Description | 
|---|
| AllApplicationsBlock(Context nmContext) | 
| AllContainersBlock(Context nmContext) | 
| ApplicationBlock(Context nmContext,
                org.apache.hadoop.conf.Configuration conf) | 
| ContainerBlock(Context nmContext) | 
| ContainersLogsBlock(Context context) | 
| NMWebAppFilter(com.google.inject.Injector injector,
              Context nmContext) | 
| NMWebServices(Context nm,
             ResourceView view,
             org.apache.hadoop.yarn.webapp.WebApp webapp) | 
| NMWebServices(Context nm,
             ResourceView view,
             org.apache.hadoop.yarn.webapp.WebApp webapp,
             javax.servlet.http.HttpServletResponse response) | 
| NodeBlock(Context context,
         ResourceView resourceView) | 
| WebServer(Context nmContext,
         ResourceView resourceView,
         org.apache.hadoop.yarn.server.security.ApplicationACLsManager aclsManager,
         LocalDirsHandlerService dirsHandler) | 
| Constructor and Description | 
|---|
| ContainerInfo(Context nmContext,
             Container container) | 
| ContainerInfo(Context nmContext,
             Container container,
             String requestUri,
             String pathPrefix,
             String remoteUser) | 
| NMContainerLogsInfo(Context nmContext,
                   org.apache.hadoop.yarn.api.records.ContainerId containerId,
                   String remoteUser,
                   org.apache.hadoop.yarn.logaggregation.ContainerLogAggregationType logType) | 
| NodeInfo(Context context,
        ResourceView resourceView) | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.