Package | Description |
---|---|
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.security |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
Modifier and Type | Method and Description |
---|---|
ExecutionType |
ContainerStatus.getExecutionType()
Get the
ExecutionType of the container. |
abstract ExecutionType |
ContainerReport.getExecutionType()
Get the execution type of the container.
|
abstract ExecutionType |
ExecutionTypeRequest.getExecutionType()
Get
ExecutionType . |
abstract ExecutionType |
UpdateContainerRequest.getExecutionType()
Get the target
ExecutionType of the container. |
static ExecutionType |
ExecutionType.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static ExecutionType[] |
ExecutionType.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
ResourceRequest.ResourceRequestBuilder |
ResourceRequest.ResourceRequestBuilder.executionType(ExecutionType executionType)
Set the
executionTypeRequest of the request with 'ensure
execution type' flag set to true. |
static ExecutionTypeRequest |
ExecutionTypeRequest.newInstance(ExecutionType execType) |
static ExecutionTypeRequest |
ExecutionTypeRequest.newInstance(ExecutionType execType,
boolean ensureExecutionType) |
static UpdateContainerRequest |
UpdateContainerRequest.newInstance(int version,
ContainerId containerId,
ContainerUpdateType updateType,
Resource targetCapability,
ExecutionType targetExecutionType) |
abstract void |
ExecutionTypeRequest.setExecutionType(ExecutionType execType)
Set the
ExecutionType of the requested container. |
abstract void |
UpdateContainerRequest.setExecutionType(ExecutionType executionType)
Set the target
ExecutionType of the container. |
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) |
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.
|
Modifier and Type | Method and Description |
---|---|
ExecutionType |
ContainerTokenIdentifier.getExecutionType()
Get the ExecutionType of container to allocate
|
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.
|
Copyright © 2024 Apache Software Foundation. All rights reserved.