Skip navigation links
A B C D E F G H I K L M N O P R S T U V W Y 

A

abort() - Method in class org.apache.tez.runtime.api.AbstractLogicalIOProcessor
 
abort() - Method in interface org.apache.tez.runtime.api.ProcessorFrameworkInterface
Indicates Processor to abort.
abortOutput(VertexStatus.State) - Method in class org.apache.tez.runtime.api.OutputCommitter
For aborting an output.
AbstractCounters<C extends TezCounter,G extends CounterGroupBase<C>> - Class in org.apache.tez.common.counters
An abstract class to provide common implementation for the Counters container in both mapred and mapreduce packages.
AbstractCounters(CounterGroupFactory<C, G>) - Constructor for class org.apache.tez.common.counters.AbstractCounters
 
AbstractCounters(AbstractCounters<C1, G1>, CounterGroupFactory<C, G>) - Constructor for class org.apache.tez.common.counters.AbstractCounters
Construct from another counters object.
AbstractLogicalInput - Class in org.apache.tez.runtime.api
An abstract class which should be the base class for all implementations of LogicalInput.
AbstractLogicalInput(InputContext, int) - Constructor for class org.apache.tez.runtime.api.AbstractLogicalInput
Constructor an instance of the LogicalInput.
AbstractLogicalIOProcessor - Class in org.apache.tez.runtime.api
Abstract representation of the interface LogicalIOProcessor.
AbstractLogicalIOProcessor(ProcessorContext) - Constructor for class org.apache.tez.runtime.api.AbstractLogicalIOProcessor
Constructor an instance of the LogicalProcessor.
AbstractLogicalOutput - Class in org.apache.tez.runtime.api
An abstract class which should be the base class for all implementations of LogicalOutput.
AbstractLogicalOutput(OutputContext, int) - Constructor for class org.apache.tez.runtime.api.AbstractLogicalOutput
Constructor an instance of the LogicalOutput.
addAppMasterLocalFiles(Map<String, LocalResource>) - Method in class org.apache.tez.client.TezClient
Add local files for the DAG App Master.
addCounter(T) - Method in interface org.apache.tez.common.counters.CounterGroupBase
Add a counter to this group.
addCounter(String, String, long) - Method in interface org.apache.tez.common.counters.CounterGroupBase
Add a counter to this group
addCounters(TezCounters) - Method in interface org.apache.tez.runtime.api.InputInitializerContext
Add custom counters
addDataSink(String, DataSinkDescriptor) - Method in class org.apache.tez.dag.api.Vertex
Specifies an external data sink for a Vertex.
addDataSink(String, DataSinkDescriptor) - Method in class org.apache.tez.dag.api.VertexGroup
Add an common data sink to the group of vertices.
addDataSource(String, DataSourceDescriptor) - Method in class org.apache.tez.dag.api.Vertex
Specifies an external data source for a Vertex.
addEdge(Edge) - Method in class org.apache.tez.dag.api.DAG
Add an Edge connecting vertices in the DAG
addEdge(GroupInputEdge) - Method in class org.apache.tez.dag.api.DAG
Add a GroupInputEdge to the DAG.
addGroup(G) - Method in class org.apache.tez.common.counters.AbstractCounters
Add a group.
addGroup(String, String) - Method in class org.apache.tez.common.counters.AbstractCounters
Add a new group
addLog4jSystemProperties(String, List<String>) - Static method in class org.apache.tez.common.TezUtils
Allows changing the log level for task / AM logging.
addRootInputEvents(String, Collection<InputDataInformationEvent>) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
Allows a VertexManagerPlugin to assign Events for Root Inputs For regular Event Routing changes - the EdgeManager should be configured via the setVertexParallelism method
addTaskLocalFiles(Map<String, LocalResource>) - Method in class org.apache.tez.dag.api.DAG
Set the files etc that must be provided to the tasks of this DAG
addTaskLocalFiles(Map<String, LocalResource>) - Method in class org.apache.tez.dag.api.Vertex
Set the files etc that must be provided to the tasks of this vertex
addURIsForCredentials(Collection<URI>) - 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.
addURIsForCredentials(Collection<URI>) - Method in class org.apache.tez.dag.api.DataSinkDescriptor
This method can be used to specify a list of URIs for which Credentials need to be obtained so that the job can run.
addURIsForCredentials(Collection<URI>) - Method in class org.apache.tez.dag.api.DataSourceDescriptor
This method can be used to specify a list of URIs for which Credentials need to be obtained so that the job can run.
addVertex(Vertex) - Method in class org.apache.tez.dag.api.DAG
 
allocateTask(Object, Resource, String[], String[], Priority, Object, Object) - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
A request to the source to allocate resources for a requesting task, with location information optionally specified
allocateTask(Object, Resource, ContainerId, Priority, Object, Object) - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
A request to the source to allocate resources for a requesting task, based on a previously used container
appIdfromString(String) - Static method in class org.apache.tez.client.TezClient
 
appShutdownRequested() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
Inform the framework that an app shutdown is required.
areContainersEnabled() - Method in class org.apache.tez.serviceplugins.api.ServicePluginsDescriptor
 

B

blacklistNode(NodeId) - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
Indication to a source that a node has been blacklisted, and should not be used for subsequent allocations.
build() - Method in class org.apache.tez.client.TezClient.TezClientBuilder
Build the actual instance of the TezClient

C

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
 
