- cacheForDAG(String, Object) - Method in interface org.apache.tez.runtime.api.ObjectRegistry
-
Insert or update object into the registry with DAG life-cycle.
- cacheForSession(String, Object) - Method in interface org.apache.tez.runtime.api.ObjectRegistry
-
Insert or update object into the registry with Session life-cycle.
- cacheForVertex(String, Object) - Method in interface org.apache.tez.runtime.api.ObjectRegistry
-
Insert or update object into the registry with Vertex life-cycle.
- CallerContext - Class in org.apache.tez.client
-
- canCommit() - Method in interface org.apache.tez.runtime.api.ProcessorContext
-
Check whether this attempt can commit its output
- clearAppMasterLocalFiles() - Method in class org.apache.tez.client.TezClient
-
- close() - Method in interface org.apache.tez.runtime.api.InputFrameworkInterface
-
Closes the Input
- close() - Method in interface org.apache.tez.runtime.api.OutputFrameworkInterface
-
Closes the Output
- close() - Method in interface org.apache.tez.runtime.api.ProcessorFrameworkInterface
-
Closes the Processor
- commitOutput() - Method in class org.apache.tez.runtime.api.OutputCommitter
-
For committing the output after successful completion of tasks that write
the output.
- CompositeDataMovementEvent - Class in org.apache.tez.runtime.api.events
-
A convenience class to specify multiple DataMovementEvents which share the
same payload.
- contextAsSimpleString() - Method in class org.apache.tez.client.CallerContext
-
- convertToHistoryText(String, Configuration) - Static method in class org.apache.tez.common.TezUtils
-
- convertToHistoryText(Configuration) - Static method in class org.apache.tez.common.TezUtils
-
- count - Variable in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- countCounters() - Method in class org.apache.tez.common.counters.AbstractCounters
-
Returns the total number of counters, by summing the number of counters
in each group.
- CounterGroup - Interface in org.apache.tez.common.counters
-
A group of
TezCounter
s that logically belong together.
- CounterGroupBase<T extends TezCounter> - Interface in org.apache.tez.common.counters
-
The common counter group interface.
- create(String, String, String, String) - Static method in class org.apache.tez.client.CallerContext
-
Instantiate the Caller Context
- create(String, String) - Static method in class org.apache.tez.client.CallerContext
-
Instantiate the Caller Context
- create(String, TezConfiguration) - Static method in class org.apache.tez.client.TezClient
-
Create a new TezClient.
- create(String, TezConfiguration, Map<String, LocalResource>, Credentials) - Static method in class org.apache.tez.client.TezClient
-
Create a new TezClient.
- create(String, TezConfiguration, boolean) - Static method in class org.apache.tez.client.TezClient
-
Create a new TezClient with AM session mode set explicitly.
- create(String, TezConfiguration, boolean, Map<String, LocalResource>, Credentials) - Static method in class org.apache.tez.client.TezClient
-
Create a new TezClient with AM session mode set explicitly.
- create(String) - Static method in class org.apache.tez.dag.api.DAG
-
Create a DAG with the specified name.
- create(OutputDescriptor, OutputCommitterDescriptor, Credentials) - Static method in class org.apache.tez.dag.api.DataSinkDescriptor
-
- create(InputDescriptor, InputInitializerDescriptor, Credentials) - Static method in class org.apache.tez.dag.api.DataSourceDescriptor
-
- create(InputDescriptor, InputInitializerDescriptor, int, Credentials, VertexLocationHint, Map<String, LocalResource>) - Static method in class org.apache.tez.dag.api.DataSourceDescriptor
-
- create(Vertex, Vertex, EdgeProperty) - Static method in class org.apache.tez.dag.api.Edge
-
Creates an edge between the specified vertices.
- create(String) - Static method in class org.apache.tez.dag.api.EdgeManagerPluginDescriptor
-
- create(EdgeProperty.DataMovementType, EdgeProperty.DataSourceType, EdgeProperty.SchedulingType, OutputDescriptor, InputDescriptor) - Static method in class org.apache.tez.dag.api.EdgeProperty
-
Setup an EdgeProperty which makes use of one of the provided EdgeProperty.DataMovementType
s
- create(EdgeManagerPluginDescriptor, EdgeProperty.DataSourceType, EdgeProperty.SchedulingType, OutputDescriptor, InputDescriptor) - Static method in class org.apache.tez.dag.api.EdgeProperty
-
Setup an Edge which uses a custom EdgeManager
- create(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(String, int, Resource) - Static method in class org.apache.tez.dag.api.PreWarmVertex
-
- create(String) - Static method in class org.apache.tez.dag.api.ProcessorDescriptor
-
- create(ByteBuffer) - Static method in class org.apache.tez.dag.api.UserPayload
-
Create a UserPayload instance which encapsulates a
ByteBuffer
.
- create(ByteBuffer, int) - Static method in class org.apache.tez.dag.api.UserPayload
-
Create an explicitly versioned UserPayload instance which encapsulates a
ByteBuffer
.
- create(String, ProcessorDescriptor, int, Resource) - Static method in class org.apache.tez.dag.api.Vertex
-
Create a new vertex with the given name.
- create(String, ProcessorDescriptor) - Static method in class org.apache.tez.dag.api.Vertex
-
Create a new vertex with the given name.
- create(String, ProcessorDescriptor, int) - Static method in class org.apache.tez.dag.api.Vertex
-
Create a new vertex with the given name and parallelism.
- create(List<TaskLocationHint>) - Static method in class org.apache.tez.dag.api.VertexLocationHint
-
- create(String) - Static method in class org.apache.tez.dag.api.VertexManagerPluginDescriptor
-
- create(int, int, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- create(int, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.DataMovementEvent
-
User Event constructor for
Output
s
- create(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
- 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
-
- createConfigBuilder(Configuration) - Static method in class org.apache.tez.dag.api.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, Map<String, String>, JavaOptsChecker) - Method in class org.apache.tez.dag.api.DAG
-
- 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.
- createUserPayloadFromConf(Configuration) - Static method in class org.apache.tez.common.TezUtils
-
- createVertexGroup(String, Vertex...) - Method in class org.apache.tez.dag.api.DAG
-
Create a group of vertices that share a common output.
- createWithObjectPayload(int, Object) - Static method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- createWithSerializedPayload(int, ByteBuffer) - Static method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
Provide a serialized form of the payload
- get(String) - Method in interface org.apache.tez.runtime.api.ObjectRegistry
-
Return the object associated with the provided key
- getAdditionalLocalFiles() - Method in class org.apache.tez.dag.api.DataSourceDescriptor
-
Get the list of additional local files which were specified during creation.
- getAffinitizedTask() - Method in class org.apache.tez.dag.api.TaskLocationHint
-
- getAllNumPhysicalInputs() - Method in class org.apache.tez.runtime.api.InputSpecUpdate
-
- getAMProxy(ApplicationId) - Method in class org.apache.tez.client.TezClient
-
- 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
- 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
-
- getClientName() - Method in class org.apache.tez.client.TezClient
-
Get the name of the client
- getConf() - Method in class org.apache.tez.dag.api.Vertex
-
- getContext() - Method in class org.apache.tez.client.CallerContext
-
- getContext() - Method in class org.apache.tez.dag.api.EdgeManagerPlugin
-
- getContext() - Method in class org.apache.tez.dag.api.EdgeManagerPluginOnDemand
-
- getContext() - Method in class org.apache.tez.dag.api.VertexManagerPlugin
-
- getContext() - Method in class org.apache.tez.runtime.api.AbstractLogicalInput
-
Return ahe
InputContext
for this specific instance of
the LogicalInput
- getContext() - Method in class org.apache.tez.runtime.api.AbstractLogicalIOProcessor
-
- getContext() - Method in class org.apache.tez.runtime.api.AbstractLogicalOutput
-
Return the
OutputContext
for this specific instance of
the LogicalOutput
- getContext() - Method in class org.apache.tez.runtime.api.InputInitializer
-
- getContext() - Method in class org.apache.tez.runtime.api.MergedLogicalInput
-
- getContext() - Method in class org.apache.tez.runtime.api.OutputCommitter
-
- getCount() - Method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- 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
-
- getCredentials() - Method in class org.apache.tez.dag.api.DataSourceDescriptor
-
Returns any credentials needed to access this data source.
- 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.
- 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
-
- getEdgeProperty() - Method in class org.apache.tez.dag.api.GroupInputEdge
-
- getEdgeSource() - Method in class org.apache.tez.dag.api.EdgeProperty
-
- 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
-
- 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
-
- 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
-
- 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
- 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
- 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.
- 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
-
- getRacks() - Method in class org.apache.tez.dag.api.TaskLocationHint
-
- getReader() - Method in interface org.apache.tez.runtime.api.Input
-
Gets an instance of the
Reader
for this
Output
- getRunningTaskCount() - Method in class org.apache.tez.dag.api.client.Progress
-
- 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
- getSourceIndex() - Method in class org.apache.tez.runtime.api.events.DataMovementEvent
-
- getSourceIndex() - Method in class org.apache.tez.runtime.api.events.InputDataInformationEvent
-
- getSourceIndexStart() - Method in class org.apache.tez.runtime.api.events.CompositeDataMovementEvent
-
- getSourceVertexName() - Method in interface org.apache.tez.dag.api.EdgeManagerPluginContext
-
Returns the source vertex name
- getSourceVertexName() - Method in class org.apache.tez.runtime.api.events.InputInitializerEvent
-
Returns the name of the vertex which generated the event.
- getSourceVertexName() - Method in interface org.apache.tez.runtime.api.InputContext
-
Get the Vertex Name of the Source that generated data for this Input
- getSourceVertexNumTasks() - Method in interface org.apache.tez.dag.api.EdgeManagerPluginContext
-
Returns the number of tasks in the source vertex
- getState() - Method in class org.apache.tez.dag.api.client.DAGStatus
-
- getState() - Method in class org.apache.tez.dag.api.client.VertexStatus
-
- getStatisticsReporter() - Method in interface org.apache.tez.runtime.api.InputContext
-
- getStatisticsReporter() - Method in interface org.apache.tez.runtime.api.OutputContext
-
- getSucceededTaskCount() - Method in class org.apache.tez.dag.api.client.Progress
-
- getTargetIndex() - Method in class org.apache.tez.runtime.api.events.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
- getTaskContainer(String, Integer) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Deprecated.
- 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
- 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.
- 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.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.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
-
- getVertexIndex() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
Get Vertex Index in the DAG
- getVertexInputNames() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the names of the non-vertex inputs of this vertex.
- getVertexName() - Method in class org.apache.tez.dag.api.event.VertexStateUpdate
-
Get the name of the vertex for which the state has changed
- getVertexName() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the name of the vertex
- getVertexName() - Method in interface org.apache.tez.runtime.api.OutputCommitterContext
-
Get the name of the Vertex
- getVertexNumTasks(String) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the number of tasks in the given vertex
- getVertexNumTasks(String) - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the number of tasks in the given vertex
- getVertexParallelism() - Method in interface org.apache.tez.runtime.api.TaskContext
-
Get the vertex parallelism of the vertex to which this task belongs.
- getVertexProgress() - Method in class org.apache.tez.dag.api.client.DAGStatus
-
Get the progress of a vertex in the DAG
- getVertexState() - Method in class org.apache.tez.dag.api.event.VertexStateUpdate
-
Get the updated state
- getVertexStatistics(String) - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
- getVertexStatus(String, Set<StatusGetOpts>) - Method in class org.apache.tez.dag.api.client.DAGClient
-
Get the status of a Vertex of a DAG
- getVertexTaskResource() - Method in interface org.apache.tez.dag.api.VertexManagerPluginContext
-
Get the resource allocated to a task of this vertex
- getVertexTaskResource() - Method in interface org.apache.tez.runtime.api.InputInitializerContext
-
Get the resource allocated to a task of this vertex
- 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.
- 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.
- sendEvents(List<Event>) - Method in interface org.apache.tez.runtime.api.TaskContext
-
Send Events to the AM and/or dependent Vertices
- serializeToConfiguration(Configuration) - Method in class org.apache.tez.common.security.DAGAccessControls
-
- 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.
- setAppMasterCredentials(Credentials) - Method in class org.apache.tez.client.TezClient
-
Set security credentials to be used inside the app master, if needed.
- setBlob(String) - Method in class org.apache.tez.client.CallerContext
-
- setCallerContext(CallerContext) - Method in class org.apache.tez.dag.api.DAG
-
Set the Context in which Tez is being called.
- setCallerIdAndType(String, String) - Method in class org.apache.tez.client.CallerContext
-
- setConf(String, String) - Method in class org.apache.tez.dag.api.DAG
-
This is currently used to setup additional configuration parameters which will be available
in the DAG configuration used in the AppMaster.
- setConf(String, String) - Method in class org.apache.tez.dag.api.Vertex
-
This is currently used to setup additional configuration parameters which will be available
in the Vertex specific configuration used in the AppMaster.
- setConstituentInputIsReady(Input) - Method in class org.apache.tez.runtime.api.MergedLogicalInput
-
Used by the framework to inform the MergedInput that one of it's constituent Inputs is ready.
- setContext(String) - Method in class org.apache.tez.client.CallerContext
-
- setCredentials(Credentials) - Method in class org.apache.tez.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)
- 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.
- 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
- 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.
- setSourceVertexName(String) - Method in class org.apache.tez.runtime.api.events.InputInitializerEvent
-
- 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.
- setUpHistoryAclManager(HistoryACLPolicyManager) - Method in class org.apache.tez.client.TezClient
-
- 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.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
-
- 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
- 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.
- 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.
- submitDAG(DAG) - Method in class org.apache.tez.client.TezClient
-
Submit a DAG.
- TASK_HEARTBEAT_TIMEOUT_CHECK_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TASK_HEARTBEAT_TIMEOUT_CHECK_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- TASK_HEARTBEAT_TIMEOUT_MS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
Int value.
- TASK_HEARTBEAT_TIMEOUT_MS_DEFAULT - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
- 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.
- 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_CLIENT_AM_PORT_RANGE - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value.
- 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_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_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_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_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_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_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_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_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_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_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_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_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_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_LIB_URIS - Static variable in class org.apache.tez.dag.api.TezConfiguration
-
String value to a file path.
- 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_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_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
-
- 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
-
- 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.VertexGroup
-
- 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
-
- tryKillDAG() - Method in class org.apache.tez.dag.api.client.DAGClient
-
Kill a running DAG