Modifier and Type | Field and Description |
---|---|
protected ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,Container> |
NodeManager.NMContext.containers |
Modifier and Type | Method and Description |
---|---|
ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,Container> |
NodeManager.NMContext.getContainers() |
ConcurrentMap<org.apache.hadoop.yarn.api.records.ContainerId,Container> |
Context.getContainers() |
Modifier and Type | Method and Description |
---|---|
abstract int |
ContainerExecutor.launchContainer(Container container,
org.apache.hadoop.fs.Path nmPrivateContainerScriptPath,
org.apache.hadoop.fs.Path nmPrivateTokensPath,
org.apache.hadoop.fs.Path nmPrivateExtTokensPath,
String extTokensEnvVar,
String user,
String appId,
org.apache.hadoop.fs.Path containerWorkDir,
List<String> localDirs,
List<String> logDirs)
Launch the container on the node.
|
int |
LinuxContainerExecutor.launchContainer(Container container,
org.apache.hadoop.fs.Path nmPrivateCotainerScriptPath,
org.apache.hadoop.fs.Path nmPrivateTokensPath,
org.apache.hadoop.fs.Path nmPrivateExtTokensPath,
String extTokensEnvVar,
String user,
String appId,
org.apache.hadoop.fs.Path containerWorkDir,
List<String> localDirs,
List<String> logDirs) |
int |
DockerContainerExecutor.launchContainer(Container container,
org.apache.hadoop.fs.Path nmPrivateContainerScriptPath,
org.apache.hadoop.fs.Path nmPrivateTokensPath,
org.apache.hadoop.fs.Path nmPrivateExtTokensPath,
String extTokensEnvVar,
String userName,
String appId,
org.apache.hadoop.fs.Path containerWorkDir,
List<String> localDirs,
List<String> logDirs) |
int |
DefaultContainerExecutor.launchContainer(Container container,
org.apache.hadoop.fs.Path nmPrivateContainerScriptPath,
org.apache.hadoop.fs.Path nmPrivateTokensPath,
org.apache.hadoop.fs.Path nmPrivateExtTokensPath,
String extTokensEnvVar,
String user,
String appId,
org.apache.hadoop.fs.Path containerWorkDir,
List<String> localDirs,
List<String> logDirs) |
Constructor and Description |
---|
ContainerExecutor.DelayedProcessKiller(Container container,
String user,
String pid,
long delay,
ContainerExecutor.Signal signal,
ContainerExecutor containerExecutor) |
Modifier and Type | Method and Description |
---|---|
Container |
AuxServicesEvent.getContainer() |
Modifier and Type | Method and Description |
---|---|
protected void |
ContainerManagerImpl.authorizeGetAndStopContainerRequest(org.apache.hadoop.yarn.api.records.ContainerId containerId,
Container container,
boolean stopRequest,
org.apache.hadoop.yarn.security.NMTokenIdentifier identifier) |
Constructor and Description |
---|
AuxServicesEvent(AuxServicesEventType eventType,
Container container) |
AuxServicesEvent(AuxServicesEventType eventType,
String user,
org.apache.hadoop.yarn.api.records.ApplicationId appId,
String serviceId,
ByteBuffer serviceData,
Container container) |
Modifier and Type | Method and Description |
---|---|
Map<org.apache.hadoop.yarn.api.records.ContainerId,Container> |
ApplicationImpl.getContainers() |
Map<org.apache.hadoop.yarn.api.records.ContainerId,Container> |
Application.getContainers() |
Constructor and Description |
---|
ApplicationContainerInitEvent(Container container) |
Modifier and Type | Class and Description |
---|---|
class |
ContainerImpl |
Modifier and Type | Field and Description |
---|---|
protected Container |
ContainerLaunch.container |
Modifier and Type | Method and Description |
---|---|
Container |
ContainersLauncherEvent.getContainer() |
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) |
ContainersLauncherEvent(Container container,
ContainersLauncherEventType eventType) |
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) |
Modifier and Type | Method and Description |
---|---|
Container |
ContainerLocalizationEvent.getContainer() |
Constructor and Description |
---|
ContainerLocalizationCleanupEvent(Container c,
Map<org.apache.hadoop.yarn.api.records.LocalResourceVisibility,Collection<LocalResourceRequest>> rsrc)
Event requesting the cleanup of the rsrc.
|
ContainerLocalizationEvent(LocalizationEventType event,
Container c) |
ContainerLocalizationRequestEvent(Container c,
Map<org.apache.hadoop.yarn.api.records.LocalResourceVisibility,Collection<LocalResourceRequest>> rsrc)
Event requesting the localization of the rsrc.
|
Constructor and Description |
---|
ContainerInfo(Context nmContext,
Container container) |
ContainerInfo(Context nmContext,
Container container,
String requestUri,
String pathPrefix) |
Copyright © 2015 Apache Software Foundation. All Rights Reserved.