public class TezTask extends Task<TezWork>
| Modifier and Type | Class and Description |
|---|---|
class |
TezTask.SyncDagClient
DAG client that does dumb global sync on all the method calls;
Tez DAG client is not thread safe and getting the 2nd one is not recommended.
|
Task.FeedType, Task.TaskStateBACKUP_COMMON_JOIN, backupChildrenTasks, backupTask, childTasks, clonedConf, COMMON_JOIN, conf, console, CONVERTED_MAPJOIN, CONVERTED_MAPJOIN_LOCAL, CONVERTED_SORTMERGEJOIN, driverContext, feedSubscribers, HINTED_MAPJOIN, HINTED_MAPJOIN_LOCAL, id, jobID, LOG, MAPJOIN_ONLY_NOBACKUP, NO_TAG, parentTasks, queryDisplay, queryPlan, queryState, rootTask, taskCounters, taskHandle, taskTag, work| Modifier and Type | Method and Description |
|---|---|
int |
execute(DriverContext driverContext)
This method is overridden in each Task.
|
Collection<MapWork> |
getMapWork() |
String |
getName()
Gets the name of the node.
|
Operator<? extends OperatorDesc> |
getReducer(MapWork mapWork) |
org.apache.tez.common.counters.TezCounters |
getTezCounters() |
org.apache.hadoop.hive.ql.plan.api.StageType |
getType()
Should be overridden to return the type of the specific task among the types in StageType.
|
boolean |
isMapRedTask() |
void |
shutdown() |
void |
updateTaskMetrics(Metrics metrics)
Provide metrics on the type and number of tasks executed by the HiveServer
|
addDependentTask, canExecuteInParallel, cloneConf, done, equals, executeTask, findLeafs, getAndInitBackupTask, getBackupChildrenTasks, getBackupTask, getChildren, getChildTasks, getCounters, getDependentTasks, getDiagnosticsMessage, getDriverContext, getExternalHandle, getFeedSubscribers, getHive, getId, getInitialized, getJobID, getNumChild, getNumParent, getParentTasks, getQueryPlan, getQueryState, getQueued, getStatusMessage, getTaskHandle, getTaskState, getTaskTag, getTopOperators, getTxnMgr, getWork, hashCode, hasReduce, initialize, isFetchSource, isLocalMode, isMapRedLocalTask, isNotInitialized, isRootTask, isRunnable, pushFeed, receiveFeed, removeDependentTask, removeFromChildrenTasks, requireLock, setBackupChildrenTasks, setBackupTask, setChildTasks, setConf, setConsole, setDiagnosticMessage, setDone, setDriverContext, setException, setFeedSubscribers, setFetchSource, setId, setInitialized, setLocalMode, setParentTasks, setQueryDisplay, setQueryPlan, setQueued, setRootTask, setStarted, setState, setStatusMessage, setTaskTag, setWork, started, subscribeFeed, toString, updateStatusInQueryDisplaypublic TezTask()
public TezTask(DagUtils utils)
public org.apache.tez.common.counters.TezCounters getTezCounters()
public int execute(DriverContext driverContext)
Taskpublic void updateTaskMetrics(Metrics metrics)
TaskupdateTaskMetrics in class Task<TezWork>public boolean isMapRedTask()
isMapRedTask in class Task<TezWork>public org.apache.hadoop.hive.ql.plan.api.StageType getType()
Taskpublic String getName()
Nodepublic Collection<MapWork> getMapWork()
getMapWork in class Task<TezWork>public Operator<? extends OperatorDesc> getReducer(MapWork mapWork)
getReducer in class Task<TezWork>Copyright © 2019 The Apache Software Foundation. All Rights Reserved.