- cacheForDAG(String, Object) - Method in interface org.apache.tez.runtime.api.ObjectRegistry
-
Insert or update object into the registry with DAG life-cycle.
- cacheForSession(String, Object) - Method in interface org.apache.tez.runtime.api.ObjectRegistry
-
Insert or update object into the registry with Session life-cycle.
- cacheForVertex(String, Object) - Method in interface org.apache.tez.runtime.api.ObjectRegistry
-
Insert or update object into the registry with Vertex life-cycle.
- CallerContext - Class in org.apache.tez.client
-
- canCommit() - Method in interface org.apache.tez.runtime.api.ProcessorContext
-
Check whether this attempt can commit its output
- clearAppMasterLocalFiles() - Method in class org.apache.tez.client.TezClient
-
- close() - Method in interface org.apache.tez.runtime.api.InputFrameworkInterface
-
Closes the Input
- close() - Method in interface org.apache.tez.runtime.api.OutputFrameworkInterface
-
Closes the Output
- close() - Method in interface org.apache.tez.runtime.api.ProcessorFrameworkInterface
-
Closes the Processor
- commitOutput() - Method in class org.apache.tez.runtime.api.OutputCommitter
-
For committing the output after successful completion of tasks that write
the output.
- CompositeDataMovementEvent - Class in org.apache.tez.runtime.api.events
-
A convenience class to specify multiple DataMovementEvents which share the
same payload.
- CompositeRoutedDataMovementEvent - Class in org.apache.tez.runtime.api.events
-
A convenience class to specify multiple DataMovementEvents which share the same payload.
- containerAllocated(Container) - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Indicate to the framework that a container is being allocated.
- containerBeingReleased(ContainerId) - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Indicates to the framework that a container is being released.
- containerCompleted(ContainerId, int, String, TaskAttemptEndReason) - Method in interface org.apache.tez.serviceplugins.api.ContainerLauncherContext
-
Inform the scheduler that a container was successfully stopped
- containerCompleted(Object, ContainerStatus) - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Indicate to the framework that a container has completed.
- ContainerEndReason - Enum in org.apache.tez.serviceplugins.api
-
- containerLaunched(ContainerId) - Method in interface org.apache.tez.serviceplugins.api.ContainerLauncherContext
-
Inform the framework that a container has been launched
- ContainerLauncher - Class in org.apache.tez.serviceplugins.api
-
Plugin to allow custom container launchers to be written to launch containers on different types
of executors.
- ContainerLauncher(ContainerLauncherContext) - Constructor for class org.apache.tez.serviceplugins.api.ContainerLauncher
-
- ContainerLauncherContext - Interface in org.apache.tez.serviceplugins.api
-
- ContainerLauncherDescriptor - Class in org.apache.tez.serviceplugins.api
-
- ContainerLauncherOperationBase - Class in org.apache.tez.serviceplugins.api
-
- ContainerLauncherOperationBase(NodeId, ContainerId, Token) - Constructor for class org.apache.tez.serviceplugins.api.ContainerLauncherOperationBase
-
- containerLaunchFailed(ContainerId, String) - Method in interface org.apache.tez.serviceplugins.api.ContainerLauncherContext
-
Inform the framework of an issue while trying to launch a container.
- ContainerLaunchRequest - Class in org.apache.tez.serviceplugins.api
-
Contains specifications for a container which needs to be launched
- ContainerLaunchRequest(NodeId, ContainerId, Token, ContainerLaunchContext, Container, String, String) - Constructor for class org.apache.tez.serviceplugins.api.ContainerLaunchRequest
-
- containerReused(Container) - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Indicate to the framework that a container is being reused:
there is a task assigned to an already used container.
- ContainerSignatureMatcher - Interface in org.apache.tez.common
-
- containerStopFailed(ContainerId, String) - Method in interface org.apache.tez.serviceplugins.api.ContainerLauncherContext
-
Inform the framework that the attempt to stop a container failed
- ContainerStopRequest - Class in org.apache.tez.serviceplugins.api
-
Contains specifications for a container which needs to be stopped
- ContainerStopRequest(NodeId, ContainerId, Token, String, String) - Constructor for class org.apache.tez.serviceplugins.api.ContainerStopRequest
-
- containerStopRequested(ContainerId) - Method in interface org.apache.tez.serviceplugins.api.ContainerLauncherContext
-
Inform the framework that a request has been made to stop a container
- contextAsSimpleString() - Method in class org.apache.tez.client.CallerContext
-
- convertToHistoryText(String, Configuration) - Static method in class org.apache.tez.common.TezUtils
-
- convertToHistoryText(Configuration) - Static method in class org.apache.tez.common.TezUtils
-
- count - Variable in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- countCounters() - Method in class org.apache.tez.common.counters.AbstractCounters
-
Returns the total number of counters, by summing the number of counters
in each group.
- CounterGroup - Interface in org.apache.tez.common.counters
-
A group of
TezCounter
s that logically belong together.
- CounterGroupBase<T extends TezCounter> - Interface in org.apache.tez.common.counters
-
The common counter group interface.
- create(String, String, String, String) - Static method in class org.apache.tez.client.CallerContext
-
Instantiate the Caller Context
- create(String, TezConfiguration) - Static method in class org.apache.tez.client.TezClient
-
Create a new TezClient.
- create(String, TezConfiguration, Map<String, LocalResource>, Credentials) - Static method in class org.apache.tez.client.TezClient
-
Create a new TezClient.
- create(String, TezConfiguration, boolean) - Static method in class org.apache.tez.client.TezClient
-
Create a new TezClient with AM session mode set explicitly.
- create(String, TezConfiguration, boolean, Map<String, LocalResource>, Credentials) - Static method in class org.apache.tez.client.TezClient
-
Create a new TezClient with AM session mode set explicitly.
- create(String) - Static method in class org.apache.tez.dag.api.DAG
-
Create a DAG with the specified name.
- create(OutputDescriptor, OutputCommitterDescriptor, Credentials) - Static method in class org.apache.tez.dag.api.DataSinkDescriptor
-
- create(InputDescriptor, InputInitializerDescriptor, Credentials) - Static method in class org.apache.tez.dag.api.DataSourceDescriptor
-
- create(InputDescriptor, InputInitializerDescriptor, int, Credentials, VertexLocationHint, Map<String, LocalResource>) - Static method in class org.apache.tez.dag.api.DataSourceDescriptor
-
- create(Vertex, Vertex, EdgeProperty) - Static method in class org.apache.tez.dag.api.Edge
-
Creates an edge between the specified vertices.
- create(String) - Static method in class org.apache.tez.dag.api.EdgeManagerPluginDescriptor
-
- create(EdgeProperty.DataMovementType, EdgeProperty.DataSourceType, EdgeProperty.SchedulingType, OutputDescriptor, InputDescriptor) - Static method in class org.apache.tez.dag.api.EdgeProperty
-
Setup an EdgeProperty which makes use of one of the provided EdgeProperty.DataMovementType
s
- create(EdgeManagerPluginDescriptor, EdgeProperty.DataSourceType, EdgeProperty.SchedulingType, OutputDescriptor, InputDescriptor) - Static method in class org.apache.tez.dag.api.EdgeProperty
-
Setup an Edge which uses a custom EdgeManager
- create(VertexGroup, Vertex, EdgeProperty, InputDescriptor) - Static method in class org.apache.tez.dag.api.GroupInputEdge
-
An Edge that connects a
VertexGroup
to a destination Vertex.
- create(String) - Static method in class org.apache.tez.dag.api.InputDescriptor
-
- create(String) - Static method in class org.apache.tez.dag.api.InputInitializerDescriptor
-
- create(String) - Static method in class org.apache.tez.dag.api.OutputCommitterDescriptor
-
- create(String) - Static method in class org.apache.tez.dag.api.OutputDescriptor
-
- create(String, ProcessorDescriptor, int, Resource) - Static method in class org.apache.tez.dag.api.PreWarmVertex
-
- create(String, int, Resource) - Static method in class org.apache.tez.dag.api.PreWarmVertex
-
- create(String) - Static method in class org.apache.tez.dag.api.ProcessorDescriptor
-
- create(ByteBuffer) - Static method in class org.apache.tez.dag.api.UserPayload
-
Create a UserPayload instance which encapsulates a
ByteBuffer
.
- create(ByteBuffer, int) - Static method in class org.apache.tez.dag.api.UserPayload
-
Create an explicitly versioned UserPayload instance which encapsulates a
ByteBuffer
.
- create(String, ProcessorDescriptor, int, Resource) - Static method in class org.apache.tez.dag.api.Vertex
-
Create a new vertex with the given name.
- create(String, ProcessorDescriptor) - Static method in class org.apache.tez.dag.api.Vertex
-
Create a new vertex with the given name.
- create(String, ProcessorDescriptor, int) - Static method in class org.apache.tez.dag.api.Vertex
-
Create a new vertex with the given name and parallelism.
- create(String, String, String) - Static method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
-
- create(List<TaskLocationHint>) - Static method in class org.apache.tez.dag.api.VertexLocationHint
-
- create(String) - Static method in class org.apache.tez.dag.api.VertexManagerPluginDescriptor
-
- create(int, int, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- create(int, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.DataMovementEvent
-
User Event constructor for
Output
s
- create(int, VertexLocationHint, InputSpecUpdate) - Static method in class org.apache.tez.runtime.api.events.InputConfigureVertexTasksEvent
-
- create(String, String, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.InputInitializerEvent
-
- create(String, int, int) - Static method in class org.apache.tez.runtime.api.events.InputReadErrorEvent
-
Creates an InputReadErrorEvent from less parameters, supposed to be used from tests only.
- create(String, int, int, boolean, boolean, String) - Static method in class org.apache.tez.runtime.api.events.InputReadErrorEvent
-
- create(String, int, int, int, boolean, boolean, String) - Static method in class org.apache.tez.runtime.api.events.InputReadErrorEvent
-
Create an InputReadErrorEvent.
- create(ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.InputUpdatePayloadEvent
-
- create(String, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.VertexManagerEvent
-
Create a new VertexManagerEvent
- create(String, String) - Static method in class org.apache.tez.serviceplugins.api.ContainerLauncherDescriptor
-
- create(TaskSchedulerDescriptor[], ContainerLauncherDescriptor[], TaskCommunicatorDescriptor[]) - Static method in class org.apache.tez.serviceplugins.api.ServicePluginsDescriptor
-
Create a service plugin descriptor with the provided plugins.
- create(boolean, TaskSchedulerDescriptor[], ContainerLauncherDescriptor[], TaskCommunicatorDescriptor[]) - Static method in class org.apache.tez.serviceplugins.api.ServicePluginsDescriptor
-
Create a service plugin descriptor with the provided plugins.
- create(boolean, boolean, TaskSchedulerDescriptor[], ContainerLauncherDescriptor[], TaskCommunicatorDescriptor[]) - Static method in class org.apache.tez.serviceplugins.api.ServicePluginsDescriptor
-
Create a service plugin descriptor with the provided plugins.
- create(boolean) - Static method in class org.apache.tez.serviceplugins.api.ServicePluginsDescriptor
-
Create a service plugin descriptor which may have in-AM execution of tasks enabled.
- create(String, String) - Static method in class org.apache.tez.serviceplugins.api.TaskCommunicatorDescriptor
-
- create(String, String) - Static method in class org.apache.tez.serviceplugins.api.TaskSchedulerDescriptor
-
- createAllTaskInputSpecUpdate(int) - Static method in class org.apache.tez.runtime.api.InputSpecUpdate
-
Create an update instance where all work units (typically represented by
InputDataInformationEvent
) will have the same number of physical inputs.
- createByteStringFromConf(Configuration) - Static method in class org.apache.tez.common.TezUtils
-
Convert a Configuration to compressed ByteString using Protocol buffer
- createConfFromBaseConfAndPayload(TaskContext) - Static method in class org.apache.tez.common.TezUtils
-
- createConfFromByteString(ByteString) - Static method in class org.apache.tez.common.TezUtils
-
Convert a byte string to a Configuration object
- createConfFromUserPayload(UserPayload) - Static method in class org.apache.tez.common.TezUtils
-
- createConfigBuilder(Configuration) - Static method in class org.apache.tez.dag.api.PreWarmVertex
-
- createExecuteInAm(boolean) - Static method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
-
Create an execution context which specifies whether the vertex needs to be executed in the
AM
- createExecuteInContainers(boolean) - Static method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
-
Create an execution context which specifies whether the vertex needs to be executed in
regular containers
- createPerTaskInputSpecUpdate(List<Integer>) - Static method in class org.apache.tez.runtime.api.InputSpecUpdate
-
Create an update instance where all work units (typically represented by
InputDataInformationEvent
) will have the same number of physical inputs.
- createTaskLocationHint(String, int) - Static method in class org.apache.tez.dag.api.TaskLocationHint
-
Provide a location hint that affinitizes to the given task in the given vertex.
- createTaskLocationHint(Set<String>, Set<String>) - Static method in class org.apache.tez.dag.api.TaskLocationHint
-
Provides a location hint with nodes and racks at which the task may be executed.
- createUserPayloadFromConf(Configuration) - Static method in class org.apache.tez.common.TezUtils
-
- createVertexGroup(String, Vertex...) - Method in class org.apache.tez.dag.api.DAG
-
Create a group of vertices that share a common output.
- createWithObjectPayload(int, Object) - Static method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- createWithSerializedPath(int, String) - Static method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- createWithSerializedPayload(int, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
Provide a serialized form of the payload
- get(String) - Method in interface org.apache.tez.runtime.api.ObjectRegistry
-
Return the object associated with the provided key
- getAdditionalResources(Map<String, LocalResource>, Map<String, LocalResource>) - Method in interface org.apache.tez.common.ContainerSignatureMatcher
-
Gets additional resources specified in lr2, which are not present for lr1
- getAffinitizedTask() - Method in class org.apache.tez.dag.api.TaskLocationHint
-
- getAmHost() - Method in class org.apache.tez.client.TezClient
-
- getAMKeepAliveService() - Method in class org.apache.tez.client.TezClient
-
- getAmPort() - Method in class org.apache.tez.client.TezClient
-
- getAMState() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Get the state of the AppMaster
- getAppClientPort() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Get the port on which the DAG client is listening
- getAppHostName() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Get the hostname on which the app is running
- getApplicationAttemptId() - Method in interface org.apache.tez.serviceplugins.api.ContainerLauncherContext
-
Get the application attempt id for the running application.
- getApplicationAttemptId() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Get the application attempt id for the running application.
- getApplicationId() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the YARN application id given to the Tez Application Master
- getApplicationId() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
Get the ApplicationId
- getApplicationId() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the ApplicationId
for the running app
- getAppMasterStatus() - Method in class org.apache.tez.client.TezClient
-
Get the status of the App Master executing the DAG
In non-session mode it returns the status of the last submitted DAG App Master
In session mode, it returns the status of the App Master hosting the session
- getAppTrackingUrl() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Get the tracking URL for the application.
- getAvailableResources() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
-
Get the currently available resources from this source
- getBlob() - Method in class org.apache.tez.client.CallerContext
-
- getCallerContext() - Method in class org.apache.tez.dag.api.DAG
-
- getCallerId() - Method in class org.apache.tez.client.CallerContext
-
- getCallerType() - Method in class org.apache.tez.client.CallerContext
-
- getClassName() - Method in class org.apache.tez.dag.api.EntityDescriptor
-
- getClient(String) - Method in class org.apache.tez.client.TezClient
-
- getClient(ApplicationId) - Method in class org.apache.tez.client.TezClient
-
Alternative to start() that explicitly sets sessionAppId and doesn't start a new AM.
- getClientName() - Method in class org.apache.tez.client.TezClient
-
Get the name of the client
- getClusterNodeCount() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
-
Get the number of nodes available from the source
- getConf() - Method in class org.apache.tez.dag.api.Vertex
-
- getContainerConfiguration() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get container configuration
- getContainerId() - Method in class org.apache.tez.serviceplugins.api.ContainerLauncherOperationBase
-
Get the containerId for the container
- getContainerLaunchContext() - Method in class org.apache.tez.serviceplugins.api.ContainerLaunchRequest
-
- getContainerLauncherName() - Method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
-
- getContainerSignatureMatcher() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Get an instance of
ContainerSignatureMatcher
which can be used to check whether the
specifications of a container match what is required by a task.
- getContainerToken() - Method in class org.apache.tez.serviceplugins.api.ContainerLauncherOperationBase
-
Get the security token for the container.
- getContext() - Method in class org.apache.tez.client.CallerContext
-
- getContext() - Method in class org.apache.tez.dag.api.EdgeManagerPlugin
-
- getContext() - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
-
- getContext() - Method in class org.apache.tez.dag.api.VertexManagerPlugin
-
- getContext() - Method in class org.apache.tez.runtime.api.AbstractLogicalInput
-
Return ahe
InputContext
for this specific instance of
the LogicalInput
- getContext() - Method in class org.apache.tez.runtime.api.AbstractLogicalIOProcessor
-
- getContext() - Method in class org.apache.tez.runtime.api.AbstractLogicalOutput
-
Return the
OutputContext
for this specific instance of
the LogicalOutput
- getContext() - Method in class org.apache.tez.runtime.api.InputInitializer
-
- getContext() - Method in class org.apache.tez.runtime.api.MergedLogicalInput
-
- getContext() - Method in class org.apache.tez.runtime.api.OutputCommitter
-
- getContext() - Method in class org.apache.tez.serviceplugins.api.ContainerLauncher
-
Get the
ContainerLauncherContext
associated with this instance of the container
launcher, which is used to communicate with the rest of the system
- getContext() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
-
Get the
TaskSchedulerContext
associated with this instance of the scheduler, which is
used to communicate with the rest of the system
- getCount() - Method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- getCount() - Method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
-
- getCounters() - Method in interface org.apache.tez.runtime.api.TaskContext
-
- getCredentials() - Method in class org.apache.tez.dag.api.DataSinkDescriptor
-
- getCustomClusterIdentifier() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
A custom cluster identifier allocated to schedulers to generate an AppId, if not making
use of YARN
- getDAGAttemptNumber() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
- getDAGAttemptNumber() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
- getDAGAttemptNumber() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
Get the current DAG Attempt Number
- getDAGAttemptNumber() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the current DAG Attempt Number
- getDAGCounters() - Method in class org.apache.tez.dag.api.client.DAGStatus
-
- getDagIdentifier() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
- getDagIdentifier() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get a numeric identifier for the dag to which the task belongs.
- getDagIdentifierString() - Method in class org.apache.tez.dag.api.client.DAGClient
-
Get the dag identifier for the currently executing dag.
- getDAGName() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the name of the DAG
- getDAGName() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
Get the name of the DAG
- getDAGName() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the name of the DAG
- getDAGProgress() - Method in class org.apache.tez.dag.api.client.DAGStatus
-
Gets overall progress value of the DAG.
- getDAGStatus(Set<StatusGetOpts>) - Method in class org.apache.tez.dag.api.client.DAGClient
-
Get the status of the specified DAG
- getDAGStatus(Set<StatusGetOpts>, long) - Method in class org.apache.tez.dag.api.client.DAGClient
-
Get the status of the specified DAG when it reaches a final state, or the timeout expires.
- getDataMovementType() - Method in class org.apache.tez.dag.api.EdgeProperty
-
Get the EdgeProperty.DataMovementType
- getDataSize() - Method in interface org.apache.tez.runtime.api.InputStatistics
-
Returns the data size associated with this logical input
It is the size of the data read from this input by the vertex.
- getDataSize() - Method in interface org.apache.tez.runtime.api.OutputStatistics
-
Returns the data size associated with this logical output
It is the size of the data written to this output by the vertex.
- getDataSourceType() - Method in class org.apache.tez.dag.api.EdgeProperty
-
Get the EdgeProperty.DataSourceType
- getDefaultSinglePhysicalInputSpecUpdate() - Static method in class org.apache.tez.runtime.api.InputSpecUpdate
-
- getDeserializedUserPayload() - Method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- getDestinationLocalhostName() - Method in class org.apache.tez.runtime.api.events.InputReadErrorEvent
-
- getDestinationVertexName() - Method in interface org.apache.tez.dag.api.EdgeManagerPluginContext
-
Returns the destination vertex name
- getDestinationVertexName() - Method in interface org.apache.tez.runtime.api.OutputContext
-
Get the Vertex Name of the Destination that is the recipient of this
Output's data
- getDestinationVertexNumTasks() - Method in interface org.apache.tez.dag.api.EdgeManagerPluginContext
-
Returns the number of tasks in the destination vertex
- getDiagnostics() - Method in class org.apache.tez.dag.api.client.DAGStatus
-
- getDiagnostics() - Method in class org.apache.tez.dag.api.client.VertexStatus
-
- getDiagnostics() - Method in class org.apache.tez.runtime.api.events.InputReadErrorEvent
-
- getDisplayName() - Method in interface org.apache.tez.common.counters.CounterGroupBase
-
Get the display name of the group.
- getDisplayName() - Method in interface org.apache.tez.common.counters.TezCounter
-
Get the display name of the counter.
- getEdgeDestination() - Method in class org.apache.tez.dag.api.EdgeProperty
-
- getEdgeProperty() - Method in class org.apache.tez.dag.api.Edge
-
- getEdgeProperty() - Method in class org.apache.tez.dag.api.GroupInputEdge
-
- getEdgeSource() - Method in class org.apache.tez.dag.api.EdgeProperty
-
- getEnum() - Method in interface org.apache.tez.serviceplugins.api.ServicePluginError
-
Get the enum representation
- getEnum() - Method in enum org.apache.tez.serviceplugins.api.ServicePluginErrorDefaults
-
- getErrorType() - Method in interface org.apache.tez.serviceplugins.api.ServicePluginError
-
The type of the error
- getErrorType() - Method in enum org.apache.tez.serviceplugins.api.ServicePluginErrorDefaults
-
- getEvents() - Method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- getExecutionContext() - Method in class org.apache.tez.dag.api.client.DAGClient
-
Gets DAG execution context for use with logging
- getExecutionContext() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the context for the executor.
- getFailedTaskAttemptCount() - Method in class org.apache.tez.dag.api.client.Progress
-
- getFailedTaskCount() - Method in class org.apache.tez.dag.api.client.Progress
-
- getFinalAppStatus() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Get the final status for the application, which could be provided to the coordinator of the
source.
- getGroup(String) - Method in class org.apache.tez.common.counters.AbstractCounters
-
Returns the named counter group, or an empty group if there is none
with the specified name.
- getGroupName() - Method in class org.apache.tez.dag.api.VertexGroup
-
Get the name of the group
- getGroupNames() - Method in class org.apache.tez.common.counters.AbstractCounters
-
Returns the names of all counter classes.
- getHeldContainersCount() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
-
Get the number of held containers.
- getHostName() - Method in interface org.apache.tez.runtime.api.ExecutionContext
-
Get the hostname on which the JVM is running.
- getHosts() - Method in class org.apache.tez.dag.api.TaskLocationHint
-
- getId() - Method in class org.apache.tez.dag.api.client.VertexStatus
-
- getIndex() - Method in class org.apache.tez.runtime.api.events.InputReadErrorEvent
-
- getInputDescriptor() - Method in class org.apache.tez.dag.api.DataSourceDescriptor
-
- getInputIndex() - Method in interface org.apache.tez.runtime.api.InputContext
-
Get the index of the input in the set of all inputs for the task.
- getInputInitializerDescriptor() - Method in class org.apache.tez.dag.api.DataSourceDescriptor
-
- getInputName() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the name of the input
- getInputOutputVertexNames() - Method in interface org.apache.tez.runtime.api.InputContext
-
Returns a convenient, human-readable string describing the input and output vertices.
- getInputOutputVertexNames() - Method in interface org.apache.tez.runtime.api.OutputContext
-
Returns a convenient, human-readable string describing the input and output vertices.
- getInputs() - Method in class org.apache.tez.runtime.api.MergedLogicalInput
-
- getInputSpecUpdate() - Method in class org.apache.tez.runtime.api.events.InputConfigureVertexTasksEvent
-
- getInputStatistics(String) - Method in interface org.apache.tez.runtime.api.VertexStatistics
-
Get statistics about an
Edge
input or external input of this
Vertex
.
- getInputUserPayload() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the user payload for the input
- getInputVertex() - Method in class org.apache.tez.dag.api.Edge
-
The @link
Vertex
that provides input to the edge
- getInputVertexEdgeProperties() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the edge properties on the input edges of this vertex.
- getInputVertexGroup() - Method in class org.apache.tez.dag.api.GroupInputEdge
-
- getInputVertexGroups() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get input vertex groups of this vertex, including vertex group name and
all members vertex name
- getInputVertices() - Method in class org.apache.tez.dag.api.Vertex
-
Get the input vertices for this vertex
- getItemsProcessed() - Method in interface org.apache.tez.runtime.api.InputStatistics
-
Get the numbers of items processed.
- getItemsProcessed() - Method in interface org.apache.tez.runtime.api.OutputStatistics
-
Get the numbers of items processed.
- getKilledTaskAttemptCount() - Method in class org.apache.tez.dag.api.client.Progress
-
- getKilledTaskCount() - Method in class org.apache.tez.dag.api.client.Progress
-
- getLocationHint() - Method in class org.apache.tez.runtime.api.events.InputConfigureVertexTasksEvent
-
- getLogLevel(Configuration, HistoryLogLevel) - Static method in enum org.apache.tez.dag.api.HistoryLogLevel
-
- getMemoryUsedByAM() - Method in class org.apache.tez.dag.api.client.DAGStatus
-
- getMemoryUsedByTasks() - Method in class org.apache.tez.dag.api.client.DAGStatus
-
- getName() - Method in interface org.apache.tez.common.counters.CounterGroupBase
-
Get the internal name of the group
- getName() - Method in interface org.apache.tez.common.counters.TezCounter
-
- getName() - Method in class org.apache.tez.dag.api.DAG
-
Get the DAG name
- getName() - Method in class org.apache.tez.dag.api.Vertex
-
Get the vertex name
- getNodeId() - Method in class org.apache.tez.serviceplugins.api.ContainerLauncherOperationBase
-
Get the node on which this container is to be launched
- getNumClusterNodes() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the number of nodes in the cluster
- getNumClusterNodes() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the number of nodes in the cluster
- getNumDestinationConsumerTasks(int) - Method in class org.apache.tez.dag.api.EdgeManagerPlugin
-
Get the number of destination tasks that consume data from the source task
- getNumDestinationConsumerTasks(int) - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
-
Get the number of destination tasks that consume data from the source task
- getNumDestinationTaskPhysicalInputs(int) - Method in class org.apache.tez.dag.api.EdgeManagerPlugin
-
Get the number of physical inputs on the destination task
- getNumDestinationTaskPhysicalInputs(int) - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
-
Get the number of physical inputs on the destination task
- getNumFailures() - Method in class org.apache.tez.runtime.api.events.InputReadErrorEvent
-
- getNumNodes(String) - Method in interface org.apache.tez.serviceplugins.api.ContainerLauncherContext
-
Get the number of nodes being handled by the specified source
- getNumPhysicalInputs() - Method in class org.apache.tez.runtime.api.AbstractLogicalInput
-
Get the number of physical inputs that this LogicalInput will receive.
- getNumPhysicalOutputs() - Method in class org.apache.tez.runtime.api.AbstractLogicalOutput
-
Get the number of physical outputs that this LogicalOutput is expected to generate.
- getNumSourceTaskPhysicalOutputs(int) - Method in class org.apache.tez.dag.api.EdgeManagerPlugin
-
Get the number of physical outputs on the source task
- getNumSourceTaskPhysicalOutputs(int) - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
-
Get the number of physical outputs on the source task
- getNumTasks() - Method in class org.apache.tez.runtime.api.events.InputConfigureVertexTasksEvent
-
- getNumTasks() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the number of tasks in this vertex.
- getObjectRegistry() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Returns a shared
ObjectRegistry
to hold user objects in memory
between tasks.
- getOutputCommitterDescriptor() - Method in class org.apache.tez.dag.api.DataSinkDescriptor
-
- getOutputDescriptor() - Method in class org.apache.tez.dag.api.DataSinkDescriptor
-
- getOutputIndex() - Method in interface org.apache.tez.runtime.api.OutputContext
-
Get the index of the output in the set of all outputs for the task.
- getOutputName() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
Get the name of the Output
- getOutputStatistics(String) - Method in interface org.apache.tez.runtime.api.VertexStatistics
-
Get statistics about an
Edge
output or external output of this
Vertex
.
- getOutputUserPayload() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
Get the User Payload for the Output
- getOutputVertex() - Method in class org.apache.tez.dag.api.Edge
-
The @link
Vertex
that reads output from the edge
- getOutputVertex() - Method in class org.apache.tez.dag.api.GroupInputEdge
-
- getOutputVertexEdgeProperties() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the edge properties on the output edges of this vertex.
- getOutputVertices() - Method in class org.apache.tez.dag.api.Vertex
-
Get the output vertices for this vertex
- getParallelism() - Method in class org.apache.tez.dag.api.Vertex
-
Get the specified number of tasks specified to run in this vertex.
- getPayload() - Method in class org.apache.tez.dag.api.UserPayload
-
Return the payload as a read-only ByteBuffer.
- getPrewarmWaitTimeMs() - Method in class org.apache.tez.client.TezClient
-
- getProcessorDescriptor() - Method in class org.apache.tez.dag.api.Vertex
-
Get the vertex task processor descriptor
- getProducerAttemptIdentifier() - Method in class org.apache.tez.runtime.api.events.VertexManagerEvent
-
Get metadata about the task attempt that produced the event.
- getProgress() - Method in class org.apache.tez.dag.api.client.VertexStatus
-
- getProgress() - Method in class org.apache.tez.runtime.api.AbstractLogicalInput
-
- getProgress() - Method in class org.apache.tez.runtime.api.MergedLogicalInput
-
- getProgress() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Request the framework for progress of the running DAG.
- getRacks() - Method in class org.apache.tez.dag.api.TaskLocationHint
-
- getRawPayload() - Method in class org.apache.tez.dag.api.UserPayload
-
Return the payload as a ByteBuffer.
- getReader() - Method in interface org.apache.tez.runtime.api.Input
-
Gets an instance of the
Reader
for this
Output
- getRejectedTaskAttemptCount() - Method in class org.apache.tez.dag.api.client.Progress
-
- getRunningTaskCount() - Method in class org.apache.tez.dag.api.client.Progress
-
- getSchedulerName() - Method in class org.apache.tez.serviceplugins.api.ContainerLaunchRequest
-
Get the name of the scheduler which allocated this container.
- getSchedulingType() - Method in class org.apache.tez.dag.api.EdgeProperty
-
Get the EdgeProperty.SchedulingType
- getSerializedPath() - Method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- getServiceConsumerMetaData(String) - Method in interface org.apache.tez.runtime.api.TaskContext
-
Returns meta-data for the specified service.
- getServiceProviderMetaData(String) - Method in interface org.apache.tez.runtime.api.TaskContext
-
Return Provider meta-data for the specified service As an example, when the
MR ShuffleHandler is used - this would return the shuffle port serialized
as bytes
- getSessionIdentifierString() - Method in class org.apache.tez.dag.api.client.DAGClient
-
Get the session identifier for the session in which this dag is running
- getSourceIndex() - Method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
-
- getSourceIndex() - Method in class org.apache.tez.runtime.api.events.DataMovementEvent
-
- getSourceIndex() - Method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- getSourceIndexStart() - Method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- getSourceVertexName() - Method in interface org.apache.tez.dag.api.EdgeManagerPluginContext
-
Returns the source vertex name
- getSourceVertexName() - Method in class org.apache.tez.runtime.api.events.InputInitializerEvent
-
Returns the name of the vertex which generated the event.
- getSourceVertexName() - Method in interface org.apache.tez.runtime.api.InputContext
-
Get the Vertex Name of the Source that generated data for this Input
- getSourceVertexNumTasks() - Method in interface org.apache.tez.dag.api.EdgeManagerPluginContext
-
Returns the number of tasks in the source vertex
- getState() - Method in class org.apache.tez.dag.api.client.DAGStatus
-
- getState() - Method in class org.apache.tez.dag.api.client.VertexStatus
-
- getStatisticsReporter() - Method in interface org.apache.tez.runtime.api.InputContext
-
- getStatisticsReporter() - Method in interface org.apache.tez.runtime.api.OutputContext
-
- getSucceededTaskCount() - Method in class org.apache.tez.dag.api.client.Progress
-
- getTargetIndex() - Method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
-
- getTargetIndex() - Method in class org.apache.tez.runtime.api.events.DataMovementEvent
-
- getTargetIndex() - Method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- getTargetInputName() - Method in class org.apache.tez.runtime.api.events.InputInitializerEvent
-
Get the input name to which this event is targeted
- getTargetVertexName() - Method in class org.apache.tez.runtime.api.events.InputInitializerEvent
-
Get the vertex name on which the targeted Input exists
- getTargetVertexName() - Method in class org.apache.tez.runtime.api.events.VertexManagerEvent
-
- getTaskAttemptNumber() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the current Task Attempt Number
- getTaskCommName() - Method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
-
- getTaskCommunicatorMetaInfo(String) - Method in interface org.apache.tez.serviceplugins.api.ContainerLauncherContext
-
Get meta info from the specified TaskCommunicator.
- getTaskCommunicatorName() - Method in class org.apache.tez.serviceplugins.api.ContainerLaunchRequest
-
Get the name of the task communicator which will be used to communicate
with the task that will run in this container.
- getTaskEnvironment() - Method in class org.apache.tez.dag.api.Vertex
-
Get the environment variables of the tasks
- getTaskIndex() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the index of this Task among the tasks of this vertex
- getTaskLaunchCmdOpts() - Method in class org.apache.tez.dag.api.Vertex
-
Get the launch command opts for tasks in this vertex
- getTaskLocalFiles() - Method in class org.apache.tez.dag.api.Vertex
-
Get the files etc that must be provided by the tasks of this vertex
- getTaskLocationHints() - Method in class org.apache.tez.dag.api.VertexLocationHint
-
- getTaskResource() - Method in class org.apache.tez.dag.api.Vertex
-
Get the resources for the vertex
- getTaskSchedulerName() - Method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
-
- getTaskVertexIndex() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the index of this task's vertex in the set of vertices in the DAG.
- getTaskVertexName() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the name of the Vertex in which the task is running
- getTotalAvailableResource() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the total resource allocated to this vertex.
- getTotalAvailableResource() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the total resource allocated to this vertex.
- getTotalMemoryAvailableToTask() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Gets the total memory available to all components of the running task.
- getTotalResources() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
-
Get the total available resources from this source
- getTotalTaskCount() - Method in class org.apache.tez.dag.api.client.Progress
-
- getUniqueIdentifier() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Returns an identifier which is unique to the specific Input, Processor or
Output
- getURIsForCredentials() - Method in class org.apache.tez.dag.api.DataSinkDescriptor
-
Get the URIs for which credentials will be obtained
- getURIsForCredentials() - Method in class org.apache.tez.dag.api.DataSourceDescriptor
-
Get the URIs for which credentials will be obtained
- getUserPayload() - Method in interface org.apache.tez.dag.api.EdgeManagerPluginContext
-
Returns the payload specified by the user for the edge.
- getUserPayload() - Method in class org.apache.tez.dag.api.EntityDescriptor
-
- getUserPayload() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the payload set for the plugin
- getUserPayload() - Method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- getUserPayload() - Method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
-
- getUserPayload() - Method in class org.apache.tez.runtime.api.events.DataMovementEvent
-
- getUserPayload() - Method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- getUserPayload() - Method in class org.apache.tez.runtime.api.events.InputInitializerEvent
-
Get the actual user payload
- getUserPayload() - Method in class org.apache.tez.runtime.api.events.InputUpdatePayloadEvent
-
- getUserPayload() - Method in class org.apache.tez.runtime.api.events.VertexManagerEvent
-
- getUserPayload() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the user payload for the initializer
- getUserPayload() - Method in interface org.apache.tez.runtime.api.MergedInputContext
-
Get the user payload for this input
- getUserPayload() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
Get the User Payload for the OutputCommitter
- getUserPayload() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the User Payload for the Input/Output/Processor
- getValue() - Method in interface org.apache.tez.common.counters.TezCounter
-
What is the current value of this counter?
- getVersion() - Method in class org.apache.tez.dag.api.UserPayload
-
- getVersion() - Method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- getVersion() - Method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
-
- getVersion() - Method in class org.apache.tez.runtime.api.events.DataMovementEvent
-
- getVersion() - Method in class org.apache.tez.runtime.api.events.InputReadErrorEvent
-
- getVertex(String) - Method in class org.apache.tez.dag.api.DAG
-
- getVertexConfiguration() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get vertex configuration
- getVertexCounters() - Method in class org.apache.tez.dag.api.client.VertexStatus
-
- getVertexGroupName() - Method in interface org.apache.tez.dag.api.EdgeManagerPluginContext
-
- getVertexId() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the vertex id as integer that belongs to this input.
- getVertexIndex() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
Get Vertex Index in the DAG
- getVertexIndexForTask(Object) - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
- getVertexInputNames() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the names of the non-vertex inputs of this vertex.
- getVertexName() - Method in class org.apache.tez.dag.api.event.VertexStateUpdate
-
Get the name of the vertex for which the state has changed
- getVertexName() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the name of the vertex
- getVertexName() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
Get the name of the Vertex
- getVertexNumTasks(String) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the number of tasks in the given vertex
- getVertexNumTasks(String) - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the number of tasks in the given vertex
- getVertexParallelism() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the vertex parallelism of the vertex to which this task belongs.
- getVertexProgress() - Method in class org.apache.tez.dag.api.client.DAGStatus
-
Get the progress of a vertex in the DAG
- getVertexState() - Method in class org.apache.tez.dag.api.event.VertexStateUpdate
-
Get the updated state
- getVertexStatistics(String) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
- getVertexStatus(String, Set<StatusGetOpts>) - Method in class org.apache.tez.dag.api.client.DAGClient
-
Get the status of a Vertex of a DAG
- getVertexTaskResource() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the resource allocated to a task of this vertex
- getVertexTaskResource() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the resource allocated to a task of this vertex
- getWebUIAddress() - Method in class org.apache.tez.dag.api.client.DAGClient
-
Returns the Tez AM's web ui address if any.
- getWorkDirs() - Method in interface org.apache.tez.runtime.api.MergedInputContext
-
Get the work directories for the Input
- getWorkDirs() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the work directories for the Input/Output/Processor
- getWriter() - Method in interface org.apache.tez.runtime.api.Output
-
Gets an instance of the
Writer
in an
Output
- GroupInputEdge - Class in org.apache.tez.dag.api
-
A composite edge that represents a common connection between a
group of input vertices and a single output vertex.
- scheduleTasks(List<VertexManagerPluginContext.ScheduleTaskRequest>) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Notify the vertex to schedule the given tasks
- scheduleVertexTasks(List<VertexManagerPluginContext.TaskWithLocationHint>) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Deprecated.
- sendAMHeartbeat(DAGClientAMProtocolBlockingPB) - Method in class org.apache.tez.client.TezClient
-
- sendEvents(List<Event>) - Method in interface org.apache.tez.runtime.api.TaskContext
-
Send Events to the AM and/or dependent Vertices
- sendEventToProcessor(Collection<CustomProcessorEvent>, int) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Allows a VertexManagerPlugin to send events of custom payload to processor
of a specific task of managed vertex
It's up to user to make sure taskId is valid
- ServicePluginError - Interface in org.apache.tez.serviceplugins.api
-
- ServicePluginErrorDefaults - Enum in org.apache.tez.serviceplugins.api
-
A default set of errors from ServicePlugins
Errors are marked as fatal or non-fatal for the Application.
- ServicePluginsDescriptor - Class in org.apache.tez.serviceplugins.api
-
An
ServicePluginsDescriptor
describes the list of plugins running within the AM for
sourcing resources, launching and executing work.
- SessionNotRunning - Exception in org.apache.tez.dag.api
-
Exception thrown when the client cannot communicate with the Tez Session
as the Tez Session is no longer running.
- SessionNotRunning(String, Throwable) - Constructor for exception org.apache.tez.dag.api.SessionNotRunning
-
- SessionNotRunning(String) - Constructor for exception org.apache.tez.dag.api.SessionNotRunning
-
- SessionNotRunning(Throwable) - Constructor for exception org.apache.tez.dag.api.SessionNotRunning
-
- setAccessControls(DAGAccessControls) - Method in class org.apache.tez.dag.api.DAG
-
Set Access controls for the DAG.
- setApplicationRegistrationData(Resource, Map<ApplicationAccessType, String>, ByteBuffer, String) - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Provide an update to the framework about specific information about the source managed by this
scheduler.
- setAppMasterCredentials(Credentials) - Method in class org.apache.tez.client.TezClient
-
Set security credentials to be used inside the app master, if needed.
- setBlob(String) - Method in class org.apache.tez.client.CallerContext
-
- setCallerContext(CallerContext) - Method in class org.apache.tez.dag.api.DAG
-
Set the Context in which Tez is being called.
- setCallerIdAndType(String, String) - Method in class org.apache.tez.client.CallerContext
-
- setConf(String, String) - Method in class org.apache.tez.dag.api.DAG
-
This is currently used to setup additional configuration parameters which will be available
in the DAG configuration used in the AppMaster.
- setConf(String, String) - Method in class org.apache.tez.dag.api.Vertex
-
This is currently used to setup additional configuration parameters which will be available
in the Vertex specific configuration used in the AppMaster.
- setConstituentInputIsReady(Input) - Method in class org.apache.tez.runtime.api.MergedLogicalInput
-
Used by the framework to inform the MergedInput that one of it's constituent Inputs is ready.
- setContext(String) - Method in class org.apache.tez.client.CallerContext
-
- setCredentials(Credentials) - Method in class org.apache.tez.client.TezClient.TezClientBuilder
-
Setup security credentials
- setCredentials(Credentials) - Method in class org.apache.tez.dag.api.DAG
-
One of the methods that can be used to provide information about required
Credentials when running on a secure cluster.
- setDAGInfo(String) - Method in class org.apache.tez.dag.api.DAG
-
Deprecated.
- setDisplayName(String) - Method in interface org.apache.tez.common.counters.CounterGroupBase
-
Set the display name of the group
- setDisplayName(String) - Method in interface org.apache.tez.common.counters.TezCounter
-
- setExecutionContext(Vertex.VertexExecutionContext) - Method in class org.apache.tez.dag.api.DAG
-
Sets the default execution context for the DAG.
- setExecutionContext(Vertex.VertexExecutionContext) - Method in class org.apache.tez.dag.api.Vertex
-
Sets the execution context for this Vertex - i.e.
- setGroupsWithModifyACLs(Collection<String>) - Method in class org.apache.tez.common.security.DAGAccessControls
-
Sets the list of groups with modify permissions on the DAG.
- setGroupsWithViewACLs(Collection<String>) - Method in class org.apache.tez.common.security.DAGAccessControls
-
Sets the list of groups with view permissions on the DAG.
- setHistoryLogLevel(HistoryLogLevel) - Method in class org.apache.tez.client.TezClient
-
Sets the history log level for this session.
- setHistoryLogLevel(HistoryLogLevel) - Method in class org.apache.tez.dag.api.DAG
-
Set history log level for this DAG.
- setHistoryText(String) - Method in class org.apache.tez.dag.api.EntityDescriptor
-
Provide a human-readable version of the user payload that can be
used in the TEZ UI
- setIsSession(boolean) - Method in class org.apache.tez.client.TezClient.TezClientBuilder
-
Specify whether this client is a session or not
- setLocalResources(Map<String, LocalResource>) - Method in class org.apache.tez.client.TezClient.TezClientBuilder
-
Set local resources to be used by the AppMaster
- setLocationHint(VertexLocationHint) - Method in class org.apache.tez.dag.api.Vertex
-
Specify location hints for the tasks of this vertex.
- setProgress(float) - Method in interface org.apache.tez.runtime.api.ProcessorContext
-
Set the overall progress of this Task Attempt.
- setProgressInternally(float) - Method in interface org.apache.tez.runtime.api.ProcessorContext
-
The actual implementation of the taskAttempt progress.
- setServicePluginDescriptor(ServicePluginsDescriptor) - Method in class org.apache.tez.client.TezClient.TezClientBuilder
-
Specify the service plugins that will be running in the AM
- setShouldUnregister() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
-
Inform the scheduler that it should unregister.
- setTargetIndex(int) - Method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- setTaskEnvironment(Map<String, String>) - Method in class org.apache.tez.dag.api.Vertex
-
Set the Key-Value pairs of environment variables for tasks of this vertex.
- setTaskLaunchCmdOpts(String) - Method in class org.apache.tez.dag.api.Vertex
-
Set the command opts for tasks of this vertex.
- setupOutput() - Method in class org.apache.tez.runtime.api.OutputCommitter
-
For the framework to setup the output during initialization.
- setUserPayload(UserPayload) - Method in class org.apache.tez.dag.api.EntityDescriptor
-
Set user payload for this entity descriptor
- setUsersWithModifyACLs(Collection<String>) - Method in class org.apache.tez.common.security.DAGAccessControls
-
Sets the list of users with modify permissions on the DAG.
- setUsersWithViewACLs(Collection<String>) - Method in class org.apache.tez.common.security.DAGAccessControls
-
Sets the list of users with view permissions on the DAG.
- setValue(long) - Method in interface org.apache.tez.common.counters.TezCounter
-
Set this counter by the given value
- setVersion(int) - Method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- setVertexLocationHint(VertexLocationHint) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Set the placement hint for tasks in this vertex
- setVertexManagerPlugin(VertexManagerPluginDescriptor) - Method in class org.apache.tez.dag.api.Vertex
-
- setVertexParallelism(int, VertexLocationHint, Map<String, EdgeManagerPluginDescriptor>, Map<String, InputSpecUpdate>) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Deprecated.
- shouldExecuteInAm() - Method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
-
- shouldExecuteInContainers() - Method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
-
- shouldLog(HistoryLogLevel) - Method in enum org.apache.tez.dag.api.HistoryLogLevel
-
- shutdown() - Method in class org.apache.tez.serviceplugins.api.ContainerLauncher
-
Stop the service.
- shutdown() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
-
Stop the service.
- size() - Method in interface org.apache.tez.common.counters.CounterGroupBase
-
- sourceIndexStart - Variable in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- start() - Method in class org.apache.tez.client.TezClient
-
Start the client.
- start() - Method in interface org.apache.tez.runtime.api.Input
-
Start any processing that the Input may need to perform.
- start() - Method in class org.apache.tez.runtime.api.MergedLogicalInput
-
- start() - Method in interface org.apache.tez.runtime.api.Output
-
Start any processing that the Output may need to perform.
- start() - Method in class org.apache.tez.serviceplugins.api.ContainerLauncher
-
An entry point for starting the service.
- start() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
-
An entry point for starting the service.
- StatusGetOpts - Enum in org.apache.tez.dag.api.client
-
Status Get Options used when making calls like getDAGStatus and
getVertexStatus in DAGClient
- stop() - Method in class org.apache.tez.client.TezClient
-
Stop the client.
- stopContainer(ContainerStopRequest) - Method in class org.apache.tez.serviceplugins.api.ContainerLauncher
-
A request to stop a specific container
- submitDAG(DAG) - Method in class org.apache.tez.client.TezClient
-
Submit a DAG.
- TASK_HEARTBEAT_TIMEOUT_CHECK_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TASK_HEARTBEAT_TIMEOUT_CHECK_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TASK_HEARTBEAT_TIMEOUT_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TASK_HEARTBEAT_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- taskAllocated(Object, Object, Container) - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
-
Indicate to the framework that a container is being assigned to a task.
- TaskAttemptEndReason - Enum in org.apache.tez.serviceplugins.api
-
- TaskCommunicatorDescriptor - Class in org.apache.tez.serviceplugins.api
-
- TaskContext - Interface in org.apache.tez.runtime.api
-
Base interface for Context classes used to initialize the Input, Output
and Processor instances.
- TaskLocationHint - Class in org.apache.tez.dag.api
-
Describes the placements hints for tasks.
- TaskScheduler - Class in org.apache.tez.serviceplugins.api
-
This class represents the API for a custom TaskScheduler which can be run within the Tez AM.
- TaskScheduler(TaskSchedulerContext) - Constructor for class org.apache.tez.serviceplugins.api.TaskScheduler
-
- TaskSchedulerContext - Interface in org.apache.tez.serviceplugins.api
-
Context for a
TaskScheduler
This provides methods for a scheduler to interact with the Tez framework.
- TaskSchedulerDescriptor - Class in org.apache.tez.serviceplugins.api
-
- taskStateUpdated(Object, TaskScheduler.SchedulerTaskState) - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
-
Information about the state of a previously allocated task.
- TEZ_AM_ACLS_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_ACLS_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_ALLOW_DISABLED_TIMELINE_DOMAINS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_ALLOW_DISABLED_TIMELINE_DOMAINS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_APPLICATION_PRIORITY - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_ATS_V15_OVERRIDE_SUMMARY_TYPES - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_ATS_V15_OVERRIDE_SUMMARY_TYPES_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CLIENT_AM_PORT_RANGE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_CLIENT_HEARTBEAT_POLL_INTERVAL_MILLIS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CLIENT_HEARTBEAT_POLL_INTERVAL_MILLIS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CLIENT_HEARTBEAT_TIMEOUT_SECS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_CLIENT_HEARTBEAT_TIMEOUT_SECS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CLIENT_THREAD_COUNT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_CLIENT_THREAD_COUNT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_COMMIT_ALL_OUTPUTS_ON_DAG_SUCCESS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_COMMIT_ALL_OUTPUTS_ON_DAG_SUCCESS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CONCURRENT_DISPATCHER_CONCURRENCY - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CONCURRENT_DISPATCHER_CONCURRENCY_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CONTAINER_IDLE_RELEASE_TIMEOUT_MAX_MILLIS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_CONTAINER_IDLE_RELEASE_TIMEOUT_MAX_MILLIS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CONTAINER_IDLE_RELEASE_TIMEOUT_MIN_MILLIS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_CONTAINER_IDLE_RELEASE_TIMEOUT_MIN_MILLIS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CONTAINER_REUSE_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_CONTAINER_REUSE_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CONTAINER_REUSE_LOCALITY_DELAY_ALLOCATION_MILLIS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_CONTAINER_REUSE_LOCALITY_DELAY_ALLOCATION_MILLIS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CONTAINER_REUSE_NEW_CONTAINERS_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_CONTAINER_REUSE_NEW_CONTAINERS_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CONTAINER_REUSE_NON_LOCAL_FALLBACK_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_CONTAINER_REUSE_NON_LOCAL_FALLBACK_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CONTAINER_REUSE_RACK_FALLBACK_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_CONTAINER_REUSE_RACK_FALLBACK_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CONTAINERLAUNCHER_THREAD_COUNT_LIMIT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_CONTAINERLAUNCHER_THREAD_COUNT_LIMIT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_CREDENTIALS_MERGE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_CREDENTIALS_MERGE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_DAG_APPCONTEXT_THREAD_COUNT_LIMIT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_DAG_APPCONTEXT_THREAD_COUNT_LIMIT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_DAG_CLEANUP_ON_COMPLETION - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_DAG_CLEANUP_ON_COMPLETION_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_DAG_CLEANUP_THREAD_COUNT_LIMIT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_DAG_CLEANUP_THREAD_COUNT_LIMIT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_DAG_SCHEDULER_CLASS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_DAG_SCHEDULER_CLASS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_DELETION_TRACKER_CLASS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value that is a class name.
- TEZ_AM_DELETION_TRACKER_CLASS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_DISABLE_CLIENT_VERSION_CHECK - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_DISABLE_CLIENT_VERSION_CHECK_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_DISPATCHER_DRAIN_EVENTS_TIMEOUT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Integer value.
- TEZ_AM_DISPATCHER_DRAIN_EVENTS_TIMEOUT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_ESTIMATOR_EXPONENTIAL_LAMBDA_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value.
- TEZ_AM_ESTIMATOR_EXPONENTIAL_LAMBDA_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_ESTIMATOR_EXPONENTIAL_SKIP_INITIALS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
The number of initial readings that the estimator ignores before giving a
prediction.
- TEZ_AM_ESTIMATOR_EXPONENTIAL_SKIP_INITIALS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_ESTIMATOR_EXPONENTIAL_STAGNATED_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
The window length in the simple exponential smoothing that considers the
task attempt is stagnated.
- TEZ_AM_ESTIMATOR_EXPONENTIAL_STAGNATED_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_FAILURE_ON_MISSING_RECOVERY_DATA - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_FAILURE_ON_MISSING_RECOVERY_DATA_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_HISTORY_LOGGING_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_HISTORY_LOGGING_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_INLINE_TASK_EXECUTION_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Tez AM Inline Mode flag.
- TEZ_AM_INLINE_TASK_EXECUTION_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Tez AM Inline Mode flag.
- TEZ_AM_INLINE_TASK_EXECUTION_MAX_TASKS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_INLINE_TASK_EXECUTION_MAX_TASKS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_LAUNCH_CLUSTER_DEFAULT_CMD_OPTS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_LAUNCH_CLUSTER_DEFAULT_CMD_OPTS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_LAUNCH_CLUSTER_DEFAULT_ENV - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_LAUNCH_CLUSTER_DEFAULT_ENV_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_LAUNCH_CMD_OPTS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_LAUNCH_CMD_OPTS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_LAUNCH_CMD_OPTS_JDK8_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_LAUNCH_CMD_OPTS_JDK9_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_LAUNCH_ENV - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_LAUNCH_ENV_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_LEGACY_SPECULATIVE_SINGLE_TASK_VERTEX_TIMEOUT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value.
- TEZ_AM_LEGACY_SPECULATIVE_SINGLE_TASK_VERTEX_TIMEOUT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_LEGACY_SPECULATIVE_SLOWTASK_THRESHOLD - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Float value.
- TEZ_AM_LOG_LEVEL - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Root Logging level passed to the Tez app master.
- TEZ_AM_LOG_LEVEL_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_MAX_ALLOWED_DOWNSTREAM_HOST_FAILURES_FRACTION - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Double value.
- TEZ_AM_MAX_ALLOWED_DOWNSTREAM_HOST_FAILURES_FRACTION_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_MAX_ALLOWED_TIME_FOR_TASK_READ_ERROR_SEC - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
int value.
- TEZ_AM_MAX_ALLOWED_TIME_FOR_TASK_READ_ERROR_SEC_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_MAX_APP_ATTEMPTS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_MAX_APP_ATTEMPTS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_MAX_TASK_FAILURES_PER_NODE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_MAX_TASK_FAILURES_PER_NODE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_MINIMUM_ALLOWED_SPECULATIVE_TASKS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Integer value.
- TEZ_AM_MINIMUM_ALLOWED_SPECULATIVE_TASKS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_MODIFY_ACLS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_NODE_BLACKLISTING_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_NODE_BLACKLISTING_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_NODE_BLACKLISTING_IGNORE_THRESHOLD - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_NODE_BLACKLISTING_IGNORE_THRESHOLD_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_NODE_UNHEALTHY_RESCHEDULE_TASKS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_NODE_UNHEALTHY_RESCHEDULE_TASKS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_ONE_TO_ONE_ROUTING_USE_ON_DEMAND_ROUTING - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_ONE_TO_ONE_ROUTING_USE_ON_DEMAND_ROUTING_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_PREEMPTION_HEARTBEATS_BETWEEN_PREEMPTIONS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_PREEMPTION_HEARTBEATS_BETWEEN_PREEMPTIONS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_PREEMPTION_MAX_WAIT_TIME_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_PREEMPTION_MAX_WAIT_TIME_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_PREEMPTION_PERCENTAGE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_PREEMPTION_PERCENTAGE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_PREFIX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_PROPORTION_RUNNING_TASKS_SPECULATABLE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Double value.
- TEZ_AM_PROPORTION_RUNNING_TASKS_SPECULATABLE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_PROPORTION_TOTAL_TASKS_SPECULATABLE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Double value.
- TEZ_AM_PROPORTION_TOTAL_TASKS_SPECULATABLE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_READY_FOR_SUBMIT_TIMEOUT_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_READY_FOR_SUBMIT_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_RECOVERY_SERVICE_CLASS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_RECOVERY_SERVICE_CLASS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_RESOURCE_CPU_VCORES - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_RESOURCE_CPU_VCORES_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_RESOURCE_MEMORY_MB - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_RESOURCE_MEMORY_MB_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_RM_HEARTBEAT_INTERVAL_MS_MAX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_RM_HEARTBEAT_INTERVAL_MS_MAX_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_SESSION_MIN_HELD_CONTAINERS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_SESSION_MIN_HELD_CONTAINERS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_SESSION_MODE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_SESSION_MODE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_SHUFFLE_AUXILIARY_SERVICE_ID - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_SHUFFLE_AUXILIARY_SERVICE_ID_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_SLEEP_TIME_BEFORE_EXIT_MILLIS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Integer value in milliseconds.
- TEZ_AM_SOONEST_RETRY_AFTER_NO_SPECULATE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value.
- TEZ_AM_SOONEST_RETRY_AFTER_NO_SPECULATE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_SOONEST_RETRY_AFTER_SPECULATE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value.
- TEZ_AM_SOONEST_RETRY_AFTER_SPECULATE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_SPECULATION_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_SPECULATION_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_SPECULATOR_CLASS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
The class that should be used for speculative execution calculations.
- TEZ_AM_STAGING_DIR - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_STAGING_DIR_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_STAGING_SCRATCH_DATA_AUTO_DELETE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_STAGING_SCRATCH_DATA_AUTO_DELETE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_TASK_AM_PORT_RANGE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_TASK_ATTEMPT_CLEANUP_ON_FAILURE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_TASK_ATTEMPT_CLEANUP_ON_FAILURE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_TASK_ESTIMATOR_CLASS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
The class that should be used for task runtime estimation.
- TEZ_AM_TASK_LISTENER_THREAD_COUNT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_TASK_LISTENER_THREAD_COUNT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_TASK_MAX_ATTEMPTS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_TASK_MAX_ATTEMPTS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_TASK_MAX_FAILED_ATTEMPTS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_TASK_MAX_FAILED_ATTEMPTS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_TASK_RESCHEDULE_HIGHER_PRIORITY - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_TASK_RESCHEDULE_HIGHER_PRIORITY_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_TASK_RESCHEDULE_RELAXED_LOCALITY - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_TASK_RESCHEDULE_RELAXED_LOCALITY_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_TEZ_UI_HISTORY_URL_TEMPLATE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value
Tez UI URL template for the application.
- TEZ_AM_TEZ_UI_HISTORY_URL_TEMPLATE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_UI_HISTORY_URL_SCHEME_CHECK_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_AM_UI_HISTORY_URL_SCHEME_CHECK_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_USE_CONCURRENT_DISPATCHER - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_USE_CONCURRENT_DISPATCHER_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_VERTEX_CLEANUP_HEIGHT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Integer value.
- TEZ_AM_VERTEX_CLEANUP_HEIGHT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_VERTEX_MAX_TASK_CONCURRENCY - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_AM_VERTEX_MAX_TASK_CONCURRENCY_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_VIEW_ACLS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_WEBSERVICE_ENABLE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value
Allow disabling of the Tez AM webservice.
- TEZ_AM_WEBSERVICE_ENABLE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_WEBSERVICE_PORT_RANGE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_WEBSERVICE_PORT_RANGE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_AM_YARN_SCHEDULER_CLASS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AM_YARN_SCHEDULER_CLASS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_APPLICATION_TAGS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_AUX_URIS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Auxiliary resources to be localized for the Tez AM and all its containers.
- TEZ_CANCEL_DELEGATION_TOKENS_ON_COMPLETION - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_CANCEL_DELEGATION_TOKENS_ON_COMPLETION_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_CLASSPATH_ADD_HADOOP_CONF - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_CLASSPATH_ADD_HADOOP_CONF_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_CLIENT_ASYNCHRONOUS_STOP - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_CLIENT_ASYNCHRONOUS_STOP_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_CLIENT_DAG_STATUS_CACHE_TIMEOUT_SECS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value
Status Cache timeout window in minutes for the DAGClient.
- TEZ_CLIENT_DAG_STATUS_CACHE_TIMEOUT_SECS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_CLIENT_DIAGNOSTICS_WAIT_TIMEOUT_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value
Time to wait (in milliseconds) for yarn app's diagnotics is available
Workaround for YARN-2560
- TEZ_CLIENT_DIAGNOSTICS_WAIT_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_CLIENT_HARD_KILL_TIMEOUT_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value.
- TEZ_CLIENT_HARD_KILL_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_CLIENT_JAVA_OPTS_CHECKER_CLASS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_CLIENT_JAVA_OPTS_CHECKER_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_CLIENT_JAVA_OPTS_CHECKER_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_CLUSTER_ADDITIONAL_CLASSPATH_PREFIX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_CONCURRENT_EDGE_TRIGGER_TYPE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_CONCURRENT_EDGE_TRIGGER_TYPE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_CONTAINER_MAX_JAVA_HEAP_FRACTION - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Double value.
- TEZ_CONTAINER_MAX_JAVA_HEAP_FRACTION_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_COUNTERS_COUNTER_NAME_MAX_LENGTH - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_COUNTERS_COUNTER_NAME_MAX_LENGTH_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_COUNTERS_GROUP_NAME_MAX_LENGTH - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_COUNTERS_GROUP_NAME_MAX_LENGTH_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_COUNTERS_MAX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_COUNTERS_MAX_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_COUNTERS_MAX_GROUPS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_COUNTERS_MAX_GROUPS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_CREDENTIALS_PATH - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value that is a file path.
- TEZ_DAG_HISTORY_LOGGING_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_DAG_HISTORY_LOGGING_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_DAG_STATUS_POLLINTERVAL_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value
Status Poll interval in Milliseconds used when getting DAG status with timeout.
- TEZ_DAG_STATUS_POLLINTERVAL_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_ESTIMATOR_PREFIX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_GENERATE_DEBUG_ARTIFACTS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_GENERATE_DEBUG_ARTIFACTS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_HISTORY_LOGGING_LOGLEVEL - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Enum value.
- TEZ_HISTORY_LOGGING_PROTO_BASE_DIR - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_HISTORY_LOGGING_PROTO_DOAS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value.
- TEZ_HISTORY_LOGGING_PROTO_DOAS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_HISTORY_LOGGING_PROTO_QUEUE_SIZE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_HISTORY_LOGGING_PROTO_QUEUE_SIZE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_HISTORY_LOGGING_PROTO_SPLIT_DAG_START - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_HISTORY_LOGGING_PROTO_SPLIT_DAG_START_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_HISTORY_LOGGING_PROTO_SYNC_WINDOWN_SECS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value.
- TEZ_HISTORY_LOGGING_PROTO_SYNC_WINDOWN_SECS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_HISTORY_LOGGING_SERVICE_CLASS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value that is a class name.
- TEZ_HISTORY_LOGGING_SERVICE_CLASS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_HISTORY_LOGGING_TASKATTEMPT_FILTERS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
List of comma separated enum values.
- TEZ_HISTORY_LOGGING_TIMELINE_CACHE_PLUGIN_OLD_NUM_DAGS_PER_GROUP - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Comma separated list of Integers.
- TEZ_HISTORY_LOGGING_TIMELINE_NUM_DAGS_PER_GROUP - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Integer value.
- TEZ_HISTORY_LOGGING_TIMELINE_NUM_DAGS_PER_GROUP_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_HISTORY_URL_BASE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value
Tez-UI Url base.
- TEZ_IGNORE_LIB_URIS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_IPC_PAYLOAD_RESERVED_BYTES - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_IPC_PAYLOAD_RESERVED_BYTES_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_JOB_FS_SERVERS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Acquire all FileSystems info.
- TEZ_JOB_FS_SERVERS_TOKEN_RENEWAL_EXCLUDE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Skip delegation token renewal for specified FileSystems.
- TEZ_JVM_SYSTEM_PROPERTIES_TO_LOG - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_JVM_SYSTEM_PROPERTIES_TO_LOG_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_LIB_URIS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value to a file path.
- TEZ_LIB_URIS_CLASSPATH - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Specify additional user classpath information to be used for Tez AM and all containers.
- TEZ_LOCAL_CACHE_ROOT_FOLDER - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_LOCAL_CACHE_ROOT_FOLDER_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_LOCAL_MODE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_LOCAL_MODE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_LOCAL_MODE_WITHOUT_NETWORK - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_LOCAL_MODE_WITHOUT_NETWORK_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_LOG_PATTERN_LAYOUT_AM - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
By this option, user can easily override the logging pattern which is applied in
TezContainerLogAppender in AM, regardless of the environmental settings.
- TEZ_LOG_PATTERN_LAYOUT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Set pattern to empty string to turn the custom log pattern feature off.
- TEZ_LOG_PATTERN_LAYOUT_TASK - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
By this option, user can easily override the logging pattern which is applied in
TezContainerLogAppender in tasks, regardless of the environmental settings.
- TEZ_MDC_CUSTOM_KEYS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Comma separated list of keys, which can used for defining keys in MDC.
- TEZ_MDC_CUSTOM_KEYS_CONF_PROPS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Comma separated list of Configuration keys.
- TEZ_MRREADER_CONFIG_UPDATE_PROPERTIES - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Comma-separated list of properties that MRReaderMapred should return (if present) when calling for config updates.
- TEZ_PREFIX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_QUEUE_NAME - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_SESSION_AM_DAG_SUBMIT_TIMEOUT_SECS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_SESSION_AM_DAG_SUBMIT_TIMEOUT_SECS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_SESSION_CLIENT_TIMEOUT_SECS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_SESSION_CLIENT_TIMEOUT_SECS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_SESSION_PREFIX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Session-related properties
- TEZ_SHARED_EXECUTOR_MAX_THREADS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_SHARED_EXECUTOR_MAX_THREADS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_SHARED_EXECUTOR_MIN_THREADS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_SHARED_EXECUTOR_MIN_THREADS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_SIMPLE_HISTORY_LOGGING_DIR - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_SIMPLE_HISTORY_LOGGING_MAX_ERRORS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_SIMPLE_HISTORY_LOGGING_MAX_ERRORS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_SITE_XML - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_SPECULATOR_PREFIX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_AM_HEARTBEAT_COUNTER_INTERVAL_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_TASK_AM_HEARTBEAT_COUNTER_INTERVAL_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_AM_HEARTBEAT_INTERVAL_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_TASK_AM_HEARTBEAT_INTERVAL_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_GENERATE_COUNTERS_PER_IO - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Whether to generate counters per IO or not.
- TEZ_TASK_GENERATE_COUNTERS_PER_IO_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_GET_TASK_SLEEP_INTERVAL_MS_MAX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_TASK_GET_TASK_SLEEP_INTERVAL_MS_MAX_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_INITIALIZE_PROCESSOR_FIRST - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_TASK_INITIALIZE_PROCESSOR_FIRST_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_INITIALIZE_PROCESSOR_IO_SERIALLY - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_TASK_INITIALIZE_PROCESSOR_IO_SERIALLY_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_LAUNCH_CLUSTER_DEFAULT_CMD_OPTS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_TASK_LAUNCH_CLUSTER_DEFAULT_CMD_OPTS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_LAUNCH_CLUSTER_DEFAULT_ENV - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_TASK_LAUNCH_CLUSTER_DEFAULT_ENV_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_LAUNCH_CMD_OPTS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_TASK_LAUNCH_CMD_OPTS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_LAUNCH_CMD_OPTS_JDK8_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_LAUNCH_CMD_OPTS_JDK9_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_LAUNCH_ENV - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- TEZ_TASK_LAUNCH_ENV_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_LOCAL_FS_WRITE_LIMIT_BYTES - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Limits the amount of data that can be written to LocalFileSystem by a Task.
- TEZ_TASK_LOCAL_FS_WRITE_LIMIT_BYTES_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_LOG_LEVEL - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Root Logging level passed to the Tez tasks.
- TEZ_TASK_LOG_LEVEL_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_MAX_ALLOWED_OUTPUT_FAILURES - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_TASK_MAX_ALLOWED_OUTPUT_FAILURES_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_MAX_ALLOWED_OUTPUT_FAILURES_FRACTION - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
double value.
- TEZ_TASK_MAX_ALLOWED_OUTPUT_FAILURES_FRACTION_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_MAX_EVENT_BACKLOG - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_TASK_MAX_EVENT_BACKLOG_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_MAX_EVENTS_PER_HEARTBEAT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_TASK_MAX_EVENTS_PER_HEARTBEAT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_PREFIX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_PROGRESS_STUCK_INTERVAL_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value.
- TEZ_TASK_PROGRESS_STUCK_INTERVAL_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_RESOURCE_CALCULATOR_PROCESS_TREE_CLASS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_RESOURCE_CPU_VCORES - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_TASK_RESOURCE_CPU_VCORES_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_RESOURCE_MEMORY_MB - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TEZ_TASK_RESOURCE_MEMORY_MB_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_SCALE_MEMORY_ADDITIONAL_RESERVATION_FRACTION_MAX - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_SCALE_MEMORY_ADDITIONAL_RESERVATION_FRACTION_PER_IO - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Fraction of available memory to reserve per input/output.
- TEZ_TASK_SCALE_MEMORY_ALLOCATOR_CLASS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
The allocator to use for initial memory allocation
- TEZ_TASK_SCALE_MEMORY_ALLOCATOR_CLASS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_SCALE_MEMORY_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Whether to scale down memory requested by each component if the total
exceeds the available JVM memory
- TEZ_TASK_SCALE_MEMORY_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_SCALE_MEMORY_INPUT_OUTPUT_CONCURRENT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Concurrent input/output memory allocation control.
- TEZ_TASK_SCALE_MEMORY_INPUT_OUTPUT_CONCURRENT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_SCALE_MEMORY_NON_CONCURRENT_INPUTS_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Controls distributing output memory to inputs when non-concurrent I/O
memory allocation is being used.
- TEZ_TASK_SCALE_MEMORY_NON_CONCURRENT_INPUTS_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_SCALE_MEMORY_RESERVE_FRACTION - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
The fraction of the JVM memory which will not be considered for allocation.
- TEZ_TASK_SCALE_MEMORY_RESERVE_FRACTION_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_SCALE_MEMORY_WEIGHTED_RATIOS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_TASK_SPECIFIC_LAUNCH_CMD_OPTS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Additional launch command options to be added for specific tasks.
- TEZ_TASK_SPECIFIC_LAUNCH_CMD_OPTS_LIST - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Set of tasks for which specific launch command options need to be added.
- TEZ_TASK_SPECIFIC_LOG_LEVEL - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Task specific log level.
- TEZ_TEST_MINI_CLUSTER_APP_WAIT_ON_SHUTDOWN_SECS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Long value.
- TEZ_TEST_MINI_CLUSTER_APP_WAIT_ON_SHUTDOWN_SECS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_THREAD_DUMP_INTERVAL - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Frequency at which thread dump should be captured.
- TEZ_THREAD_DUMP_INTERVAL_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_USE_CLUSTER_HADOOP_LIBS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_USE_CLUSTER_HADOOP_LIBS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_USER_CLASSPATH_FIRST - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Boolean value.
- TEZ_USER_CLASSPATH_FIRST_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TEZ_VERTEX_FAILURES_MAXPERCENT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Float value.
- TEZ_VERTEX_FAILURES_MAXPERCENT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TezAppMasterStatus - Enum in org.apache.tez.client
-
Defines status for the App Master executing the DAG
- TezClient - Class in org.apache.tez.client
-
TezClient is used to submit Tez DAGs for execution.
- TezClient(String, TezConfiguration, boolean, Map<String, LocalResource>, Credentials) - Constructor for class org.apache.tez.client.TezClient
-
- TezClient(String, TezConfiguration, boolean, Map<String, LocalResource>, Credentials, ServicePluginsDescriptor) - Constructor for class org.apache.tez.client.TezClient
-
- TezClient.TezClientBuilder - Class in org.apache.tez.client
-
A builder for setting up an instance of
TezClient
- TezConfiguration - Class in org.apache.tez.dag.api
-
Defines the configurations for Tez.
- TezConfiguration() - Constructor for class org.apache.tez.dag.api.TezConfiguration
-
- TezConfiguration(Configuration) - Constructor for class org.apache.tez.dag.api.TezConfiguration
-
- TezConfiguration(boolean) - Constructor for class org.apache.tez.dag.api.TezConfiguration
-
- TezCounter - Interface in org.apache.tez.common.counters
-
A named counter that tracks the progress of a job.
- TezCounters - Class in org.apache.tez.common.counters
-
Counters
holds per job/task counters, defined either by the
framework or applications.
- TezCounters() - Constructor for class org.apache.tez.common.counters.TezCounters
-
Default constructor
- TezCounters(CounterGroupFactory<TezCounter, CounterGroup>) - Constructor for class org.apache.tez.common.counters.TezCounters
-
Construct the Counters object from the another counters object
- TezCounters(AbstractCounters<C, G>) - Constructor for class org.apache.tez.common.counters.TezCounters
-
Construct the Counters object from the another counters object
- TezException - Exception in org.apache.tez.dag.api
-
Checked Exception thrown upon error
- TezException(Throwable) - Constructor for exception org.apache.tez.dag.api.TezException
-
- TezException(String) - Constructor for exception org.apache.tez.dag.api.TezException
-
- TezException(String, Throwable) - Constructor for exception org.apache.tez.dag.api.TezException
-
- TezUncheckedException - Exception in org.apache.tez.dag.api
-
Unchecked Exception thrown upon error
- TezUncheckedException(Throwable) - Constructor for exception org.apache.tez.dag.api.TezUncheckedException
-
- TezUncheckedException(String) - Constructor for exception org.apache.tez.dag.api.TezUncheckedException
-
- TezUncheckedException(String, Throwable) - Constructor for exception org.apache.tez.dag.api.TezUncheckedException
-
- TezUtils - Class in org.apache.tez.common
-
Utility methods for setting up a DAG.
- toShortString() - Method in class org.apache.tez.common.counters.AbstractCounters
-
- toString() - Method in class org.apache.tez.client.CallerContext
-
- toString() - Method in class org.apache.tez.common.counters.AbstractCounters
-
Return textual representation of the counter values.
- toString() - Method in class org.apache.tez.dag.api.client.DAGStatus
-
- toString() - Method in class org.apache.tez.dag.api.client.Progress
-
- toString() - Method in class org.apache.tez.dag.api.client.VertexStatus
-
- toString() - Method in class org.apache.tez.dag.api.Edge
-
- toString() - Method in class org.apache.tez.dag.api.EdgeProperty
-
- toString() - Method in class org.apache.tez.dag.api.EntityDescriptor
-
- toString() - Method in class org.apache.tez.dag.api.event.VertexStateUpdate
-
- toString() - Method in class org.apache.tez.dag.api.GroupInputEdge
-
- toString() - Method in class org.apache.tez.dag.api.Vertex
-
- toString() - Method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
-
- toString() - Method in class org.apache.tez.dag.api.VertexGroup
-
- toString() - Method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
-
- toString() - Method in class org.apache.tez.runtime.api.events.DataMovementEvent
-
- toString() - Method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- toString() - Method in class org.apache.tez.runtime.api.events.InputInitializerEvent
-
- toString() - Method in class org.apache.tez.runtime.api.InputSpecUpdate
-
- toString() - Method in class org.apache.tez.serviceplugins.api.ContainerLauncherOperationBase
-
- toString() - Method in class org.apache.tez.serviceplugins.api.ContainerLaunchRequest
-
- toString() - Method in class org.apache.tez.serviceplugins.api.ContainerStopRequest
-
- toString() - Method in class org.apache.tez.serviceplugins.api.ServicePluginsDescriptor
-
- trapEvents(EventHandler) - Method in interface org.apache.tez.runtime.api.OutputContext
-
Notify the context that at this point no more events should be sent.
- tryKillDAG() - Method in class org.apache.tez.dag.api.client.DAGClient
-
Kill a running DAG
- validateLogLevel(String) - Static method in enum org.apache.tez.dag.api.HistoryLogLevel
-
- validateProperty(String, Scope) - Static method in class org.apache.tez.dag.api.TezConfiguration
-
- valueOf(String) - Static method in enum org.apache.tez.client.TezAppMasterStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.tez.common.counters.DAGCounter
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.tez.dag.api.client.StatusGetOpts
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.tez.dag.api.event.VertexState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.tez.dag.api.HistoryLogLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.tez.serviceplugins.api.ContainerEndReason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.tez.serviceplugins.api.ServicePluginErrorDefaults
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.tez.serviceplugins.api.TaskAttemptEndReason
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.tez.client.TezAppMasterStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.tez.common.counters.DAGCounter
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.tez.dag.api.client.StatusGetOpts
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.tez.dag.api.event.VertexState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.tez.dag.api.HistoryLogLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.tez.serviceplugins.api.ContainerEndReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.tez.serviceplugins.api.ServicePluginErrorDefaults
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.tez.serviceplugins.api.TaskAttemptEndReason
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- version - Variable in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- Vertex - Class in org.apache.tez.dag.api
-
Defines a vertex in the DAG.
- Vertex.VertexExecutionContext - Class in org.apache.tez.dag.api
-
The execution context for a running vertex.
- VertexGroup - Class in org.apache.tez.dag.api
-
Represents a virtual collection of vertices whose members can be treated as a single
named collection for graph operations.
- VertexLocationHint - Class in org.apache.tez.dag.api
-
Describes the placements hints for tasks in a vertex.
- VertexManagerEvent - Class in org.apache.tez.runtime.api.events
-
Event used to send information from a Task to the VertexManager for a vertex.
- VertexManagerPlugin - Class in org.apache.tez.dag.api
-
Interface to plugin user logic into the VertexManager to implement runtime
scheduling optimizations and graph reconfiguration.
- VertexManagerPlugin(VertexManagerPluginContext) - Constructor for class org.apache.tez.dag.api.VertexManagerPlugin
-
Crete an instance of the VertexManagerPlugin.
- VertexManagerPluginContext - Interface in org.apache.tez.dag.api
-
Object with API's to interact with the Tez execution engine
- VertexManagerPluginDescriptor - Class in org.apache.tez.dag.api
-
- VertexManagerPluginDescriptor() - Constructor for class org.apache.tez.dag.api.VertexManagerPluginDescriptor
-
- vertexReconfigurationPlanned() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Optional API.
- VertexState - Enum in org.apache.tez.dag.api.event
-
Vertex state information.
- VertexStateUpdate - Class in org.apache.tez.dag.api.event
-
Updates that are sent to user code running within the AM, on Vertex state changes.
- VertexStateUpdate(String, VertexState) - Constructor for class org.apache.tez.dag.api.event.VertexStateUpdate
-
- VertexStatistics - Interface in org.apache.tez.runtime.api
-
Provides various statistics about the physical execution of this
Vertex
This only provides point in time values for the statistics and values are
refreshed based on when the implementations of the inputs/outputs/tasks etc.
- VertexStatus - Class in org.apache.tez.dag.api.client
-
Describes the status of the
Vertex
- VertexStatus(DAGProtos.VertexStatusProtoOrBuilder) - Constructor for class org.apache.tez.dag.api.client.VertexStatus
-