Uses of Class
org.apache.hadoop.hive.ql.exec.Task

Packages that use Task
org.apache.hadoop.hive.ql   
org.apache.hadoop.hive.ql.exec Hive QL execution tasks, operators, functions and other handlers. 
org.apache.hadoop.hive.ql.history   
org.apache.hadoop.hive.ql.index   
org.apache.hadoop.hive.ql.index.bitmap   
org.apache.hadoop.hive.ql.index.compact   
org.apache.hadoop.hive.ql.io.rcfile.merge   
org.apache.hadoop.hive.ql.metadata   
org.apache.hadoop.hive.ql.optimizer   
org.apache.hadoop.hive.ql.optimizer.physical   
org.apache.hadoop.hive.ql.optimizer.physical.index   
org.apache.hadoop.hive.ql.parse   
org.apache.hadoop.hive.ql.plan   
 

Uses of Task in org.apache.hadoop.hive.ql
 

Methods in org.apache.hadoop.hive.ql that return types with arguments of type Task
 List<Task<? extends Serializable>> QTestUtil.analyzeAST(ASTNode ast)
           
 ArrayList<Task<? extends Serializable>> QueryPlan.getRootTasks()
           
 Queue<Task<? extends Serializable>> DriverContext.getRunnable()
           
 

Methods in org.apache.hadoop.hive.ql with parameters of type Task
 void DriverContext.addToRunnable(Task<? extends Serializable> tsk)
           
static boolean DriverContext.isLaunchable(Task<? extends Serializable> tsk)
          Checks if a task can be launched.
 void Driver.launchTask(Task<? extends Serializable> tsk, String queryId, boolean noName, Map<TaskResult,TaskRunner> running, String jobname, int jobs, DriverContext cxt)
          Launches a new task
 

Method parameters in org.apache.hadoop.hive.ql with type arguments of type Task
 int QTestUtil.checkPlan(String tname, List<Task<? extends Serializable>> tasks)
           
 boolean Driver.hasReduceTasks(List<Task<? extends Serializable>> tasks)
           
 void QueryPlan.setRootTasks(ArrayList<Task<? extends Serializable>> rootTasks)
           
 

Constructor parameters in org.apache.hadoop.hive.ql with type arguments of type Task
DriverContext(Queue<Task<? extends Serializable>> runnable, Context ctx)
           
 

Uses of Task in org.apache.hadoop.hive.ql.exec
 

Subclasses of Task in org.apache.hadoop.hive.ql.exec
 class ConditionalTask
          Conditional Task implementation.
 class CopyTask
          CopyTask implementation.
 class DDLTask
          DDLTask implementation.
 class ExecDriver
          ExecDriver.
 class ExplainTask
          ExplainTask implementation.
 class FetchTask
          FetchTask implementation.
 class FunctionTask
          FunctionTask.
 class MapredLocalTask
           
 class MapRedTask
          Extension of ExecDriver: - can optionally spawn a map-reduce task from a separate jvm - will make last minute adjustments to map-reduce job parameters, viz: * estimating number of reducers * estimating whether job should run locally
 class MoveTask
          MoveTask implementation.
 class StatsTask
          StatsTask implementation.
 

Fields in org.apache.hadoop.hive.ql.exec declared as Task
protected  Task<? extends Serializable> Task.backupTask
           
protected  Task<? extends Serializable> HadoopJobExecHelper.task
           
protected  Task<? extends Serializable> TaskRunner.tsk
           
 

Fields in org.apache.hadoop.hive.ql.exec with type parameters of type Task
protected  List<Task<? extends Serializable>> Task.backupChildrenTasks
           
protected  List<Task<? extends Serializable>> Task.childTasks
           
protected  List<Task<? extends Serializable>> Task.feedSubscribers
           
protected  List<Task<? extends Serializable>> Task.parentTasks
           
 Class<? extends Task<T>> TaskFactory.taskTuple.taskClass
           
 

Methods in org.apache.hadoop.hive.ql.exec that return Task
static
<T extends Serializable>
Task<T>
TaskFactory.get(Class<T> workClass, HiveConf conf)
           
static
<T extends Serializable>
Task<T>
TaskFactory.get(T work, HiveConf conf, Task<? extends Serializable>... tasklist)
           
 Task<? extends Serializable> Task.getAndInitBackupTask()
           
