public class MapredLocalTask extends Task<MapredLocalWork> implements Serializable
Task.FeedType, Task.TaskState| Modifier and Type | Field and Description |
|---|---|
protected HadoopJobExecHelper |
jobExecHelper |
static org.slf4j.Logger |
l4j |
static MemoryMXBean |
memoryMXBean |
BACKUP_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, MAPJOIN_ONLY_NOBACKUP, NO_TAG, parentTasks, queryDisplay, queryPlan, queryState, rootTask, taskCounters, taskHandle, taskTag, work| Constructor and Description |
|---|
MapredLocalTask() |
MapredLocalTask(MapredLocalWork plan,
org.apache.hadoop.mapred.JobConf job,
boolean isSilent) |
| Modifier and Type | Method and Description |
|---|---|
int |
execute(DriverContext driverContext)
This method is overridden in each Task.
|
int |
executeInChildVM(DriverContext driverContext) |
int |
executeInProcess(DriverContext driverContext) |
String |
getName()
Gets the name of the node.
|
Collection<Operator<? extends OperatorDesc>> |
getTopOperators() |
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.
|
void |
initialize(QueryState queryState,
QueryPlan queryPlan,
DriverContext driverContext,
CompilationOpContext opContext) |
boolean |
isMapRedLocalTask() |
static String |
now() |
boolean |
requireLock() |
void |
setExecContext(ExecMapperContext execContext) |
void |
shutdown() |
void |
startForward(String bigTableBucket) |
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, getMapWork, getNumChild, getNumParent, getParentTasks, getQueryPlan, getQueryState, getQueued, getReducer, getStatusMessage, getTaskHandle, getTaskState, getTaskTag, getTxnMgr, getWork, hashCode, hasReduce, isFetchSource, isLocalMode, isMapRedTask, isNotInitialized, isRootTask, isRunnable, pushFeed, receiveFeed, removeDependentTask, removeFromChildrenTasks, 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, updateStatusInQueryDisplayprotected HadoopJobExecHelper jobExecHelper
public static final transient org.slf4j.Logger l4j
public static MemoryMXBean memoryMXBean
public MapredLocalTask()
public MapredLocalTask(MapredLocalWork plan, org.apache.hadoop.mapred.JobConf job, boolean isSilent) throws HiveException
HiveExceptionpublic void setExecContext(ExecMapperContext execContext)
public void updateTaskMetrics(Metrics metrics)
TaskupdateTaskMetrics in class Task<MapredLocalWork>public void initialize(QueryState queryState, QueryPlan queryPlan, DriverContext driverContext, CompilationOpContext opContext)
initialize in class Task<MapredLocalWork>public static String now()
public boolean requireLock()
requireLock in class Task<MapredLocalWork>public int execute(DriverContext driverContext)
Taskexecute in class Task<MapredLocalWork>public int executeInChildVM(DriverContext driverContext)
public int executeInProcess(DriverContext driverContext)
public boolean isMapRedLocalTask()
isMapRedLocalTask in class Task<MapredLocalWork>public Collection<Operator<? extends OperatorDesc>> getTopOperators()
getTopOperators in class Task<MapredLocalWork>public String getName()
Nodepublic org.apache.hadoop.hive.ql.plan.api.StageType getType()
TaskgetType in class Task<MapredLocalWork>public void shutdown()
shutdown in class Task<MapredLocalWork>Copyright © 2019 The Apache Software Foundation. All Rights Reserved.