public class ExplainTask extends Task<ExplainWork> implements Serializable
| Modifier and Type | Class and Description |
|---|---|
class |
ExplainTask.MethodComparator
MethodComparator.
|
Task.FeedType, Task.TaskState| Modifier and Type | Field and Description |
|---|---|
static String |
EXPL_COLUMN_NAME |
protected org.slf4j.Logger |
LOG |
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 |
|---|
ExplainTask() |
| Modifier and Type | Method and Description |
|---|---|
boolean |
canExecuteInParallel() |
int |
execute(DriverContext driverContext)
This method is overridden in each Task.
|
org.json.JSONObject |
getJSONLogicalPlan(PrintStream out,
ExplainWork work) |
org.json.JSONObject |
getJSONPlan(PrintStream out,
ExplainWork work) |
org.json.JSONObject |
getJSONPlan(PrintStream out,
List<Task<?>> tasks,
Task<?> fetchTask,
boolean jsonOutput,
boolean isExtended,
boolean appendTaskType) |
String |
getName()
Gets the name of the node.
|
static List<org.apache.hadoop.hive.metastore.api.FieldSchema> |
getResultSchema() |
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.
|
String |
outputAST(String treeString,
PrintStream out,
boolean jsonOutput,
int indent) |
org.json.JSONObject |
outputDependencies(PrintStream out,
boolean jsonOutput,
boolean appendTaskType,
List<Task> tasks) |
org.json.JSONObject |
outputStagePlans(PrintStream out,
List<Task> tasks,
boolean jsonOutput,
boolean isExtended) |
addDependentTask, 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, getTopOperators, getTxnMgr, getWork, hashCode, hasReduce, initialize, isFetchSource, isLocalMode, isMapRedLocalTask, isMapRedTask, 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, shutdown, started, subscribeFeed, toString, updateStatusInQueryDisplay, updateTaskMetricspublic static final String EXPL_COLUMN_NAME
protected final org.slf4j.Logger LOG
public org.json.JSONObject getJSONLogicalPlan(PrintStream out, ExplainWork work) throws Exception
Exceptionpublic org.json.JSONObject getJSONPlan(PrintStream out, ExplainWork work) throws Exception
Exceptionpublic org.json.JSONObject getJSONPlan(PrintStream out, List<Task<?>> tasks, Task<?> fetchTask, boolean jsonOutput, boolean isExtended, boolean appendTaskType) throws Exception
Exceptionpublic int execute(DriverContext driverContext)
Taskexecute in class Task<ExplainWork>public String outputAST(String treeString, PrintStream out, boolean jsonOutput, int indent) throws org.json.JSONException
org.json.JSONExceptionpublic org.json.JSONObject outputDependencies(PrintStream out, boolean jsonOutput, boolean appendTaskType, List<Task> tasks) throws Exception
Exceptionpublic org.json.JSONObject outputStagePlans(PrintStream out, List<Task> tasks, boolean jsonOutput, boolean isExtended) throws Exception
Exceptionpublic org.apache.hadoop.hive.ql.plan.api.StageType getType()
TaskgetType in class Task<ExplainWork>public String getName()
Nodepublic static List<org.apache.hadoop.hive.metastore.api.FieldSchema> getResultSchema()
public boolean canExecuteInParallel()
canExecuteInParallel in class Task<ExplainWork>Copyright © 2019 The Apache Software Foundation. All Rights Reserved.