static
<T extends Serializable>
Task<T>
TaskFactory.getAndMakeChild(T work, HiveConf conf, Task<? extends Serializable>... tasklist)
           
 Task<? extends Serializable> Task.getBackupTask()
           
 Task<? extends Serializable> TaskRunner.getTask()
           
 

Methods in org.apache.hadoop.hive.ql.exec that return types with arguments of type Task
 List<Task<? extends Serializable>> Task.getBackupChildrenTasks()
           
 List<Task<? extends Serializable>> Task.getChildTasks()
           
 List<Task<? extends Serializable>> Task.getDependentTasks()
          The default dependent tasks are just child tasks, but different types could implement their own (e.g.
 List<Task<? extends Serializable>> ConditionalTask.getDependentTasks()
           
 List<Task<? extends Serializable>> Task.getFeedSubscribers()
           
 List<Task<? extends Serializable>> ConditionalTask.getListTasks()
           
 List<Task<? extends Serializable>> Task.getParentTasks()
           
 

Methods in org.apache.hadoop.hive.ql.exec with parameters of type Task
 boolean Task.addDependentTask(Task<? extends Serializable> dependent)
          Add a dependent task on the current task.
 boolean ConditionalTask.addDependentTask(Task<? extends Serializable> dependent)
          Add a dependent task on the current conditional task.
static
<T extends Serializable>
Task<T>
TaskFactory.get(T work, HiveConf conf, Task<? extends Serializable>... tasklist)
           
static
<T extends Serializable>
Task<T>
TaskFactory.getAndMakeChild(T work, HiveConf conf, Task<? extends Serializable>... tasklist)
           
static void TaskFactory.makeChild(Task<?> ret, Task<? extends Serializable>... tasklist)
           
static void TaskFactory.makeChild(Task<?> ret, Task<? extends Serializable>... tasklist)
           
 void Task.removeDependentTask(Task<? extends Serializable> dependent)
          Remove the dependent task.
static void Utilities.reworkMapRedWork(Task<? extends Serializable> task, boolean reworkMapredWork, HiveConf conf)
          The check here is kind of not clean.
static void Utilities.serializeTasks(Task<? extends Serializable> t, OutputStream out)
          Serialize a single Task.
 void Task.setBackupTask(Task<? extends Serializable> backupTask)
           
 void Task.subscribeFeed(Task<? extends Serializable> publisher)
          Subscribe the feed of publisher.
 

Method parameters in org.apache.hadoop.hive.ql.exec with type arguments of type Task
static List<ExecDriver> Utilities.getMRTasks(List<Task<? extends Serializable>> tasks)
           
static org.json.JSONObject ExplainTask.outputDependencies(PrintStream out, boolean jsonOutput, List<Task<? extends Serializable>> rootTasks, int indent)
           
static org.json.JSONObject ExplainTask.outputStagePlans(PrintStream out, ExplainWork work, List<Task<? extends Serializable>> rootTasks, int indent)
           
 void Task.setBackupChildrenTasks(List<Task<? extends Serializable>> backupChildrenTasks)
           
 void Task.setChildTasks(List<Task<? extends Serializable>> childTasks)
           
 void Task.setFeedSubscribers(List<Task<? extends Serializable>> s)
           
 void ConditionalTask.setListTasks(List<Task<? extends Serializable>> listTasks)
           
 void Task.setParentTasks(List<Task<? extends Serializable>> parentTasks)
           
 

Constructors in org.apache.hadoop.hive.ql.exec with parameters of type Task
HadoopJobExecHelper(org.apache.hadoop.mapred.JobConf job, SessionState.LogHelper console, Task<? extends Serializable> task, HadoopJobExecHook hookCallBack)
           
TaskRunner(Task<? extends Serializable> tsk, TaskResult result)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.exec with type arguments of type Task
TaskFactory.taskTuple(Class<T> workClass, Class<? extends Task<T>> taskClass)
           
 

Uses of Task in org.apache.hadoop.hive.ql.history
 

Methods in org.apache.hadoop.hive.ql.history with parameters of type Task
 void HiveHistory.endTask(String queryId, Task<? extends Serializable> task)
          Called at the end of a task.
 void HiveHistory.progressTask(String queryId, Task<? extends Serializable> task)
          Called at the end of a task.
 void HiveHistory.startTask(String queryId, Task<? extends Serializable> task, String taskName)
          Called at the start of a task.
 

Uses of Task in org.apache.hadoop.hive.ql.index
 

Subclasses of Task in org.apache.hadoop.hive.ql.index
 class IndexMetadataChangeTask
           
 

Methods in org.apache.hadoop.hive.ql.index that return Task
protected abstract  Task<?> TableBasedIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs, Set<WriteEntity> outputs, List<FieldSchema> indexField, boolean partitioned, PartitionDesc indexTblPartDesc, String indexTableName, PartitionDesc baseTablePartDesc, String baseTableName, String dbName)
           
