Uses of Class
org.apache.hadoop.yarn.api.records.ContainerLaunchContext

Packages that use ContainerLaunchContext
org.apache.hadoop.yarn.api.protocolrecords   
org.apache.hadoop.yarn.api.records   
org.apache.hadoop.yarn.client.api Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements. 
org.apache.hadoop.yarn.client.api.async   
 

Uses of ContainerLaunchContext in org.apache.hadoop.yarn.api.protocolrecords
 

Methods in org.apache.hadoop.yarn.api.protocolrecords that return ContainerLaunchContext
abstract  ContainerLaunchContext StartContainerRequest.getContainerLaunchContext()
          Get the ContainerLaunchContext for the container to be started by the NodeManager.
 

Methods in org.apache.hadoop.yarn.api.protocolrecords with parameters of type ContainerLaunchContext
static StartContainerRequest StartContainerRequest.newInstance(ContainerLaunchContext context, Token container)
           
abstract  void StartContainerRequest.setContainerLaunchContext(ContainerLaunchContext context)
          Set the ContainerLaunchContext for the container to be started by the NodeManager
 

Uses of ContainerLaunchContext in org.apache.hadoop.yarn.api.records
 

Methods in org.apache.hadoop.yarn.api.records that return ContainerLaunchContext
abstract  ContainerLaunchContext ApplicationSubmissionContext.getAMContainerSpec()
          Get the ContainerLaunchContext to describe the Container with which the ApplicationMaster is launched.
static ContainerLaunchContext ContainerLaunchContext.newInstance(Map<String,LocalResource> localResources, Map<String,String> environment, List<String> commands, Map<String,ByteBuffer> serviceData, ByteBuffer tokens, Map<ApplicationAccessType,String> acls)
           
 

Methods in org.apache.hadoop.yarn.api.records with parameters of type ContainerLaunchContext
static ApplicationSubmissionContext ApplicationSubmissionContext.newInstance(ApplicationId applicationId, String applicationName, String queue, ContainerLaunchContext amContainer, boolean isUnmanagedAM, boolean cancelTokensWhenComplete, int maxAppAttempts, String applicationType, boolean keepContainers, String appLabelExpression, ResourceRequest resourceRequest)
           
static ApplicationSubmissionContext ApplicationSubmissionContext.newInstance(ApplicationId applicationId, String applicationName, String queue, Priority priority, ContainerLaunchContext amContainer, boolean isUnmanagedAM, boolean cancelTokensWhenComplete, int maxAppAttempts, Resource resource)
           
static ApplicationSubmissionContext ApplicationSubmissionContext.newInstance(ApplicationId applicationId, String applicationName, String queue, Priority priority, ContainerLaunchContext amContainer, boolean isUnmanagedAM, boolean cancelTokensWhenComplete, int maxAppAttempts, Resource resource, String applicationType)
           
static ApplicationSubmissionContext ApplicationSubmissionContext.newInstance(ApplicationId applicationId, String applicationName, String queue, Priority priority, ContainerLaunchContext amContainer, boolean isUnmanagedAM, boolean cancelTokensWhenComplete, int maxAppAttempts, Resource resource, String applicationType, boolean keepContainers)
           
static ApplicationSubmissionContext ApplicationSubmissionContext.newInstance(ApplicationId applicationId, String applicationName, String queue, Priority priority, ContainerLaunchContext amContainer, boolean isUnmanagedAM, boolean cancelTokensWhenComplete, int maxAppAttempts, Resource resource, String applicationType, boolean keepContainers, LogAggregationContext logAggregationContext)
           
static ApplicationSubmissionContext ApplicationSubmissionContext.newInstance(ApplicationId applicationId, String applicationName, String queue, Priority priority, ContainerLaunchContext amContainer, boolean isUnmanagedAM, boolean cancelTokensWhenComplete, int maxAppAttempts, Resource resource, String applicationType, boolean keepContainers, long attemptFailuresValidityInterval)
           
static ApplicationSubmissionContext ApplicationSubmissionContext.newInstance(ApplicationId applicationId, String applicationName, String queue, Priority priority, ContainerLaunchContext amContainer, boolean isUnmanagedAM, boolean cancelTokensWhenComplete, int maxAppAttempts, Resource resource, String applicationType, boolean keepContainers, String appLabelExpression, String amContainerLabelExpression)
           
abstract  void ApplicationSubmissionContext.setAMContainerSpec(ContainerLaunchContext amContainer)
          Set the ContainerLaunchContext to describe the Container with which the ApplicationMaster is launched.
 

Uses of ContainerLaunchContext in org.apache.hadoop.yarn.client.api
 

Methods in org.apache.hadoop.yarn.client.api with parameters of type ContainerLaunchContext
abstract  Map<String,ByteBuffer> NMClient.startContainer(Container container, ContainerLaunchContext containerLaunchContext)
          Start an allocated container.
 

Uses of ContainerLaunchContext in org.apache.hadoop.yarn.client.api.async
 

Methods in org.apache.hadoop.yarn.client.api.async with parameters of type ContainerLaunchContext
abstract  void NMClientAsync.startContainerAsync(Container container, ContainerLaunchContext containerLaunchContext)
           
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.