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.optimizer   
org.apache.hadoop.hive.ql.optimizer.physical   
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
 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 Driver.countJobs(List<Task<? extends Serializable>> tasks)
           
 int Driver.countJobs(List<Task<? extends Serializable>> tasks, List<Task<? extends Serializable>> seenTasks)
           
 int Driver.countJobs(List<Task<? extends Serializable>> tasks, List<Task<? extends Serializable>> seenTasks)
           
 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 MapRedTask
          Alternate implementation (to ExecDriver) of spawning a mapreduce task that runs it from a separate jvm.
 class MoveTask
          MoveTask implementation.
 

Fields in org.apache.hadoop.hive.ql.exec declared as 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.childTasks
           
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)
           
static
<T extends Serializable>
Task<T>
TaskFactory.getAndMakeChild(T work, HiveConf conf, Task<? extends Serializable>... tasklist)
           
 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.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.getListTasks()
           
 List<Task<? extends Serializable>> Task.getParentTasks()
           
 

Methods in org.apache.hadoop.hive.ql.exec with parameters of type Task
 boolean ConditionalTask.addDependentTask(Task<? extends Serializable> dependent)
          Add a dependent task on the current conditional task.
 boolean Task.addDependentTask(Task<? extends Serializable> dependent)
          Add a dependent task on the current 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)
           
 void Task.removeDependentTask(Task<? extends Serializable> dependent)
          Remove the dependent task.
static void Utilities.serializeTasks(Task<? extends Serializable> t, OutputStream out)
          Serialize a single Task.
 

Method parameters in org.apache.hadoop.hive.ql.exec with type arguments of type Task
 void ExplainTask.outputDependencies(PrintStream out, List<Task<? extends Serializable>> rootTasks, int indent)
           
 void ExplainTask.outputStagePlans(PrintStream out, List<Task<? extends Serializable>> rootTasks, int indent)
           
 void Task.setChildTasks(List<Task<? extends Serializable>> childTasks)
           
 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
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.optimizer
 

Methods in org.apache.hadoop.hive.ql.optimizer that return Task
 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()
           
 

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

Constructors in org.apache.hadoop.hive.ql.optimizer.physical with parameters of type Task
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.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>> BaseSemanticAnalyzer.getRootTasks()
           
 

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

Methods in org.apache.hadoop.hive.ql.plan that return types with arguments of type Task
 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>> ConditionalResolver.getTasks(HiveConf conf, Object ctx)
          All conditional resolvers implement this interface.
 List<Task<? extends Serializable>> ConditionalResolverMergeFiles.getTasks(HiveConf conf, Object objCtx)
           
 

Method parameters in org.apache.hadoop.hive.ql.plan with type arguments of type Task
 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)
           
 



Copyright © 2010 The Apache Software Foundation