@InterfaceAudience.Private public class BuilderUtils extends Object
Modifier and Type | Class and Description |
---|---|
static class |
BuilderUtils.ApplicationIdComparator |
static class |
BuilderUtils.ContainerIdComparator |
Constructor and Description |
---|
BuilderUtils() |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.yarn.api.records.ApplicationId |
convert(long clustertimestamp,
CharSequence id) |
static org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse |
newAllocateResponse(int responseId,
List<org.apache.hadoop.yarn.api.records.ContainerStatus> completedContainers,
List<org.apache.hadoop.yarn.api.records.Container> allocatedContainers,
List<org.apache.hadoop.yarn.api.records.NodeReport> updatedNodes,
org.apache.hadoop.yarn.api.records.Resource availResources,
org.apache.hadoop.yarn.api.records.AMCommand command,
int numClusterNodes,
org.apache.hadoop.yarn.api.records.PreemptionMessage preempt) |
static org.apache.hadoop.yarn.api.records.Token |
newAMRMToken(byte[] identifier,
String kind,
byte[] password,
String service) |
static org.apache.hadoop.yarn.api.records.ApplicationAttemptId |
newApplicationAttemptId(org.apache.hadoop.yarn.api.records.ApplicationId appId,
int attemptId) |
static org.apache.hadoop.yarn.api.records.ApplicationId |
newApplicationId(long clusterTimeStamp,
int id) |
static org.apache.hadoop.yarn.api.records.ApplicationId |
newApplicationId(org.apache.hadoop.yarn.factories.RecordFactory recordFactory,
long clustertimestamp,
CharSequence id) |
static org.apache.hadoop.yarn.api.records.ApplicationId |
newApplicationId(org.apache.hadoop.yarn.factories.RecordFactory recordFactory,
long clusterTimeStamp,
int id) |
static org.apache.hadoop.yarn.api.records.ApplicationReport |
newApplicationReport(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId,
String user,
String queue,
String name,
String host,
int rpcPort,
org.apache.hadoop.yarn.api.records.Token clientToAMToken,
org.apache.hadoop.yarn.api.records.YarnApplicationState state,
String diagnostics,
String url,
long startTime,
long finishTime,
org.apache.hadoop.yarn.api.records.FinalApplicationStatus finalStatus,
org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport appResources,
String origTrackingUrl,
float progress,
String appType,
org.apache.hadoop.yarn.api.records.Token amRmToken,
Set<String> tags) |
static org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport |
newApplicationResourceUsageReport(int numUsedContainers,
int numReservedContainers,
org.apache.hadoop.yarn.api.records.Resource usedResources,
org.apache.hadoop.yarn.api.records.Resource reservedResources,
org.apache.hadoop.yarn.api.records.Resource neededResources,
long memorySeconds,
long vcoreSeconds) |
static org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext |
newApplicationSubmissionContext(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
String applicationName,
String queue,
org.apache.hadoop.yarn.api.records.Priority priority,
org.apache.hadoop.yarn.api.records.ContainerLaunchContext amContainer,
boolean isUnmanagedAM,
boolean cancelTokensWhenComplete,
int maxAppAttempts,
org.apache.hadoop.yarn.api.records.Resource resource) |
static org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext |
newApplicationSubmissionContext(org.apache.hadoop.yarn.api.records.ApplicationId applicationId,
String applicationName,
String queue,
org.apache.hadoop.yarn.api.records.Priority priority,
org.apache.hadoop.yarn.api.records.ContainerLaunchContext amContainer,
boolean isUnmanagedAM,
boolean cancelTokensWhenComplete,
int maxAppAttempts,
org.apache.hadoop.yarn.api.records.Resource resource,
String applicationType) |
static org.apache.hadoop.yarn.api.records.Token |
newClientToAMToken(byte[] identifier,
String kind,
byte[] password,
String service) |
static org.apache.hadoop.yarn.api.records.Container |
newContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId,
org.apache.hadoop.yarn.api.records.NodeId nodeId,
String nodeHttpAddress,
org.apache.hadoop.yarn.api.records.Resource resource,
org.apache.hadoop.yarn.api.records.Priority priority,
org.apache.hadoop.yarn.api.records.Token containerToken) |
static org.apache.hadoop.yarn.api.records.ContainerId |
newContainerId(org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
long containerId) |
static org.apache.hadoop.yarn.api.records.ContainerId |
newContainerId(int appId,
int appAttemptId,
long timestamp,
long id) |
static org.apache.hadoop.yarn.api.records.ContainerId |
newContainerId(org.apache.hadoop.yarn.factories.RecordFactory recordFactory,
org.apache.hadoop.yarn.api.records.ApplicationId appId,
org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId,
int containerId) |
static org.apache.hadoop.yarn.api.records.ContainerLaunchContext |
newContainerLaunchContext(Map<String,org.apache.hadoop.yarn.api.records.LocalResource> localResources,
Map<String,String> environment,
List<String> commands,
Map<String,ByteBuffer> serviceData,
ByteBuffer tokens,
Map<org.apache.hadoop.yarn.api.records.ApplicationAccessType,String> acls) |
static org.apache.hadoop.yarn.api.records.ContainerStatus |
newContainerStatus(org.apache.hadoop.yarn.api.records.ContainerId containerId,
org.apache.hadoop.yarn.api.records.ContainerState containerState,
String diagnostics,
int exitStatus) |
static org.apache.hadoop.yarn.api.records.Token |
newContainerToken(org.apache.hadoop.yarn.api.records.ContainerId cId,
String host,
int port,
String user,
org.apache.hadoop.yarn.api.records.Resource r,
long expiryTime,
int masterKeyId,
byte[] password,
long rmIdentifier) |
static org.apache.hadoop.yarn.api.records.Token |
newContainerToken(org.apache.hadoop.yarn.api.records.NodeId nodeId,
byte[] password,
org.apache.hadoop.yarn.security.ContainerTokenIdentifier tokenIdentifier) |
static org.apache.hadoop.yarn.security.ContainerTokenIdentifier |
newContainerTokenIdentifier(org.apache.hadoop.yarn.api.records.Token containerToken) |
static org.apache.hadoop.yarn.api.records.Token |
newDelegationToken(byte[] identifier,
String kind,
byte[] password,
String service) |
static org.apache.hadoop.yarn.api.records.LocalResource |
newLocalResource(URI uri,
org.apache.hadoop.yarn.api.records.LocalResourceType type,
org.apache.hadoop.yarn.api.records.LocalResourceVisibility visibility,
long size,
long timestamp,
boolean shouldBeUploadedToSharedCache) |
static org.apache.hadoop.yarn.api.records.LocalResource |
newLocalResource(org.apache.hadoop.yarn.api.records.URL url,
org.apache.hadoop.yarn.api.records.LocalResourceType type,
org.apache.hadoop.yarn.api.records.LocalResourceVisibility visibility,
long size,
long timestamp,
boolean shouldBeUploadedToSharedCache) |
static org.apache.hadoop.yarn.api.records.NodeId |
newNodeId(String host,
int port) |
static org.apache.hadoop.yarn.api.records.NodeReport |
newNodeReport(org.apache.hadoop.yarn.api.records.NodeId nodeId,
org.apache.hadoop.yarn.api.records.NodeState nodeState,
String httpAddress,
String rackName,
org.apache.hadoop.yarn.api.records.Resource used,
org.apache.hadoop.yarn.api.records.Resource capability,
int numContainers,
String healthReport,
long lastHealthReportTime) |
static org.apache.hadoop.yarn.api.records.NodeReport |
newNodeReport(org.apache.hadoop.yarn.api.records.NodeId nodeId,
org.apache.hadoop.yarn.api.records.NodeState nodeState,
String httpAddress,
String rackName,
org.apache.hadoop.yarn.api.records.Resource used,
org.apache.hadoop.yarn.api.records.Resource capability,
int numContainers,
String healthReport,
long lastHealthReportTime,
Set<String> nodeLabels) |
static org.apache.hadoop.yarn.api.records.Priority |
newPriority(int p) |
static org.apache.hadoop.yarn.api.records.Resource |
newResource(int memory,
int vCores) |
static org.apache.hadoop.yarn.api.records.ResourceRequest |
newResourceRequest(org.apache.hadoop.yarn.api.records.Priority priority,
String hostName,
org.apache.hadoop.yarn.api.records.Resource capability,
int numContainers) |
static org.apache.hadoop.yarn.api.records.ResourceRequest |
newResourceRequest(org.apache.hadoop.yarn.api.records.ResourceRequest r) |
static <T extends org.apache.hadoop.yarn.api.records.Token> |
newToken(Class<T> tokenClass,
byte[] identifier,
String kind,
byte[] password,
String service) |
static org.apache.hadoop.yarn.api.records.URL |
newURL(String scheme,
String host,
int port,
String file) |
public static org.apache.hadoop.yarn.api.records.LocalResource newLocalResource(org.apache.hadoop.yarn.api.records.URL url, org.apache.hadoop.yarn.api.records.LocalResourceType type, org.apache.hadoop.yarn.api.records.LocalResourceVisibility visibility, long size, long timestamp, boolean shouldBeUploadedToSharedCache)
public static org.apache.hadoop.yarn.api.records.LocalResource newLocalResource(URI uri, org.apache.hadoop.yarn.api.records.LocalResourceType type, org.apache.hadoop.yarn.api.records.LocalResourceVisibility visibility, long size, long timestamp, boolean shouldBeUploadedToSharedCache)
public static org.apache.hadoop.yarn.api.records.ApplicationId newApplicationId(org.apache.hadoop.yarn.factories.RecordFactory recordFactory, long clustertimestamp, CharSequence id)
public static org.apache.hadoop.yarn.api.records.ApplicationId newApplicationId(org.apache.hadoop.yarn.factories.RecordFactory recordFactory, long clusterTimeStamp, int id)
public static org.apache.hadoop.yarn.api.records.ApplicationId newApplicationId(long clusterTimeStamp, int id)
public static org.apache.hadoop.yarn.api.records.ApplicationAttemptId newApplicationAttemptId(org.apache.hadoop.yarn.api.records.ApplicationId appId, int attemptId)
public static org.apache.hadoop.yarn.api.records.ApplicationId convert(long clustertimestamp, CharSequence id)
public static org.apache.hadoop.yarn.api.records.ContainerId newContainerId(org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId, long containerId)
public static org.apache.hadoop.yarn.api.records.ContainerId newContainerId(int appId, int appAttemptId, long timestamp, long id)
public static org.apache.hadoop.yarn.api.records.Token newContainerToken(org.apache.hadoop.yarn.api.records.ContainerId cId, String host, int port, String user, org.apache.hadoop.yarn.api.records.Resource r, long expiryTime, int masterKeyId, byte[] password, long rmIdentifier) throws IOException
IOException
public static org.apache.hadoop.yarn.api.records.ContainerId newContainerId(org.apache.hadoop.yarn.factories.RecordFactory recordFactory, org.apache.hadoop.yarn.api.records.ApplicationId appId, org.apache.hadoop.yarn.api.records.ApplicationAttemptId appAttemptId, int containerId)
public static org.apache.hadoop.yarn.api.records.NodeId newNodeId(String host, int port)
public static org.apache.hadoop.yarn.api.records.NodeReport newNodeReport(org.apache.hadoop.yarn.api.records.NodeId nodeId, org.apache.hadoop.yarn.api.records.NodeState nodeState, String httpAddress, String rackName, org.apache.hadoop.yarn.api.records.Resource used, org.apache.hadoop.yarn.api.records.Resource capability, int numContainers, String healthReport, long lastHealthReportTime)
public static org.apache.hadoop.yarn.api.records.NodeReport newNodeReport(org.apache.hadoop.yarn.api.records.NodeId nodeId, org.apache.hadoop.yarn.api.records.NodeState nodeState, String httpAddress, String rackName, org.apache.hadoop.yarn.api.records.Resource used, org.apache.hadoop.yarn.api.records.Resource capability, int numContainers, String healthReport, long lastHealthReportTime, Set<String> nodeLabels)
public static org.apache.hadoop.yarn.api.records.ContainerStatus newContainerStatus(org.apache.hadoop.yarn.api.records.ContainerId containerId, org.apache.hadoop.yarn.api.records.ContainerState containerState, String diagnostics, int exitStatus)
public static org.apache.hadoop.yarn.api.records.Container newContainer(org.apache.hadoop.yarn.api.records.ContainerId containerId, org.apache.hadoop.yarn.api.records.NodeId nodeId, String nodeHttpAddress, org.apache.hadoop.yarn.api.records.Resource resource, org.apache.hadoop.yarn.api.records.Priority priority, org.apache.hadoop.yarn.api.records.Token containerToken)
public static <T extends org.apache.hadoop.yarn.api.records.Token> T newToken(Class<T> tokenClass, byte[] identifier, String kind, byte[] password, String service)
public static org.apache.hadoop.yarn.api.records.Token newDelegationToken(byte[] identifier, String kind, byte[] password, String service)
public static org.apache.hadoop.yarn.api.records.Token newClientToAMToken(byte[] identifier, String kind, byte[] password, String service)
public static org.apache.hadoop.yarn.api.records.Token newAMRMToken(byte[] identifier, String kind, byte[] password, String service)
public static org.apache.hadoop.yarn.api.records.Token newContainerToken(org.apache.hadoop.yarn.api.records.NodeId nodeId, byte[] password, org.apache.hadoop.yarn.security.ContainerTokenIdentifier tokenIdentifier)
public static org.apache.hadoop.yarn.security.ContainerTokenIdentifier newContainerTokenIdentifier(org.apache.hadoop.yarn.api.records.Token containerToken) throws IOException
IOException
public static org.apache.hadoop.yarn.api.records.ContainerLaunchContext newContainerLaunchContext(Map<String,org.apache.hadoop.yarn.api.records.LocalResource> localResources, Map<String,String> environment, List<String> commands, Map<String,ByteBuffer> serviceData, ByteBuffer tokens, Map<org.apache.hadoop.yarn.api.records.ApplicationAccessType,String> acls)
public static org.apache.hadoop.yarn.api.records.Priority newPriority(int p)
public static org.apache.hadoop.yarn.api.records.ResourceRequest newResourceRequest(org.apache.hadoop.yarn.api.records.Priority priority, String hostName, org.apache.hadoop.yarn.api.records.Resource capability, int numContainers)
public static org.apache.hadoop.yarn.api.records.ResourceRequest newResourceRequest(org.apache.hadoop.yarn.api.records.ResourceRequest r)
public static org.apache.hadoop.yarn.api.records.ApplicationReport newApplicationReport(org.apache.hadoop.yarn.api.records.ApplicationId applicationId, org.apache.hadoop.yarn.api.records.ApplicationAttemptId applicationAttemptId, String user, String queue, String name, String host, int rpcPort, org.apache.hadoop.yarn.api.records.Token clientToAMToken, org.apache.hadoop.yarn.api.records.YarnApplicationState state, String diagnostics, String url, long startTime, long finishTime, org.apache.hadoop.yarn.api.records.FinalApplicationStatus finalStatus, org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport appResources, String origTrackingUrl, float progress, String appType, org.apache.hadoop.yarn.api.records.Token amRmToken, Set<String> tags)
public static org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext newApplicationSubmissionContext(org.apache.hadoop.yarn.api.records.ApplicationId applicationId, String applicationName, String queue, org.apache.hadoop.yarn.api.records.Priority priority, org.apache.hadoop.yarn.api.records.ContainerLaunchContext amContainer, boolean isUnmanagedAM, boolean cancelTokensWhenComplete, int maxAppAttempts, org.apache.hadoop.yarn.api.records.Resource resource, String applicationType)
public static org.apache.hadoop.yarn.api.records.ApplicationSubmissionContext newApplicationSubmissionContext(org.apache.hadoop.yarn.api.records.ApplicationId applicationId, String applicationName, String queue, org.apache.hadoop.yarn.api.records.Priority priority, org.apache.hadoop.yarn.api.records.ContainerLaunchContext amContainer, boolean isUnmanagedAM, boolean cancelTokensWhenComplete, int maxAppAttempts, org.apache.hadoop.yarn.api.records.Resource resource)
public static org.apache.hadoop.yarn.api.records.ApplicationResourceUsageReport newApplicationResourceUsageReport(int numUsedContainers, int numReservedContainers, org.apache.hadoop.yarn.api.records.Resource usedResources, org.apache.hadoop.yarn.api.records.Resource reservedResources, org.apache.hadoop.yarn.api.records.Resource neededResources, long memorySeconds, long vcoreSeconds)
public static org.apache.hadoop.yarn.api.records.Resource newResource(int memory, int vCores)
public static org.apache.hadoop.yarn.api.records.URL newURL(String scheme, String host, int port, String file)
public static org.apache.hadoop.yarn.api.protocolrecords.AllocateResponse newAllocateResponse(int responseId, List<org.apache.hadoop.yarn.api.records.ContainerStatus> completedContainers, List<org.apache.hadoop.yarn.api.records.Container> allocatedContainers, List<org.apache.hadoop.yarn.api.records.NodeReport> updatedNodes, org.apache.hadoop.yarn.api.records.Resource availResources, org.apache.hadoop.yarn.api.records.AMCommand command, int numClusterNodes, org.apache.hadoop.yarn.api.records.PreemptionMessage preempt)
Copyright © 2016 Apache Software Foundation. All Rights Reserved.