public class FetchTask extends Task<FetchWork> implements Serializable
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, MAPJOIN_ONLY_NOBACKUP, NO_TAG, parentTasks, queryDisplay, queryPlan, queryState, rootTask, taskCounters, taskHandle, taskTag, work| Constructor and Description |
|---|
FetchTask() |
| Modifier and Type | Method and Description |
|---|---|
boolean |
canExecuteInParallel() |
void |
clearFetch()
Clear the Fetch Operator.
|
int |
execute(DriverContext driverContext)
This method is overridden in each Task.
|
boolean |
fetch(List res) |
int |
getMaxRows()
Return the maximum number of rows returned by fetch.
|
String |
getName()
Gets the name of the node.
|
TableDesc |
getTblDesc()
Return the tableDesc of the fetchWork.
|
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 ctx,
CompilationOpContext opContext) |
boolean |
isFetchFrom(FileSinkDesc fs) |
void |
setMaxRows(int maxRows)
Set the maximum number of rows returned by fetch.
|
void |
setValidWriteIdList(String writeIdStr) |
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, 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 void setValidWriteIdList(String writeIdStr)
public void initialize(QueryState queryState, QueryPlan queryPlan, DriverContext ctx, CompilationOpContext opContext)
initialize in class Task<FetchWork>public int execute(DriverContext driverContext)
Taskpublic TableDesc getTblDesc()
public int getMaxRows()
public void setMaxRows(int maxRows)
public boolean fetch(List res) throws IOException
IOExceptionpublic boolean isFetchFrom(FileSinkDesc fs)
public org.apache.hadoop.hive.ql.plan.api.StageType getType()
Taskpublic String getName()
Nodepublic void clearFetch()
throws HiveException
HiveExceptionpublic boolean canExecuteInParallel()
canExecuteInParallel in class Task<FetchWork>Copyright © 2019 The Apache Software Foundation. All Rights Reserved.