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.security |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
Modifier and Type | Method and Description |
---|---|
abstract LogAggregationContext |
ApplicationSubmissionContext.getLogAggregationContext()
Get
LogAggregationContext of the application |
static LogAggregationContext |
LogAggregationContext.newInstance(String includePattern,
String excludePattern) |
static LogAggregationContext |
LogAggregationContext.newInstance(String includePattern,
String excludePattern,
String rolledLogsIncludePattern,
String rolledLogsExcludePattern) |
static LogAggregationContext |
LogAggregationContext.newInstance(String includePattern,
String excludePattern,
String rolledLogsIncludePattern,
String rolledLogsExcludePattern,
String policyClassName,
String policyParameters) |
Modifier and Type | Method and Description |
---|---|
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) |
abstract void |
ApplicationSubmissionContext.setLogAggregationContext(LogAggregationContext logAggregationContext)
Set
LogAggregationContext for the application |
Modifier and Type | Method and Description |
---|---|
LogAggregationContext |
ContainerTokenIdentifier.getLogAggregationContext() |
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,
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.