protected  Task<?> AggregateIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs, Set<WriteEntity> outputs, List<FieldSchema> indexField, boolean partitioned, PartitionDesc indexTblPartDesc, String indexTableName, PartitionDesc baseTablePartDesc, String baseTableName, String dbName)
           
 

Methods in org.apache.hadoop.hive.ql.index that return types with arguments of type Task
 List<Task<?>> TableBasedIndexHandler.generateIndexBuildTaskList(Table baseTbl, Index index, List<Partition> indexTblPartitions, List<Partition> baseTblPartitions, Table indexTbl, Set<ReadEntity> inputs, Set<WriteEntity> outputs)
           
 List<Task<?>> HiveIndexHandler.generateIndexBuildTaskList(Table baseTbl, Index index, List<Partition> indexTblPartitions, List<Partition> baseTblPartitions, Table indexTbl, Set<ReadEntity> inputs, Set<WriteEntity> outputs)
          Requests that the handler generate a plan for building the index; the plan should read the base table and write out the index representation.
 List<Task<? extends Serializable>> HiveIndexQueryContext.getQueryTasks()
           
 

Method parameters in org.apache.hadoop.hive.ql.index with type arguments of type Task
 void HiveIndexQueryContext.setQueryTasks(List<Task<? extends Serializable>> indexQueryTasks)
           
 

Uses of Task in org.apache.hadoop.hive.ql.index.bitmap
 

Methods in org.apache.hadoop.hive.ql.index.bitmap that return Task
protected  Task<?> BitmapIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs, Set<WriteEntity> outputs, List<FieldSchema> indexField, boolean partitioned, PartitionDesc indexTblPartDesc, String indexTableName, PartitionDesc baseTablePartDesc, String baseTableName, String dbName)
           
 

Uses of Task in org.apache.hadoop.hive.ql.index.compact
 

Methods in org.apache.hadoop.hive.ql.index.compact that return Task
protected  Task<?> CompactIndexHandler.getIndexBuilderMapRedTask(Set<ReadEntity> inputs, Set<WriteEntity> outputs, List<FieldSchema> indexField, boolean partitioned, PartitionDesc indexTblPartDesc, String indexTableName, PartitionDesc baseTablePartDesc, String baseTableName, String dbName)
           
 

Uses of Task in org.apache.hadoop.hive.ql.io.rcfile.merge
 

Subclasses of Task in org.apache.hadoop.hive.ql.io.rcfile.merge
 class BlockMergeTask
           
 

Uses of Task in org.apache.hadoop.hive.ql.metadata
 

Method parameters in org.apache.hadoop.hive.ql.metadata with type arguments of type Task
 void DummySemanticAnalyzerHook1.postAnalyze(HiveSemanticAnalyzerHookContext context, List<Task<? extends Serializable>> rootTasks)
           
 void DummySemanticAnalyzerHook.postAnalyze(HiveSemanticAnalyzerHookContext context, List<Task<? extends Serializable>> rootTasks)
           
 

Uses of Task in org.apache.hadoop.hive.ql.optimizer
 

Methods in org.apache.hadoop.hive.ql.optimizer that return Task
static Task<?> IndexUtils.createRootTask(HiveConf builderConf, Set<ReadEntity> inputs, Set<WriteEntity> outputs, StringBuilder command, LinkedHashMap<String,String> partSpec, String indexTableName, String dbName)
           
 Task<? extends Serializable> GenMRProcContext.getCurrTask()
           
 Task<? extends Serializable> GenMRProcContext.GenMapRedCtx.getCurrTask()
           
 Task<? extends Serializable> GenMRProcContext.GenMRUnionCtx.getUTask()
           
 

