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

Packages that use Resource
org.apache.hadoop.yarn.api.protocolrecords   
org.apache.hadoop.yarn.api.records   
org.apache.hadoop.yarn.client.api   
org.apache.hadoop.yarn.client.api.async   
org.apache.hadoop.yarn.security   
 

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

Methods in org.apache.hadoop.yarn.api.protocolrecords that return Resource
abstract  Resource AllocateResponse.getAvailableResources()
          Get the available headroom for resources in the cluster for the application.
abstract  Resource RegisterApplicationMasterResponse.getMaximumResourceCapability()
          Get the maximum capability for any Resource allocated by the ResourceManager in the cluster.
abstract  Resource GetNewApplicationResponse.getMaximumResourceCapability()
          Get the maximum capability for any Resource allocated by the ResourceManager in the cluster.
 

Methods in org.apache.hadoop.yarn.api.protocolrecords with parameters of type Resource
static GetNewApplicationResponse GetNewApplicationResponse.newInstance(ApplicationId applicationId, Resource minCapability, Resource maxCapability)
           
static AllocateResponse AllocateResponse.newInstance(int responseId, List<ContainerStatus> completedContainers, List<Container> allocatedContainers, List<NodeReport> updatedNodes, Resource availResources, AMCommand command, int numClusterNodes, PreemptionMessage preempt, List<NMToken> nmTokens)
           
static AllocateResponse AllocateResponse.newInstance(int responseId, List<ContainerStatus> completedContainers, List<Container> allocatedContainers, List<NodeReport> updatedNodes, Resource availResources, AMCommand command, int numClusterNodes, PreemptionMessage preempt, List<NMToken> nmTokens, List<org.apache.hadoop.yarn.api.records.ContainerResourceIncrease> increasedContainers, List<org.apache.hadoop.yarn.api.records.ContainerResourceDecrease> decreasedContainers)
           
static RegisterApplicationMasterResponse RegisterApplicationMasterResponse.newInstance(Resource minCapability, Resource maxCapability, Map<ApplicationAccessType,String> acls, ByteBuffer key, List<Container> containersFromPreviousAttempt, String queue, List<NMToken> nmTokensFromPreviousAttempts)
           
abstract  void AllocateResponse.setAvailableResources(Resource limit)
           
abstract  void RegisterApplicationMasterResponse.setMaximumResourceCapability(Resource capability)
           
abstract  void GetNewApplicationResponse.setMaximumResourceCapability(Resource capability)
           
 

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

Methods in org.apache.hadoop.yarn.api.records that return Resource
abstract  Resource ContainerReport.getAllocatedResource()
          Get the allocated Resource of the container.
abstract  Resource ContainerResourceIncreaseRequest.getCapability()
           
abstract  Resource ResourceRequest.getCapability()
          Get the Resource capability of the request.
abstract  Resource NodeReport.getCapability()
          Get the total Resource on the node.
abstract  Resource ApplicationResourceUsageReport.getNeededResources()
          Get the needed Resource.
abstract  Resource ApplicationResourceUsageReport.getReservedResources()
          Get the reserved Resource.
abstract  Resource ResourceOption.getResource()
          Get the resource of the ResourceOption.
abstract  Resource ApplicationSubmissionContext.getResource()
          Get the resource required by the ApplicationMaster for this application.
abstract  Resource Container.getResource()
          Get the Resource allocated to the container.
abstract  Resource NodeReport.getUsed()
          Get used Resource on the node.
abstract  Resource ApplicationResourceUsageReport.getUsedResources()
          Get the used Resource.
static Resource Resource.newInstance(int memory, int vCores)
           
 

Methods in org.apache.hadoop.yarn.api.records with parameters of type Resource
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 Container Container.newInstance(ContainerId containerId, NodeId nodeId, String nodeHttpAddress, Resource resource, Priority priority, Token containerToken)
           
static ContainerResourceIncreaseRequest ContainerResourceIncreaseRequest.newInstance(ContainerId existingContainerId, Resource targetCapability)
           
static ContainerReport ContainerReport.newInstance(ContainerId containerId, Resource allocatedResource, NodeId assignedNode, Priority priority, long creationTime, long finishTime, String diagnosticInfo, String logUrl, int containerExitStatus, ContainerState containerState)
           
static ApplicationResourceUsageReport ApplicationResourceUsageReport.newInstance(int numUsedContainers, int numReservedContainers, Resource usedResources, Resource reservedResources, Resource neededResources)
           
static NodeReport NodeReport.newInstance(NodeId nodeId, NodeState nodeState, String httpAddress, String rackName, Resource used, Resource capability, int numContainers, String healthReport, long lastHealthReportTime)
           
static ResourceRequest ResourceRequest.newInstance(Priority priority, String hostName, Resource capability, int numContainers)
           
static ResourceRequest ResourceRequest.newInstance(Priority priority, String hostName, Resource capability, int numContainers, boolean relaxLocality)
           
static ResourceOption ResourceOption.newInstance(Resource resource, int overCommitTimeout)
           
abstract  void ContainerReport.setAllocatedResource(Resource resource)
           
abstract  void ContainerResourceIncreaseRequest.setCapability(Resource capability)
           
abstract  void ResourceRequest.setCapability(Resource capability)
          Set the Resource capability of the request
abstract  void NodeReport.setCapability(Resource capability)
           
abstract  void ApplicationResourceUsageReport.setNeededResources(Resource needed_resources)
           
abstract  void ApplicationResourceUsageReport.setReservedResources(Resource reserved_resources)
           
protected abstract  void ResourceOption.setResource(Resource resource)
           
abstract  void ApplicationSubmissionContext.setResource(Resource resource)
          Set the resource required by the ApplicationMaster for this application.
abstract  void Container.setResource(Resource resource)
           
abstract  void NodeReport.setUsed(Resource used)
           
abstract  void ApplicationResourceUsageReport.setUsedResources(Resource resources)
           
 

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

Methods in org.apache.hadoop.yarn.client.api that return Resource
abstract  Resource AMRMClient.getAvailableResources()
          Get the currently available resources in the cluster.
 

Methods in org.apache.hadoop.yarn.client.api with parameters of type Resource
abstract  List<? extends Collection<T>> AMRMClient.getMatchingRequests(Priority priority, String resourceName, Resource capability)
          Get outstanding ContainerRequests matching the given parameters.
 

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

Methods in org.apache.hadoop.yarn.client.api.async that return Resource
abstract  Resource AMRMClientAsync.getAvailableResources()
          Get the currently available resources in the cluster.
 

Methods in org.apache.hadoop.yarn.client.api.async with parameters of type Resource
abstract  List<? extends Collection<T>> AMRMClientAsync.getMatchingRequests(Priority priority, String resourceName, Resource capability)
           
 

Uses of Resource in org.apache.hadoop.yarn.security
 

Methods in org.apache.hadoop.yarn.security that return Resource
 Resource ContainerTokenIdentifier.getResource()
           
 

Constructors in org.apache.hadoop.yarn.security with parameters of type Resource
ContainerTokenIdentifier(ContainerId containerID, String hostName, String appSubmitter, Resource r, long expiryTimeStamp, int masterKeyId, long rmIdentifier, Priority priority, long creationTime)
           
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.