public class MapredLocalTask extends Task<MapredLocalWork> implements Serializable
Task.FeedType
Modifier and Type | Field and Description |
---|---|
protected HadoopJobExecHelper |
jobExecHelper |
static org.apache.commons.logging.Log |
l4j |
static MemoryMXBean |
memoryMXBean |
BACKUP_COMMON_JOIN, backupChildrenTasks, backupTask, childTasks, clonedConf, COMMON_JOIN, conf, console, CONVERTED_MAPJOIN, CONVERTED_MAPJOIN_LOCAL, CONVERTED_SORTMERGEJOIN, db, driverContext, feedSubscribers, HINTED_MAPJOIN, HINTED_MAPJOIN_LOCAL, id, initialized, isdone, jobID, MAPJOIN_ONLY_NOBACKUP, NO_TAG, parentTasks, queryPlan, queued, rootTask, started, 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() |
StageType |
getType()
Should be overridden to return the type of the specific task among the types in StageType.
|
void |
initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext driverContext) |
boolean |
isMapRedLocalTask() |
static String |
now() |
boolean |
requireLock() |
void |
setExecContext(ExecMapperContext execContext) |
void |
shutdown() |
void |
startForward(String bigTableBucket) |
addDependentTask, cloneConf, done, equals, executeTask, getAndInitBackupTask, getBackupChildrenTasks, getBackupTask, getChildren, getChildTasks, getCounters, getDependentTasks, getFeedSubscribers, getId, getInitialized, getJobID, getMapWork, getNumChild, getNumParent, getParentTasks, getQueryPlan, getQueued, getReducer, getTaskHandle, getTaskTag, getWork, hashCode, hasReduce, ifRetryCmdWhenFail, isFetchSource, isLocalMode, isMapRedTask, isRootTask, isRunnable, pushFeed, receiveFeed, removeDependentTask, removeFromChildrenTasks, setBackupChildrenTasks, setBackupTask, setChildTasks, setConsole, setDone, setException, setFeedSubscribers, setFetchSource, setId, setInitialized, setLocalMode, setParentTasks, setQueryPlan, setQueued, setRetryCmdWhenFail, setRootTask, setStarted, setTaskTag, setWork, started, subscribeFeed, toString
protected HadoopJobExecHelper jobExecHelper
public static final transient org.apache.commons.logging.Log l4j
public static MemoryMXBean memoryMXBean
public MapredLocalTask()
public MapredLocalTask(MapredLocalWork plan, org.apache.hadoop.mapred.JobConf job, boolean isSilent) throws HiveException
HiveException
public void setExecContext(ExecMapperContext execContext)
public void initialize(HiveConf conf, QueryPlan queryPlan, DriverContext driverContext)
initialize
in class Task<MapredLocalWork>
public static String now()
public boolean requireLock()
requireLock
in class Task<MapredLocalWork>
public int execute(DriverContext driverContext)
Task
execute
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()
Node
public StageType getType()
Task
getType
in class Task<MapredLocalWork>
public void shutdown()
shutdown
in class Task<MapredLocalWork>
Copyright © 2017 The Apache Software Foundation. All rights reserved.