Methods in org.apache.hadoop.hive.ql.optimizer that return types with arguments of type Task
 List<Task<? extends Serializable>> GenMRProcContext.getMvTask()
           
 HashMap<Operator<? extends Serializable>,Task<? extends Serializable>> GenMRProcContext.getOpTaskMap()
           
 List<Task<? extends Serializable>> GenMRProcContext.getRootTasks()
           
 

Methods in org.apache.hadoop.hive.ql.optimizer with parameters of type Task
static void GenMapRedUtils.initUnionPlan(GenMRProcContext opProcCtx, Task<? extends Serializable> currTask, boolean local)
           
static void GenMapRedUtils.joinPlan(Operator<? extends Serializable> op, Task<? extends Serializable> oldTask, Task<? extends Serializable> task, GenMRProcContext opProcCtx, int pos, boolean split, boolean readMapJoinData, boolean readUnionData)
           
static void GenMapRedUtils.joinPlan(Operator<? extends Serializable> op, Task<? extends Serializable> oldTask, Task<? extends Serializable> task, GenMRProcContext opProcCtx, int pos, boolean split, boolean readMapJoinData, boolean readUnionData)
           
static void GenMapRedUtils.joinPlan(Operator<? extends Serializable> op, Task<? extends Serializable> oldTask, Task<? extends Serializable> task, GenMRProcContext opProcCtx, int pos, boolean split, boolean readMapJoinData, boolean readUnionData, boolean createLocalWork)
          Merge the current task with the task for the current reducer.
static void GenMapRedUtils.joinPlan(Operator<? extends Serializable> op, Task<? extends Serializable> oldTask, Task<? extends Serializable> task, GenMRProcContext opProcCtx, int pos, boolean split, boolean readMapJoinData, boolean readUnionData, boolean createLocalWork)
          Merge the current task with the task for the current reducer.
 void GenMRProcContext.setCurrTask(Task<? extends Serializable> currTask)
           
 void GenMRProcContext.GenMRUnionCtx.setUTask(Task<? extends Serializable> uTask)
           
static void GenMapRedUtils.splitTasks(Operator<? extends Serializable> op, Task<? extends Serializable> parentTask, Task<? extends Serializable> childTask, GenMRProcContext opProcCtx, boolean setReducer, boolean local, int posn)
           
static void GenMapRedUtils.splitTasks(Operator<? extends Serializable> op, Task<? extends Serializable> parentTask, Task<? extends Serializable> childTask, GenMRProcContext opProcCtx, boolean setReducer, boolean local, int posn)
           
 

Method parameters in org.apache.hadoop.hive.ql.optimizer with type arguments of type Task
 void GenMRProcContext.setMvTask(List<Task<? extends Serializable>> mvTask)
           
 void GenMRProcContext.setOpTaskMap(HashMap<Operator<? extends Serializable>,Task<? extends Serializable>> opTaskMap)
           
 void GenMRProcContext.setRootTasks(List<Task<? extends Serializable>> rootTasks)
           
 

Constructors in org.apache.hadoop.hive.ql.optimizer with parameters of type Task
GenMRProcContext.GenMapRedCtx(Task<? extends Serializable> currTask, Operator<? extends Serializable> currTopOp, String currAliasId)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.optimizer with type arguments of type Task
GenMRProcContext(HiveConf conf, HashMap<Operator<? extends Serializable>,Task<? extends Serializable>> opTaskMap, List<Operator<? extends Serializable>> seenOps, ParseContext parseCtx, List<Task<? extends Serializable>> mvTask, List<Task<? extends Serializable>> rootTasks, LinkedHashMap<Operator<? extends Serializable>,GenMRProcContext.GenMapRedCtx> mapCurrCtx, Set<ReadEntity> inputs, Set<WriteEntity> outputs)
           
GenMRProcContext(HiveConf conf, HashMap<Operator<? extends Serializable>,Task<? extends Serializable>> opTaskMap, List<Operator<? extends Serializable>> seenOps, ParseContext parseCtx, List<Task<? extends Serializable>> mvTask, List<Task<? extends Serializable>> rootTasks, LinkedHashMap<Operator<? extends Serializable>,GenMRProcContext.GenMapRedCtx> mapCurrCtx, Set<ReadEntity> inputs, Set<WriteEntity> outputs)
           