cancelAMKeepAlive(boolean) - Method in class org.apache.tez.client.TezClient
 
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
If the next DAG App Master needs different local files, then use this method to clear the local files and then add the new local files using TezClient.addAppMasterLocalFiles(Map).
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.
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
 
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 TezCounters 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, 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 a DataSourceDescriptor when the data shard calculation happens in the App Master at runtime
create(InputDescriptor, InputInitializerDescriptor, int, Credentials, VertexLocationHint, Map<String, LocalResource>) - Static method in class org.apache.tez.dag.api.DataSourceDescriptor
Create a DataSourceDescriptor when the data shard calculation happens in the client at compile time
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.DataMovementTypes
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(EdgeManagerPluginDescriptor, EdgeProperty.DataMovementType, EdgeProperty.DataSourceType, EdgeProperty.SchedulingType, OutputDescriptor, InputDescriptor) - Static method in class org.apache.tez.dag.api.EdgeProperty
 
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 a PreWarmVertex to be used in TezClient.preWarm(PreWarmVertex) It may be necessary to call more methods to add local files etc on the pre-warm vertex post creation so that it matches the real DAG vertices.
create(String, int, Resource) - Static method in class org.apache.tez.dag.api.PreWarmVertex
Create a PreWarmVertex to be used in @link TezClient.preWarm(PreWarmVertex) This uses a built in pre-warm processor that implements common functionality.
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, int, int, int, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
 
