Package | Description |
---|---|
org.apache.hadoop.yarn.api.protocolrecords |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.api.records |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.client.api | |
org.apache.hadoop.yarn.client.api.async | |
org.apache.hadoop.yarn.exceptions |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.security |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
Modifier and Type | Method and Description |
---|---|
abstract Resource |
AllocateResponse.getAvailableResources()
Get the available headroom for resources in the cluster for the
application.
|
abstract Resource |
GetNewApplicationResponse.getMaximumResourceCapability()
Get the maximum capability for any
Resource allocated by the
ResourceManager in the cluster. |
abstract Resource |
RegisterApplicationMasterResponse.getMaximumResourceCapability()
Get the maximum capability for any
Resource allocated by the
ResourceManager in the cluster. |
abstract Resource |
GetResourceProfileResponse.getResource()
Get the resources that will be allocated if the profile was used.
|
Modifier and Type | Method and Description |
---|---|
abstract Map<String,Resource> |
RegisterApplicationMasterResponse.getResourceProfiles()
Get list of supported resource profiles from RM.
|
abstract Map<String,Resource> |
GetAllResourceProfilesResponse.getResourceProfiles() |
Modifier and Type | Method and Description |
---|---|
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,
Token amRMToken,
List<UpdatedContainer> updatedContainers,
CollectorInfo collectorInfo) |
abstract void |
GetResourceProfileResponse.setResource(Resource r)
Set the resources that will be allocated if the profile is used.
|
Modifier and Type | Method and Description |
---|---|
abstract void |
GetAllResourceProfilesResponse.setResourceProfiles(Map<String,Resource> profiles) |
Modifier and Type | Method and Description |
---|---|
abstract Resource |
ContainerReport.getAllocatedResource()
Get the allocated
Resource of the container. |
abstract Resource |
ReservationRequest.getCapability()
Get the
Resource capability of the request. |
abstract Resource |
UpdateContainerRequest.getCapability()
Get the
Resource capability of the request. |
abstract Resource |
ResourceAllocationRequest.getCapability()
Get the allocated resource.
|
abstract Resource |
ResourceRequest.getCapability()
Get the
Resource capability of the request. |
Resource |
ContainerStatus.getCapability()
Get the
Resource allocated to the container. |
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 |
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 |
ResourceSizing.getResources() |
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) |
static Resource |
Resource.newInstance(long memory,
int vCores) |
static Resource |
Resource.newInstance(long memory,
int vCores,
Map<String,Long> others)
Create a new
Resource instance with the given CPU and memory
values and additional resource values as set in the others
parameter. |
Modifier and Type | Method and Description |
---|---|
ResourceRequest.ResourceRequestBuilder |
ResourceRequest.ResourceRequestBuilder.capability(Resource capability)
Set the
capability of the request. |
int |
Resource.compareTo(Resource other) |
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) |
static UpdateContainerRequest |
UpdateContainerRequest.newInstance(int version,
ContainerId containerId,
ContainerUpdateType updateType,
Resource targetCapability,
ExecutionType targetExecutionType) |
static ResourceSizing |
ResourceSizing.newInstance(int numAllocations,
Resource resources) |
static ResourceAllocationRequest |
ResourceAllocationRequest.newInstance(long startTime,
long endTime,
Resource capability) |
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 ResourceRequest |
ResourceRequest.newInstance(Priority priority,
String hostName,
Resource capability,
int numContainers,
boolean relaxLocality,
String labelExpression) |
static ResourceRequest |
ResourceRequest.newInstance(Priority priority,
String hostName,
Resource capability,
int numContainers,
boolean relaxLocality,
String labelExpression,
ExecutionTypeRequest executionTypeRequest) |
static ResourceSizing |
ResourceSizing.newInstance(Resource resources) |
static ReservationRequest |
ReservationRequest.newInstance(Resource capability,
int numContainers) |
static ResourceOption |
ResourceOption.newInstance(Resource resource,
int overCommitTimeout) |
static ReservationRequest |
ReservationRequest.newInstance(Resource capability,
int numContainers,
int concurrency,
long duration) |
abstract void |
ContainerReport.setAllocatedResource(Resource resource) |
abstract void |
ReservationRequest.setCapability(Resource capability)
Set the
Resource capability of the request |
abstract void |
UpdateContainerRequest.setCapability(Resource capability)
Set the
Resource capability of the request. |
abstract void |
ResourceRequest.setCapability(Resource capability)
Set the
Resource capability of the request. |
abstract void |
ApplicationSubmissionContext.setResource(Resource resource)
Set the resource required by the
ApplicationMaster for this
application. |
abstract void |
ResourceSizing.setResources(Resource resources) |
Modifier and Type | Method and Description |
---|---|
abstract Resource |
AMRMClient.getAvailableResources()
Get the currently available resources in the cluster.
|
abstract Resource |
YarnClient.getResourceProfile(String profile)
Get the details of a specific resource profile from the RM.
|
Modifier and Type | Method and Description |
---|---|
abstract Map<String,Resource> |
YarnClient.getResourceProfiles()
Get the resource profiles available in the RM.
|
Modifier and Type | Method and Description |
---|---|
List<? extends Collection<T>> |
AMRMClient.getMatchingRequests(Priority priority,
String resourceName,
ExecutionType executionType,
Resource capability)
Get outstanding
ContainerRequest s matching the given
parameters. |
List<? extends Collection<T>> |
AMRMClient.getMatchingRequests(Priority priority,
String resourceName,
ExecutionType executionType,
Resource capability,
String profile) |
abstract List<? extends Collection<T>> |
AMRMClient.getMatchingRequests(Priority priority,
String resourceName,
Resource capability)
Get outstanding
ContainerRequest s matching the given
parameters. |
void |
AMRMClient.requestContainerResourceChange(Container container,
Resource capability)
|
Modifier and Type | Method and Description |
---|---|
abstract Resource |
AMRMClientAsync.getAvailableResources()
Get the currently available resources in the cluster.
|
Modifier and Type | Method and Description |
---|---|
List<? extends Collection<T>> |
AMRMClientAsync.getMatchingRequests(Priority priority,
String resourceName,
ExecutionType executionType,
Resource capability)
Returns all matching ContainerRequests that match the given Priority,
ResourceName, ExecutionType and Capability.
|
abstract List<? extends Collection<T>> |
AMRMClientAsync.getMatchingRequests(Priority priority,
String resourceName,
Resource capability) |
void |
AMRMClientAsync.requestContainerResourceChange(Container container,
Resource capability)
|
Constructor and Description |
---|
ResourceNotFoundException(Resource resource,
String type) |
ResourceNotFoundException(Resource resource,
String type,
Throwable cause) |
Modifier and Type | Method and Description |
---|---|
Resource |
ContainerTokenIdentifier.getResource() |
Constructor and Description |
---|
ContainerTokenIdentifier(ContainerId containerID,
int containerVersion,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext,
String nodeLabelExpression,
org.apache.hadoop.yarn.server.api.ContainerType containerType,
ExecutionType executionType) |
ContainerTokenIdentifier(ContainerId containerID,
int containerVersion,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext,
String nodeLabelExpression,
org.apache.hadoop.yarn.server.api.ContainerType containerType,
ExecutionType executionType,
long allocationRequestId)
Convenience Constructor for existing clients.
|
ContainerTokenIdentifier(ContainerId containerID,
int containerVersion,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext,
String nodeLabelExpression,
org.apache.hadoop.yarn.server.api.ContainerType containerType,
ExecutionType executionType,
long allocationRequestId,
Set<String> allocationTags)
Create a Container Token Identifier.
|
ContainerTokenIdentifier(ContainerId containerID,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime) |
ContainerTokenIdentifier(ContainerId containerID,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext)
Deprecated.
Use one of the other constructors instead.
|
ContainerTokenIdentifier(ContainerId containerID,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext,
String nodeLabelExpression) |
ContainerTokenIdentifier(ContainerId containerID,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext,
String nodeLabelExpression,
org.apache.hadoop.yarn.server.api.ContainerType containerType) |
Copyright © 2024 Apache Software Foundation. All rights reserved.