GenMRProcContext(HiveConf conf, HashMap<Operator<? extends Serializable>,Task<? extends Serializable>> opTaskMap, List<Operator<? extends Serializable>> seenOps, ParseContext parseCtx, List<Task<? extends Serializable>> mvTask, List<Task<? extends Serializable>> rootTasks, LinkedHashMap<Operator<? extends Serializable>,GenMRProcContext.GenMapRedCtx> mapCurrCtx, Set<ReadEntity> inputs, Set<WriteEntity> outputs)
           
 

Uses of Task in org.apache.hadoop.hive.ql.optimizer.physical
 

Fields in org.apache.hadoop.hive.ql.optimizer.physical declared as Task
protected  Task<? extends Serializable> PhysicalContext.fetchTask
           
 

Fields in org.apache.hadoop.hive.ql.optimizer.physical with type parameters of type Task
protected  List<Task<? extends Serializable>> PhysicalContext.rootTasks
           
 

Methods in org.apache.hadoop.hive.ql.optimizer.physical that return Task
 Task<? extends Serializable> SkewJoinResolver.SkewJoinProcCtx.getCurrentTask()
           
 Task<? extends Serializable> MapJoinResolver.LocalMapJoinProcCtx.getCurrentTask()
           
 

Methods in org.apache.hadoop.hive.ql.optimizer.physical with parameters of type Task
 void PhysicalContext.addToRootTask(Task<? extends Serializable> tsk)
           
static void GenMRSkewJoinProcessor.processSkewJoin(JoinOperator joinOp, Task<? extends Serializable> currTask, ParseContext parseCtx)
          Create tasks for processing skew joins.
 void PhysicalContext.removeFromRootTask(Task<? extends Serializable> tsk)
           
 void SkewJoinResolver.SkewJoinProcCtx.setCurrentTask(Task<? extends Serializable> currentTask)
           
 void MapJoinResolver.LocalMapJoinProcCtx.setCurrentTask(Task<? extends Serializable> currentTask)
           
 

Constructors in org.apache.hadoop.hive.ql.optimizer.physical with parameters of type Task
MapJoinResolver.LocalMapJoinProcCtx(Task<? extends Serializable> task, ParseContext parseCtx)
           
PhysicalContext(HiveConf conf, ParseContext parseContext, Context context, List<Task<? extends Serializable>> rootTasks, Task<? extends Serializable> fetchTask)
           
SkewJoinResolver.SkewJoinProcCtx(Task<? extends Serializable> task, ParseContext parseCtx)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.optimizer.physical with type arguments of type Task
PhysicalContext(HiveConf conf, ParseContext parseContext, Context context, List<Task<? extends Serializable>> rootTasks, Task<? extends Serializable> fetchTask)
           
 

Uses of Task in org.apache.hadoop.hive.ql.optimizer.physical.index
 

Methods in org.apache.hadoop.hive.ql.optimizer.physical.index that return Task
 Task<? extends Serializable> IndexWhereProcCtx.getCurrentTask()
           
 

Constructors in org.apache.hadoop.hive.ql.optimizer.physical.index with parameters of type Task
IndexWhereProcCtx(Task<? extends Serializable> task, ParseContext parseCtx)
           
 

Uses of Task in org.apache.hadoop.hive.ql.parse
 

Fields in org.apache.hadoop.hive.ql.parse with type parameters of type Task
protected  List<Task<? extends Serializable>> BaseSemanticAnalyzer.rootTasks
           
 

Methods in org.apache.hadoop.hive.ql.parse that return types with arguments of type Task
 List<Task<? extends Serializable>> IndexUpdater.generateUpdateTasks()
           
 List<Task<? extends Serializable>> BaseSemanticAnalyzer.getRootTasks()
           
 

Methods in org.apache.hadoop.hive.ql.parse with parameters of type Task
 void ParseContext.replaceRootTask(Task<? extends Serializable> rootTask, List<? extends Task<? extends Serializable>> tasks)
           
 