create(int, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.DataMovementEvent
User Event constructor for Outputs
create(ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.DataMovementEvent
 
create(int, int, int, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.DataMovementEvent
 
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
 
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
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
Convert an instance of UserPayload to Configuration
createConfigBuilder(Configuration) - Static method in class org.apache.tez.dag.api.PreWarmVertex
Create a config builder for the @link PreWarmVertex.
createDag(Configuration, Credentials, Map<String, LocalResource>, LocalResource, boolean) - Method in class org.apache.tez.dag.api.DAG
 
createDag(Configuration, Credentials, Map<String, LocalResource>, LocalResource, boolean, ServicePluginsDescriptor, JavaOptsChecker) - Method in class org.apache.tez.dag.api.DAG
 
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
createFrameworkClient() - Method in class org.apache.tez.client.TezClient
 
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.
createTezFrameworkExecutorService(int, String) - Method in interface org.apache.tez.runtime.api.TaskContext
Create a new ExecutorService with the given parallelism and thread name format.
createUserPayloadFromConf(Configuration) - Static method in class org.apache.tez.common.TezUtils
Convert a Configuration to a UserPayload
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
 
createWithSerializedPayload(int, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
Provide a serialized form of the payload

D

DAG - Static variable in class org.apache.tez.client.TezClient
 
DAG - Class in org.apache.tez.dag.api
Top level entity that defines the DAG (Directed Acyclic Graph) representing the data flow graph.
DAG_RECOVERY_ENABLED - Static variable in class org.apache.tez.dag.api.TezConfiguration
Boolean value.
DAG_RECOVERY_ENABLED_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
DAG_RECOVERY_FILE_IO_BUFFER_SIZE - Static variable in class org.apache.tez.dag.api.TezConfiguration
Int value.
DAG_RECOVERY_FILE_IO_BUFFER_SIZE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
DAG_RECOVERY_FLUSH_INTERVAL_SECS - Static variable in class org.apache.tez.dag.api.TezConfiguration
Int value.
DAG_RECOVERY_FLUSH_INTERVAL_SECS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
DAG_RECOVERY_MAX_UNFLUSHED_EVENTS - Static variable in class org.apache.tez.dag.api.TezConfiguration
Int value.
DAG_RECOVERY_MAX_UNFLUSHED_EVENTS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
DAGAccessControls - Class in org.apache.tez.common.security
Access controls for the DAG
DAGAccessControls() - Constructor for class org.apache.tez.common.security.DAGAccessControls
 
DAGAccessControls(String, String) - Constructor for class org.apache.tez.common.security.DAGAccessControls
Helper API to support YARN and MapReduce format for specifying users and groups.
DAGClient - Class in org.apache.tez.dag.api.client
Class for monitoring the DAG running in a Tez DAG Application Master.
DAGClient() - Constructor for class org.apache.tez.dag.api.client.DAGClient
 
dagComplete() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
Indicates to the scheduler that the currently running dag has completed.
DAGCounter - Enum in org.apache.tez.common.counters
 
DAGStatus - Class in org.apache.tez.dag.api.client
Describes the status of the DAG
DAGStatus(DAGProtos.DAGStatusProtoOrBuilder, DagStatusSource) - Constructor for class org.apache.tez.dag.api.client.DAGStatus
 
DAGSubmissionTimedOut - Exception in org.apache.tez.dag.api
Exception thrown when DAG submission to a Tez Session times out.
DAGSubmissionTimedOut(String) - Constructor for exception org.apache.tez.dag.api.DAGSubmissionTimedOut
 
DataMovementEvent - Class in org.apache.tez.runtime.api.events
Event used by user code to send information between tasks.
DataSinkDescriptor - Class in org.apache.tez.dag.api
Defines the output and output committer for a data sink
DataSinkDescriptor(OutputDescriptor, OutputCommitterDescriptor, Credentials) - Constructor for class org.apache.tez.dag.api.DataSinkDescriptor
Deprecated.
DataSourceDescriptor - Class in org.apache.tez.dag.api
Defines the input and input initializer for a data source
deallocateContainer(ContainerId) - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
A request to de-allocate a previously allocated container.
deallocateTask(Object, boolean, TaskAttemptEndReason, String) - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
A request to deallocate a task.
deepCopyAsArray() - Method in class org.apache.tez.dag.api.UserPayload
 
DEFAULT - Static variable in enum org.apache.tez.dag.api.HistoryLogLevel
 
delete(String) - Method in interface org.apache.tez.runtime.api.ObjectRegistry
Delete the object associated with the provided key
doneReconfiguringVertex() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
Optional API.

E

Edge - Class in org.apache.tez.dag.api
Edge defines the connection between a producer and consumer vertex in the DAG.
EdgeManagerPlugin - Class in org.apache.tez.dag.api
This interface defines the routing of the event between tasks of producer and consumer vertices.
EdgeManagerPlugin(EdgeManagerPluginContext) - Constructor for class org.apache.tez.dag.api.EdgeManagerPlugin
Create an instance of the EdgeManagerPlugin.
EdgeManagerPluginContext - Interface in org.apache.tez.dag.api
Context information provided to EdgeManagerPlugins This interface is not supposed to be implemented by users
EdgeManagerPluginDescriptor - Class in org.apache.tez.dag.api
Describes the @link EdgeManagerPlugin
EdgeManagerPluginOnDemand - Class in org.apache.tez.dag.api
This interface defines the routing of the event between tasks of producer and consumer vertices.
EdgeManagerPluginOnDemand(EdgeManagerPluginContext) - Constructor for class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
Create an instance of the EdgeManagerPluginOnDemand.
EdgeProperty - Class in org.apache.tez.dag.api
An @link EdgeProperty defines the relation between the source and destination vertices of an edge.
EntityDescriptor<T extends EntityDescriptor<T>> - Class in org.apache.tez.dag.api
Describes a given user code entity.
EntityDescriptor() - Constructor for class org.apache.tez.dag.api.EntityDescriptor
 
EntityDescriptor(String) - Constructor for class org.apache.tez.dag.api.EntityDescriptor
 
equals(Object) - Method in class org.apache.tez.common.counters.AbstractCounters
 
equals(Object) - Method in class org.apache.tez.dag.api.client.DAGStatus
 
equals(Object) - Method in class org.apache.tez.dag.api.client.Progress
 
equals(Object) - Method in class org.apache.tez.dag.api.client.VertexStatus
 
equals(Object) - Method in class org.apache.tez.dag.api.Edge
 
equals(Object) - Method in class org.apache.tez.dag.api.GroupInputEdge
 
equals(Object) - Method in class org.apache.tez.dag.api.TaskLocationHint
 
equals(Object) - Method in class org.apache.tez.dag.api.Vertex
 
equals(Object) - Method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
 
equals(Object) - Method in class org.apache.tez.dag.api.VertexGroup
 
equals(Object) - Method in class org.apache.tez.dag.api.VertexLocationHint
 
Event - Class in org.apache.tez.runtime.api
Base class for all events generated within the Tez execution engine.
Event() - Constructor for class org.apache.tez.runtime.api.Event
 
ExecutionContext - Interface in org.apache.tez.runtime.api
The context for the executor within which a task runs.
expand(int, int) - Method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
Expand the CompositeDataMovementEvent into a routable DataMovementEvent by providing the source output index and the target input index.
expand(int) - Method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
 
expandRouted(EdgeManagerPluginOnDemand.CompositeEventRouteMetadata) - Method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
 

F

fatalError(Throwable, String) - Method in interface org.apache.tez.runtime.api.TaskContext
Deprecated.
Replaced by TaskContext.reportFailure(TaskFailureType, Throwable, String) (FailureType, Throwable, String)} Note: To maintain compatibility, even though this method is named 'fatalError' - this method operates as TaskContext.reportFailure(TaskFailureType, Throwable, String) with the TaskFailureType set to TaskFailureType.NON_FATAL.
findCounter(String, String) - Method in class org.apache.tez.common.counters.AbstractCounters
Find a counter, create one if necessary
findCounter(Enum<?>) - Method in class org.apache.tez.common.counters.AbstractCounters
Find the counter for the given enum.
findCounter(String, FileSystemCounter) - Method in class org.apache.tez.common.counters.AbstractCounters
Find the file system counter for the given scheme and enum.
findCounter(String, String) - Method in interface org.apache.tez.common.counters.CounterGroupBase
Find a counter in the group.
findCounter(String, boolean) - Method in interface org.apache.tez.common.counters.CounterGroupBase
Find a counter in the group
findCounter(String) - Method in interface org.apache.tez.common.counters.CounterGroupBase
Find a counter in the group.

G

get(String) - Method in interface org.apache.tez.runtime.api.ObjectRegistry
Return the object associated with the provided key
getAdditionalLocalFiles() - Method in class org.apache.tez.dag.api.DataSourceDescriptor
Get the list of additional local files which were specified during creation.
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
 
getAllNumPhysicalInputs() - Method in class org.apache.tez.runtime.api.InputSpecUpdate
 
getAMKeepAliveService() - Method in class org.apache.tez.client.TezClient
 
getAMProxy(ApplicationId) - 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
getApplicationReportInternal() - Method in class org.apache.tez.dag.api.client.DAGClient
 
getAppMasterApplicationId() - Method in class org.apache.tez.client.TezClient
 
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
 
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
The ContainerLauncherContext for the container being launched
getContainerLauncherDescriptors() - Method in class org.apache.tez.serviceplugins.api.ServicePluginsDescriptor
 
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
Return the EdgeManagerPluginContext for this specific instance of the vertex manager.
getContext() - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
Return the EdgeManagerPluginContext for this specific instance of the vertex manager.
getContext() - Method in class org.apache.tez.dag.api.VertexManagerPlugin
Return ahe VertexManagerPluginContext for this specific instance of the vertex manager.
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
Return ahe InputInitializerContext for this specific instance of the Initializer.
getContext() - Method in class org.apache.tez.runtime.api.MergedLogicalInput
 
getContext() - Method in class org.apache.tez.runtime.api.OutputCommitter
Return ahe OutputCommitterContext for this specific instance of the Committer.
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.DAG
 
getCredentials() - Method in class org.apache.tez.dag.api.DataSinkDescriptor
Get the Credentials for this DataSinkDescriptor
getCredentials() - Method in class org.apache.tez.dag.api.DataSourceDescriptor
Returns any credentials needed to access this data source.
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
getDagAccessControls() - Method in class org.apache.tez.dag.api.DAG
 
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
getDagConf() - Method in class org.apache.tez.dag.api.DAG
 
getDAGCounters() - Method in class org.apache.tez.dag.api.client.DAGStatus
 
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
getDataSinks() - Method in class org.apache.tez.dag.api.Vertex
 
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.
getDataSources() - Method in class org.apache.tez.dag.api.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
 
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
 
getEdgeManagerDescriptor() - Method in class org.apache.tez.dag.api.EdgeProperty
Returns the Edge Manager specifications for this edge.
getEdgeProperty() - Method in class org.apache.tez.dag.api.Edge
The @link EdgeProperty for this 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.
getGroupsWithModifyACLs() - Method in class org.apache.tez.common.security.DAGAccessControls
 
getGroupsWithViewACLs() - Method in class org.apache.tez.common.security.DAGAccessControls
 
getHistoryText() - Method in class org.apache.tez.dag.api.EntityDescriptor
 
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.Edge
 
getId() - Method in class org.apache.tez.dag.api.GroupInputEdge
 
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
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.dag.api.DataSourceDescriptor
Get the location hints for the tasks in the vertex for this data source.
getLocationHint() - Method in class org.apache.tez.runtime.api.events.InputConfigureVertexTasksEvent
 
getLogLevel(Configuration, HistoryLogLevel) - Static method in enum org.apache.tez.dag.api.HistoryLogLevel
 
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
getNumberOfShards() - Method in class org.apache.tez.dag.api.DataSourceDescriptor
Number of shards for this data source.
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
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.
getNumPhysicalInputsForWorkUnit(int) - Method in class org.apache.tez.runtime.api.InputSpecUpdate
 
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
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
Get an InputStatisticsReporter for this Input that can be used to report statistics like data size
getStatisticsReporter() - Method in interface org.apache.tez.runtime.api.OutputContext
Get an OutputStatisticsReporter for this Output that can be used to report statistics like data size
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
 
getTaskCommunicatorDescriptors() - Method in class org.apache.tez.serviceplugins.api.ServicePluginsDescriptor
 
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.DAG
 
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
getTaskSchedulerDescriptors() - Method in class org.apache.tez.serviceplugins.api.ServicePluginsDescriptor
 
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
 
getUnderlyingCounter() - Method in interface org.apache.tez.common.counters.TezCounter
Return the underlying object if this is a facade.
getUnderlyingGroup() - Method in interface org.apache.tez.common.counters.CounterGroupBase
 
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.DAG
 
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
getUsersWithModifyACLs() - Method in class org.apache.tez.common.security.DAGAccessControls
 
getUsersWithViewACLs() - Method in class org.apache.tez.common.security.DAGAccessControls
 
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
 
getVertexCounters() - Method in class org.apache.tez.dag.api.client.VertexStatus
 
getVertexExecutionContext() - Method in class org.apache.tez.dag.api.Vertex
 
getVertexGroupName() - Method in interface org.apache.tez.dag.api.EdgeManagerPluginContext
 
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
Get a VertexStatistics object to find out execution statistics about the given Vertex.
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
getVertices() - Method in class org.apache.tez.dag.api.DAG
 
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
getWriteAllCounters() - Method in class org.apache.tez.common.counters.AbstractCounters
Get the "writeAllCounters" option
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.

H

handleEvents(List<Event>) - Method in interface org.apache.tez.runtime.api.InputFrameworkInterface
Handles user and system generated Events, which typically carry information such as an output being available on the previous vertex.
handleEvents(List<Event>) - Method in interface org.apache.tez.runtime.api.OutputFrameworkInterface
Handles user and system generated Events, which typically carry information such as a downstream vertex being ready to consume input.
handleEvents(List<Event>) - Method in interface org.apache.tez.runtime.api.ProcessorFrameworkInterface
Handles user and system generated Events.
handleInputInitializerEvent(List<InputInitializerEvent>) - Method in class org.apache.tez.runtime.api.InputInitializer
Handle events meant for the specific Initializer.
hashCode() - Method in class org.apache.tez.common.counters.AbstractCounters
 
hashCode() - Method in class org.apache.tez.dag.api.client.DAGStatus
 
hashCode() - Method in class org.apache.tez.dag.api.client.Progress
 
hashCode() - Method in class org.apache.tez.dag.api.client.VertexStatus
 
hashCode() - Method in class org.apache.tez.dag.api.Edge
 
hashCode() - Method in class org.apache.tez.dag.api.GroupInputEdge
 
hashCode() - Method in class org.apache.tez.dag.api.TaskLocationHint
 
hashCode() - Method in class org.apache.tez.dag.api.Vertex
 
hashCode() - Method in class org.apache.tez.dag.api.Vertex.VertexExecutionContext
 
hashCode() - Method in class org.apache.tez.dag.api.VertexGroup
 
hashCode() - Method in class org.apache.tez.dag.api.VertexLocationHint
 
hasPayload() - Method in class org.apache.tez.dag.api.UserPayload
 
hasUnregistered() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
Checks with the scheduler whether it has unregistered.
HistoryACLPolicyException - Exception in org.apache.tez.common.security
HistoryACLPolicyException Exception thrown upon error within HistoryACLPolicyManager
HistoryACLPolicyException(Throwable) - Constructor for exception org.apache.tez.common.security.HistoryACLPolicyException
 
HistoryACLPolicyException(String) - Constructor for exception org.apache.tez.common.security.HistoryACLPolicyException
 
HistoryACLPolicyException(String, Throwable) - Constructor for exception org.apache.tez.common.security.HistoryACLPolicyException
 
HistoryLogLevel - Enum in org.apache.tez.dag.api
The log level for the history, this is used to determine which events are sent to the history logger.
historyText - Variable in class org.apache.tez.dag.api.EntityDescriptor
 

I

incrAllCounters(AbstractCounters<C, G>) - Method in class org.apache.tez.common.counters.AbstractCounters
Increments multiple counters by their amounts in another Counters instance.
incrAllCounters(CounterGroupBase<T>) - Method in interface org.apache.tez.common.counters.CounterGroupBase
Increment all counters by a group of counters
increment(long) - Method in interface org.apache.tez.common.counters.TezCounter
Increment this counter by the given value
informInputReady() - Method in class org.apache.tez.runtime.api.MergedLogicalInput
Used by the actual MergedInput to notify that it's ready for consumption.
initialize() - Method in class org.apache.tez.dag.api.EdgeManagerPlugin
Initializes the EdgeManagerPlugin.
initialize() - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
Initializes the EdgeManagerPlugin.
initialize() - Method in class org.apache.tez.dag.api.VertexManagerPlugin
Initialize the plugin.
initialize() - Method in class org.apache.tez.runtime.api.AbstractLogicalInput
 
initialize() - Method in class org.apache.tez.runtime.api.AbstractLogicalIOProcessor
 
initialize() - Method in class org.apache.tez.runtime.api.AbstractLogicalOutput
 
initialize() - Method in interface org.apache.tez.runtime.api.InputFrameworkInterface
Initializes the Input.
initialize() - Method in class org.apache.tez.runtime.api.InputInitializer
Run the initializer.
initialize() - Method in class org.apache.tez.runtime.api.OutputCommitter
Setup up the Output committer.
initialize() - Method in interface org.apache.tez.runtime.api.OutputFrameworkInterface
Initializes the Output
initialize() - Method in interface org.apache.tez.runtime.api.ProcessorFrameworkInterface
Initializes the Processor
initialize() - Method in class org.apache.tez.serviceplugins.api.ContainerLauncher
An entry point for initialization.
initialize() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
An entry point for initialization.
initiateStop() - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
The first step of stopping the task scheduler service.
Input - Interface in org.apache.tez.runtime.api
Represents an input through which a Processor receives data on an edge.
InputConfigureVertexTasksEvent - Class in org.apache.tez.runtime.api.events
An event typically sent by the InputInitializer of a vertex to configure the tasks of the vertex.
InputContext - Interface in org.apache.tez.runtime.api
Context handle for the Input to initialize itself.
InputDataInformationEvent - Class in org.apache.tez.runtime.api.events
Events used by InputInitializer implementations to provide the user payload for individual tasks running as part of the Vertex for which an Initial Input has been configured.
InputDescriptor - Class in org.apache.tez.dag.api
Describes the Input
InputDescriptor() - Constructor for class org.apache.tez.dag.api.InputDescriptor
 
InputFrameworkInterface - Interface in org.apache.tez.runtime.api
Represents an input through which a TezProcessor receives data on an edge.
InputInitializer - Class in org.apache.tez.runtime.api
InputInitializers are typically used to initialize vertices connected to data sources.
InputInitializer(InputInitializerContext) - Constructor for class org.apache.tez.runtime.api.InputInitializer
Constructor an instance of the InputInitializer.
InputInitializerContext - Interface in org.apache.tez.runtime.api
A context that provides information to the InputInitializer
InputInitializerDescriptor - Class in org.apache.tez.dag.api
Describes the InputInitializer
InputInitializerDescriptor() - Constructor for class org.apache.tez.dag.api.InputInitializerDescriptor
 
InputInitializerEvent - Class in org.apache.tez.runtime.api.events
An event that is routed to the specified InputInitializer.
inputIsReady() - Method in interface org.apache.tez.runtime.api.InputContext
Inform the framework that the specific Input is ready for consumption.
inputIsReady() - Method in interface org.apache.tez.runtime.api.MergedInputContext
Inform the framework that the specific Input is ready for consumption.
InputReadErrorEvent - Class in org.apache.tez.runtime.api.events
Event generated by an Input to indicate error when trying to retrieve data.
InputSpecUpdate - Class in org.apache.tez.runtime.api
Update Input specs for Inputs running in a task.
InputStatistics - Interface in org.apache.tez.runtime.api
Provides various statistics about physical execution activity happening on a logical input in a Vertex.
InputStatisticsReporter - Interface in org.apache.tez.runtime.api
Report statistics about the Input
InputUpdatePayloadEvent - Class in org.apache.tez.runtime.api.events
Events used by InputInitializer implementations to update the shared user payload for the Input that is being initialized.
isCompleted() - Method in class org.apache.tez.dag.api.client.DAGStatus
 
isExactMatch(Object, Object) - Method in interface org.apache.tez.common.ContainerSignatureMatcher
Checks if the container signatures match exactly
isForAllWorkUnits() - Method in class org.apache.tez.runtime.api.InputSpecUpdate
 
isSession() - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
Check whether the AM is running in session mode.
isSuperSet(Object, Object) - Method in interface org.apache.tez.common.ContainerSignatureMatcher
Checks the compatibility between the specified container signatures.
isTaskRecoverySupported() - Method in class org.apache.tez.runtime.api.OutputCommitter
Whether the OutputCommitter supports recovery of output from a Task that completed in a previous DAG attempt
isUberEnabled() - Method in class org.apache.tez.serviceplugins.api.ServicePluginsDescriptor
 
iterator() - Method in class org.apache.tez.common.counters.AbstractCounters
 

K

killSelf(Throwable, String) - Method in interface org.apache.tez.runtime.api.TaskContext
Kill the currently running attempt.

L

launchContainer(ContainerLaunchRequest) - 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
limits() - Method in class org.apache.tez.common.counters.AbstractCounters
 
LOG - Static variable in class org.apache.tez.common.counters.AbstractCounters
 
LogicalInput - Interface in org.apache.tez.runtime.api
An Input which handles all incoming physical connections on an edge.
LogicalInputFrameworkInterface - Interface in org.apache.tez.runtime.api
Defines the framework facing interfact for a LogicalInput User implementations are expected to derive from AbstractLogicalInput
LogicalIOProcessor - Interface in org.apache.tez.runtime.api
Represents a processor which consumes LogicalInputs and produces LogicalOutputs
LogicalIOProcessorFrameworkInterface - Interface in org.apache.tez.runtime.api
Represents a processor framework interface which consumes LogicalInputs and produces LogicalOutputs.
LogicalOutput - Interface in org.apache.tez.runtime.api
An @link Output which handles all outgoing physical connections on an edge.
LogicalOutputFrameworkInterface - Interface in org.apache.tez.runtime.api
Framework facing interface for the LogicalOutput Users are expected to derive from AbstractLogicalOutput

M

makeCopy(int) - Method in class org.apache.tez.runtime.api.events.DataMovementEvent
Make a routable copy of the DataMovementEvent by adding a target input index
memoryAssigned(long) - Method in class org.apache.tez.runtime.api.MemoryUpdateCallback
 
MemoryUpdateCallback - Class in org.apache.tez.runtime.api
This interface will be used by Tez to inform components about available memory.
MemoryUpdateCallback() - Constructor for class org.apache.tez.runtime.api.MemoryUpdateCallback
 
MergedInputContext - Interface in org.apache.tez.runtime.api
Context for MergedLogicalInput This interface is not supposed to be implemented by users
MergedLogicalInput - Class in org.apache.tez.runtime.api
A LogicalInput that is used to merge the data from multiple inputs and provide a single Reader to read that data.
MergedLogicalInput(MergedInputContext, List<Input>) - Constructor for class org.apache.tez.runtime.api.MergedLogicalInput
Constructor an instance of the MergedLogicalInputs.
mergeIntoAmAcls(Configuration) - Method in class org.apache.tez.common.security.DAGAccessControls
Merge the dag acls with the AM acls in the configuration object.

N

newBuilder(String, TezConfiguration) - Static method in class org.apache.tez.client.TezClient
Create a new TezClientBuilder.
nodesUpdated(List<NodeReport>) - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
Provide an update to the framework about the status of nodes available to this report
notifyProgress() - Method in interface org.apache.tez.runtime.api.MergedInputContext
Inform the framework that progress has been made
notifyProgress() - Method in interface org.apache.tez.runtime.api.TaskContext
Notifies the framework that progress is being made by this component.

O

ObjectRegistry - Interface in org.apache.tez.runtime.api
A simple shared object registry to cache objects in the memory of the container running the task.
onRootVertexInitialized(String, InputDescriptor, List<Event>) - Method in class org.apache.tez.dag.api.VertexManagerPlugin
Notification that the inputs of this vertex have initialized
onSourceTaskCompleted(String, Integer) - Method in class org.apache.tez.dag.api.VertexManagerPlugin
Deprecated.
onSourceTaskCompleted(TaskAttemptIdentifier) - Method in class org.apache.tez.dag.api.VertexManagerPlugin
Notification of a source vertex task completion.
onVertexManagerEventReceived(VertexManagerEvent) - Method in class org.apache.tez.dag.api.VertexManagerPlugin
Notification of an event directly sent to this vertex manager
onVertexStarted(Map<String, List<Integer>>) - Method in class org.apache.tez.dag.api.VertexManagerPlugin
Deprecated.
onVertexStarted(List<TaskAttemptIdentifier>) - Method in class org.apache.tez.dag.api.VertexManagerPlugin
Notification that the vertex is ready to start running tasks
onVertexStateUpdated(VertexStateUpdate) - Method in class org.apache.tez.dag.api.VertexManagerPlugin
Receive notifications on vertex state changes.
onVertexStateUpdated(VertexStateUpdate) - Method in class org.apache.tez.runtime.api.InputInitializer
Receive notifications on vertex state changes.
org.apache.tez.client - package org.apache.tez.client
 
org.apache.tez.common - package org.apache.tez.common
 
org.apache.tez.common.annotation - package org.apache.tez.common.annotation
 
org.apache.tez.common.counters - package org.apache.tez.common.counters
 
org.apache.tez.common.security - package org.apache.tez.common.security
 
org.apache.tez.dag.api - package org.apache.tez.dag.api
 
org.apache.tez.dag.api.client - package org.apache.tez.dag.api.client
 
org.apache.tez.dag.api.event - package org.apache.tez.dag.api.event
 
org.apache.tez.dag.api.records - package org.apache.tez.dag.api.records
 
org.apache.tez.runtime.api - package org.apache.tez.runtime.api
 
org.apache.tez.runtime.api.events - package org.apache.tez.runtime.api.events
 
org.apache.tez.serviceplugins.api - package org.apache.tez.serviceplugins.api
 
Output - Interface in org.apache.tez.runtime.api
Represents an Output through which a TezProcessor writes information to an edge.
OutputCommitter - Class in org.apache.tez.runtime.api
OutputCommitter to "finalize" the output and make it user-visible if needed.
OutputCommitter(OutputCommitterContext) - Constructor for class org.apache.tez.runtime.api.OutputCommitter
Constructor an instance of the OutputCommitter.
OutputCommitterContext - Interface in org.apache.tez.runtime.api
Context through which the OutputCommitter can access all the relevant information that it needs.
OutputCommitterDescriptor - Class in org.apache.tez.dag.api
Describes the OutputCommitter
OutputCommitterDescriptor() - Constructor for class org.apache.tez.dag.api.OutputCommitterDescriptor
 
OutputContext - Interface in org.apache.tez.runtime.api
Context handle for the Output to initialize itself.
OutputDescriptor - Class in org.apache.tez.dag.api
Describes the Output
OutputDescriptor() - Constructor for class org.apache.tez.dag.api.OutputDescriptor
 
OutputFrameworkInterface - Interface in org.apache.tez.runtime.api
Represents the Tez framework part of an Output.
OutputStatistics - Interface in org.apache.tez.runtime.api
Provides various statistics about physical execution activity happening on a logical output in a Vertex.
OutputStatisticsReporter - Interface in org.apache.tez.runtime.api
Report statistics about the Output

P

populateConfProtoFromEntries(Iterable<Map.Entry<String, String>>, DAGProtos.ConfigurationProto.Builder) - Static method in class org.apache.tez.common.TezUtils
 
preemptContainer(ContainerId) - Method in interface org.apache.tez.serviceplugins.api.TaskSchedulerContext
Inform the framework that the scheduler has determined that a previously allocated container needs to be preempted
prepareForRouting() - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
This method will be invoked just before routing of events will begin.
preWarm(PreWarmVertex) - Method in class org.apache.tez.client.TezClient
API to help pre-allocate containers in session mode.
preWarm(PreWarmVertex, long, TimeUnit) - Method in class org.apache.tez.client.TezClient
API to help pre-allocate containers in session mode.
PreWarmVertex - Class in org.apache.tez.dag.api
A PreWarmVertex is used to specify parameters to be used to setup prewarmed containers for Tez session mode.
Processor - Interface in org.apache.tez.runtime.api
Processor represents the Tez entity responsible for consuming Input and producing Output.
ProcessorContext - Interface in org.apache.tez.runtime.api
Context handle for the Processor to initialize itself.
ProcessorDescriptor - Class in org.apache.tez.dag.api
Describes the Processor
ProcessorDescriptor() - Constructor for class org.apache.tez.dag.api.ProcessorDescriptor
 
ProcessorFrameworkInterface - Interface in org.apache.tez.runtime.api
Represents the Tez framework part of an Processor.
Progress - Class in org.apache.tez.dag.api.client
Describes the progress made by DAG execution
ProgressFailedException - Exception in org.apache.tez.runtime.api
 
ProgressFailedException() - Constructor for exception org.apache.tez.runtime.api.ProgressFailedException
 
ProgressFailedException(Throwable) - Constructor for exception org.apache.tez.runtime.api.ProgressFailedException
 
ProgressFailedException(String, Throwable) - Constructor for exception org.apache.tez.runtime.api.ProgressFailedException
 

R

Reader - Class in org.apache.tez.runtime.api
A Reader represents the data being read in an Input It encapsulates the data type etc of the data being provided by the Input E.g.
Reader() - Constructor for class org.apache.tez.runtime.api.Reader
 
readFields(DataInput) - Method in class org.apache.tez.common.counters.AbstractCounters
 
readFields(DataInput) - Method in class org.apache.tez.dag.api.EntityDescriptor
 
reconfigureVertex(int, VertexLocationHint, Map<String, EdgeProperty>, Map<String, InputSpecUpdate>) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
API to reconfigure a Vertex that is reading root inputs based on the data read from the root inputs.
reconfigureVertex(int, VertexLocationHint, Map<String, EdgeProperty>) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
API to reconfigure a Vertex by changing its task parallelism.
reconfigureVertex(Map<String, InputSpecUpdate>, VertexLocationHint, int) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
API to reconfigure a Vertex that is reading root inputs based on the data read from the root inputs.
recoverTask(int, int) - Method in class org.apache.tez.runtime.api.OutputCommitter
Recover task output from a previous DAG attempt
registerForVertexStateUpdates(String, Set<VertexState>) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
Register to get notifications on updates to the specified vertex.
registerForVertexStateUpdates(String, Set<VertexState>) - Method in interface org.apache.tez.runtime.api.InputInitializerContext
Register to get notifications on updates to the specified vertex.
reportDataSize(long) - Method in interface org.apache.tez.runtime.api.InputStatisticsReporter
Report the size of the logical data read
reportDataSize(long) - Method in interface org.apache.tez.runtime.api.OutputStatisticsReporter
Report the size of the logical data written
reportFailure(TaskFailureType, Throwable, String) - Method in interface org.apache.tez.runtime.api.TaskContext
Report an error to the framework.
reportItemsProcessed(long) - Method in interface org.apache.tez.runtime.api.InputStatisticsReporter
Report the number of items processed.
reportItemsProcessed(long) - Method in interface org.apache.tez.runtime.api.OutputStatisticsReporter
Report the number of items processed.
requestInitialMemory(long, MemoryUpdateCallback) - Method in interface org.apache.tez.runtime.api.TaskContext
Request a specific amount of memory during initialization (initialize(..*Context)) The requester is notified of allocation via the provided callback handler.
routeCompositeDataMovementEventToDestination(int, int) - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
The method provides the EdgeManagerPluginOnDemand.EventRouteMetadata to route a CompositeDataMovementEvent produced by the given source task to the given destination task.
routeDataMovementEventToDestination(DataMovementEvent, int, int, Map<Integer, List<Integer>>) - Method in class org.apache.tez.dag.api.EdgeManagerPlugin
Return the routing information to inform consumers about the source task output that is now available.
routeDataMovementEventToDestination(int, int, int) - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
The method provides the EdgeManagerPluginOnDemand.EventRouteMetadata to route a DataMovementEvent produced by the given source task to the given destination task.
routeDataMovementEventToDestination(DataMovementEvent, int, int, Map<Integer, List<Integer>>) - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
Return the routing information to inform consumers about the source task output that is now available.
routeInputErrorEventToSource(InputReadErrorEvent, int, int) - Method in class org.apache.tez.dag.api.EdgeManagerPlugin
Return the source task index to which to send the input error event
routeInputErrorEventToSource(int, int) - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
Return the source task index to which to send the input error event
routeInputErrorEventToSource(InputReadErrorEvent, int, int) - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
Return the source task index to which to send the input error event
routeInputSourceTaskFailedEventToDestination(int, Map<Integer, List<Integer>>) - Method in class org.apache.tez.dag.api.EdgeManagerPlugin
Return the routing information to inform consumers about the failure of a source task whose outputs have been potentially lost.
routeInputSourceTaskFailedEventToDestination(int, int) - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
The method provides the EdgeManagerPluginOnDemand.EventRouteMetadata to route an InputFailedEvent produced by the given source task to the given destination task.
routeInputSourceTaskFailedEventToDestination(int, Map<Integer, List<Integer>>) - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
Return the routing information to inform consumers about the failure of a source task whose outputs have been potentially lost.
run(Map<String, LogicalInput>, Map<String, LogicalOutput>) - Method in interface org.apache.tez.runtime.api.LogicalIOProcessorFrameworkInterface
Runs the Processor

S

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
 
setCount(int) - Method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
 
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
Deprecated.
(and no-op by default)
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.
setProducerAttemptIdentifier(TaskAttemptIdentifier) - Method in class org.apache.tez.runtime.api.events.VertexManagerEvent
 
setProgress(float) - Method in interface org.apache.tez.runtime.api.ProcessorContext
Set the overall progress of this Task Attempt.
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.
setSourceVertexName(String) - Method in class org.apache.tez.runtime.api.events.InputInitializerEvent
 
setTargetIndex(int) - Method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
 
setTargetIndex(int) - Method in class org.apache.tez.runtime.api.events.DataMovementEvent
 
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
 
setVersion(int) - Method in class org.apache.tez.runtime.api.events.CompositeRoutedDataMovementEvent
 
setVersion(int) - Method in class org.apache.tez.runtime.api.events.DataMovementEvent
 
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
Specifies a VertexManagerPlugin for the vertex.
setVertexParallelism(int, VertexLocationHint, Map<String, EdgeManagerPluginDescriptor>, Map<String, InputSpecUpdate>) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
Deprecated.
setWriteAllCounters(boolean) - Method in class org.apache.tez.common.counters.AbstractCounters
Set the "writeAllCounters" option to true or false
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.

T

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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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_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(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.
TezUtils() - Constructor for class org.apache.tez.common.TezUtils
 
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
 
tryKillDAG() - Method in class org.apache.tez.dag.api.client.DAGClient
Kill a running DAG

U

unblacklistNode(NodeId) - Method in class org.apache.tez.serviceplugins.api.TaskScheduler
Indication to a source that a node has been un-blacklisted, and can be used from subsequent allocations
union(Object, Object) - Method in interface org.apache.tez.common.ContainerSignatureMatcher
Do a union of 2 signatures Pre-condition.
UserPayload - Class in org.apache.tez.dag.api
Wrapper class to hold user payloads Provides a version to help in evolving the payloads
userPayload - Variable in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
 

V

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
Describes the VertexManagerPlugin
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
 

W

waitForAllInputsReady(Collection<Input>) - Method in interface org.apache.tez.runtime.api.ProcessorContext
Blocking call which returns only after all of the specified Inputs are ready for consumption.
waitForAllInputsReady(Collection<Input>, long) - Method in interface org.apache.tez.runtime.api.ProcessorContext
Blocking call which returns only after all of the specified Inputs are ready for consumption with timeout.
waitForAnyInputReady(Collection<Input>) - Method in interface org.apache.tez.runtime.api.ProcessorContext
Blocking call which returns when any of the specified Inputs is ready for consumption.
waitForAnyInputReady(Collection<Input>, long) - Method in interface org.apache.tez.runtime.api.ProcessorContext
Blocking call which returns when any of the specified Inputs is ready for consumption.
waitForCompletion() - Method in class org.apache.tez.dag.api.client.DAGClient
Wait forever for DAG to complete without printing any vertex statuses
waitForCompletion(long) - Method in class org.apache.tez.dag.api.client.DAGClient
Wait for DAG to complete without printing any vertex statuses
waitForCompletionWithStatusUpdates(Set<StatusGetOpts>) - Method in class org.apache.tez.dag.api.client.DAGClient
Wait for DAG to complete and periodically print *all* vertices' status.
waitTillReady() - Method in class org.apache.tez.client.TezClient
Wait till the DAG is ready to be submitted.
waitTillReady(long, TimeUnit) - Method in class org.apache.tez.client.TezClient
Wait till the DAG is ready to be submitted.
write(DataOutput) - Method in class org.apache.tez.common.counters.AbstractCounters
Write the set of groups.
write(DataOutput) - Method in class org.apache.tez.dag.api.EntityDescriptor
 
Writer - Class in org.apache.tez.runtime.api
A Writer represents the data being written by an Output It encapsulates the data type etc of the data being provided by the Output E.g.
Writer() - Constructor for class org.apache.tez.runtime.api.Writer
 

Y

YARN_ATS_ACL_DAG_DOMAIN_ID - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
YARN_ATS_ACL_DOMAINS_AUTO_CREATE - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
YARN_ATS_ACL_DOMAINS_AUTO_CREATE_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
YARN_ATS_ACL_SESSION_DOMAIN_ID - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
YARN_ATS_EVENT_FLUSH_TIMEOUT_MILLIS - Static variable in class org.apache.tez.dag.api.TezConfiguration
Int value.
YARN_ATS_EVENT_FLUSH_TIMEOUT_MILLIS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
YARN_ATS_MAX_EVENTS_PER_BATCH - Static variable in class org.apache.tez.dag.api.TezConfiguration
Int value.
YARN_ATS_MAX_EVENTS_PER_BATCH_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
YARN_ATS_MAX_POLLING_TIME_PER_EVENT - Static variable in class org.apache.tez.dag.api.TezConfiguration
Int value.
YARN_ATS_MAX_POLLING_TIME_PER_EVENT_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
 
A B C D E F G H I K L M N O P R S T U V W Y 
Skip navigation links

Copyright © 2019 Apache Software Foundation. All rights reserved.