public class DDLTask extends Task<DDLWork> implements Serializable
Task.FeedType, Task.TaskState| Modifier and Type | Field and Description |
|---|---|
static String |
DATABASE_PATH_SUFFIX
Make qualified location for a database .
|
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 |
|---|
DDLTask() |
| Modifier and Type | Method and Description |
|---|---|
static StringBuilder |
appendSerdeParams(StringBuilder builder,
Map<String,String> serdeParam) |
boolean |
canExecuteInParallel() |
static boolean |
doesTableNeedLocation(Table tbl) |
static void |
dumpLockInfo(DataOutputStream os,
org.apache.hadoop.hive.metastore.api.ShowLocksResponse rsp) |
int |
execute(DriverContext driverContext)
This method is overridden in each Task.
|
String |
getName()
Gets the name of the node.
|
Task<? extends Serializable> |
getSubtask() |
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) |
static void |
makeLocationQualified(String databaseName,
Table table,
HiveConf conf)
Make location in specified sd qualified.
|
boolean |
requireLock() |
int |
showColumns(Hive db,
ShowColumnsDesc showCols)
Write a list of the columns in the table to a file.
|
static void |
validateSerDe(String serdeName,
HiveConf conf)
Check if the given serde is valid.
|
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, 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 DATABASE_PATH_SUFFIX
public Task<? extends Serializable> getSubtask()
public boolean requireLock()
requireLock in class Task<DDLWork>public void initialize(QueryState queryState, QueryPlan queryPlan, DriverContext ctx, CompilationOpContext opContext)
initialize in class Task<DDLWork>public int execute(DriverContext driverContext)
Taskpublic static StringBuilder appendSerdeParams(StringBuilder builder, Map<String,String> serdeParam)
public int showColumns(Hive db, ShowColumnsDesc showCols) throws HiveException
db - The database in context.showCols - A ShowColumnsDesc for columns we're interested in.HiveException - Throws this exception if an unexpected error occurs.public static void dumpLockInfo(DataOutputStream os, org.apache.hadoop.hive.metastore.api.ShowLocksResponse rsp) throws IOException
IOExceptionpublic static void validateSerDe(String serdeName, HiveConf conf) throws HiveException
HiveExceptionpublic org.apache.hadoop.hive.ql.plan.api.StageType getType()
Taskpublic String getName()
Nodepublic static void makeLocationQualified(String databaseName, Table table, HiveConf conf) throws HiveException
databaseName - Database name.sd - Storage descriptor.name - Object name.HiveExceptionpublic static boolean doesTableNeedLocation(Table tbl)
public boolean canExecuteInParallel()
canExecuteInParallel in class Task<DDLWork>Copyright © 2019 The Apache Software Foundation. All Rights Reserved.