Method parameters in org.apache.hadoop.hive.ql.parse with type arguments of type Task
 void HiveSemanticAnalyzerHook.postAnalyze(HiveSemanticAnalyzerHookContext context, List<Task<? extends Serializable>> rootTasks)
          Invoked after Hive performs its own semantic analysis on a statement (including optimization).
 void AbstractSemanticAnalyzerHook.postAnalyze(HiveSemanticAnalyzerHookContext context, List<Task<? extends Serializable>> rootTasks)
           
 void ParseContext.replaceRootTask(Task<? extends Serializable> rootTask, List<? extends Task<? extends Serializable>> tasks)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.parse with type arguments of type Task
ParseContext(HiveConf conf, QB qb, ASTNode ast, HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner, HashMap<TableScanOperator,PrunedPartitionList> opToPartList, HashMap<String,Operator<? extends Serializable>> topOps, HashMap<String,Operator<? extends Serializable>> topSelOps, LinkedHashMap<Operator<? extends Serializable>,OpParseContext> opParseCtx, Map<JoinOperator,QBJoinTree> joinContext, HashMap<TableScanOperator,Table> topToTable, List<LoadTableDesc> loadTableWork, List<LoadFileDesc> loadFileWork, Context ctx, HashMap<String,String> idToTableNameMap, int destTableId, UnionProcContext uCtx, List<AbstractMapJoinOperator<? extends MapJoinDesc>> listMapJoinOpsNoReducer, Map<GroupByOperator,Set<String>> groupOpToInputTables, Map<String,PrunedPartitionList> prunedPartitions, HashMap<TableScanOperator,FilterDesc.sampleDesc> opToSamplePruner, SemanticAnalyzer.GlobalLimitCtx globalLimitCtx, HashMap<String,SplitSample> nameToSplitSample, HashSet<ReadEntity> semanticInputs, List<Task<? extends Serializable>> rootTasks)
           
 

Uses of Task in org.apache.hadoop.hive.ql.plan
 

Methods in org.apache.hadoop.hive.ql.plan that return Task
 Task<? extends Serializable> ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx.getCommonJoinTask()
           
 

Methods in org.apache.hadoop.hive.ql.plan that return types with arguments of type Task
 HashMap<String,Task<? extends Serializable>> ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx.getAliasToTask()
           
 HashMap<String,Task<? extends Serializable>> ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx.getDirToTaskMap()
           
 List<Task<? extends Serializable>> ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx.getListTasks()
           
 ArrayList<Task<? extends Serializable>> ExplainWork.getRootTasks()
           
 List<Task<? extends Serializable>> ConditionalResolverSkewJoin.getTasks(HiveConf conf, Object objCtx)
           
 List<Task<? extends Serializable>> ConditionalResolverMergeFiles.getTasks(HiveConf conf, Object objCtx)
           
 List<Task<? extends Serializable>> ConditionalResolverCommonJoin.getTasks(HiveConf conf, Object objCtx)
           
 List<Task<? extends Serializable>> ConditionalResolver.getTasks(HiveConf conf, Object ctx)
          All conditional resolvers implement this interface.
 

Methods in org.apache.hadoop.hive.ql.plan with parameters of type Task
 void ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx.setCommonJoinTask(Task<? extends Serializable> commonJoinTask)
           
 

Method parameters in org.apache.hadoop.hive.ql.plan with type arguments of type Task
 void ConditionalResolverCommonJoin.ConditionalResolverCommonJoinCtx.setAliasToTask(HashMap<String,Task<? extends Serializable>> aliasToTask)
           
 void ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx.setDirToTaskMap(HashMap<String,Task<? extends Serializable>> dirToTaskMap)
           
 void ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx.setListTasks(List<Task<? extends Serializable>> listTasks)
           
 void ExplainWork.setRootTasks(ArrayList<Task<? extends Serializable>> rootTasks)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.plan with type arguments of type Task
ConditionalResolverMergeFiles.ConditionalResolverMergeFilesCtx(List<Task<? extends Serializable>> listTasks, String dir)
           
ConditionalResolverSkewJoin.ConditionalResolverSkewJoinCtx(HashMap<String,Task<? extends Serializable>> dirToTaskMap)
           
ExplainWork(String resFile, List<Task<? extends Serializable>> rootTasks, String astStringTree, boolean extended, boolean formatted)
           
 



Copyright © 2011 The Apache Software Foundation