public class ExecDriver extends Task<MapredWork> implements Serializable, HadoopJobExecHook
Task.FeedType
Modifier and Type | Field and Description |
---|---|
protected org.apache.hadoop.mapred.JobConf |
job |
protected HadoopJobExecHelper |
jobExecHelper |
protected static org.apache.commons.logging.Log |
LOG |
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 |
---|
ExecDriver()
Constructor when invoked from QL.
|
ExecDriver(MapredWork plan,
org.apache.hadoop.mapred.JobConf job,
boolean isSilent)
Constructor/Initialization for invocation as independent utility.
|
Modifier and Type | Method and Description |
---|---|
boolean |
checkFatalErrors(org.apache.hadoop.mapred.Counters ctrs,
StringBuilder errMsg)
Fatal errors are those errors that cannot be recovered by retries.
|
int |
execute(DriverContext driverContext)
Execute a query plan using Hadoop.
|
static String |
generateCmdLine(HiveConf hconf,
Context ctx)
Given a Hive Configuration object - generate a command line fragment for passing such
configuration information to ExecDriver.
|
static String |
getCurrentDB() |
Collection<MapWork> |
getMapWork() |
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.
|
boolean |
hasReduce() |
void |
initialize(HiveConf conf,
QueryPlan queryPlan,
DriverContext driverContext)
Initialization when invoked from QL.
|
boolean |
isMapRedTask() |
void |
logPlanProgress(SessionState ss) |
static void |
main(String[] args) |
boolean |
mapDone() |
boolean |
mapStarted() |
boolean |
reduceDone() |
boolean |
reduceStarted() |
boolean |
requireLock() |
protected void |
setInputAttributes(org.apache.hadoop.conf.Configuration conf)
Set hive input format, and input format file if necessary.
|
void |
shutdown() |
addDependentTask, cloneConf, done, equals, executeTask, getAndInitBackupTask, getBackupChildrenTasks, getBackupTask, getChildren, getChildTasks, getCounters, getDependentTasks, getFeedSubscribers, getId, getInitialized, getJobID, getNumChild, getNumParent, getParentTasks, getQueryPlan, getQueued, getReducer, getTaskHandle, getTaskTag, getWork, hashCode, ifRetryCmdWhenFail, isFetchSource, isLocalMode, isMapRedLocalTask, 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 transient org.apache.hadoop.mapred.JobConf job
public static MemoryMXBean memoryMXBean
protected HadoopJobExecHelper jobExecHelper
protected static final transient org.apache.commons.logging.Log LOG
public ExecDriver()
public ExecDriver(MapredWork plan, org.apache.hadoop.mapred.JobConf job, boolean isSilent) throws HiveException
HiveException
public boolean requireLock()
requireLock
in class Task<MapredWork>
public void initialize(HiveConf conf, QueryPlan queryPlan, DriverContext driverContext)
initialize
in class Task<MapredWork>
public boolean checkFatalErrors(org.apache.hadoop.mapred.Counters ctrs, StringBuilder errMsg)
checkFatalErrors
in interface HadoopJobExecHook
public int execute(DriverContext driverContext)
execute
in class Task<MapredWork>
protected void setInputAttributes(org.apache.hadoop.conf.Configuration conf)
public static String getCurrentDB()
public boolean mapStarted()
public boolean reduceStarted()
public boolean mapDone()
public boolean reduceDone()
public static void main(String[] args) throws IOException, HiveException
IOException
HiveException
public static String generateCmdLine(HiveConf hconf, Context ctx) throws IOException
IOException
public Collection<MapWork> getMapWork()
getMapWork
in class Task<MapredWork>
public boolean isMapRedTask()
isMapRedTask
in class Task<MapredWork>
public Collection<Operator<? extends OperatorDesc>> getTopOperators()
getTopOperators
in class Task<MapredWork>
public boolean hasReduce()
hasReduce
in class Task<MapredWork>
public StageType getType()
Task
getType
in class Task<MapredWork>
public String getName()
Node
public void logPlanProgress(SessionState ss) throws IOException
logPlanProgress
in interface HadoopJobExecHook
IOException
public void shutdown()
shutdown
in class Task<MapredWork>
Copyright © 2017 The Apache Software Foundation. All rights reserved.