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

Packages that use Operator
org.apache.hadoop.hive.ql.exec Hive QL execution tasks, operators, functions and other handlers. 
org.apache.hadoop.hive.ql.io   
org.apache.hadoop.hive.ql.optimizer   
org.apache.hadoop.hive.ql.optimizer.lineage   
org.apache.hadoop.hive.ql.optimizer.pcr   
org.apache.hadoop.hive.ql.optimizer.physical   
org.apache.hadoop.hive.ql.parse   
org.apache.hadoop.hive.ql.plan   
org.apache.hadoop.hive.ql.ppd   
 

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

Subclasses of Operator in org.apache.hadoop.hive.ql.exec
 class AbstractMapJoinOperator<T extends MapJoinDesc>
           
 class CollectOperator
          Buffers rows emitted by other operators.
 class CommonJoinOperator<T extends JoinDesc>
          Join operator implementation.
 class ExtractOperator
          Extract operator implementation Extracts a subobject and passes that on.
 class FileSinkOperator
          File Sink operator implementation.
 class FilterOperator
          Filter operator implementation.
 class ForwardOperator
          Forward Operator Just forwards.
 class GroupByOperator
          GroupBy operator implementation.
 class HashTableDummyOperator
           
 class HashTableSinkOperator
           
 class JoinOperator
          Join operator implementation.
 class LateralViewForwardOperator
          LateralViewForwardOperator.
 class LateralViewJoinOperator
          The lateral view join operator is used for FROM src LATERAL VIEW udtf()...
 class LimitOperator
          Limit operator implementation Limits the number of rows to be passed on.
 class MapJoinOperator
          Map side Join operator implementation.
 class MapOperator
          Map operator.
 class ReduceSinkOperator
          Reduce Sink Operator sends output to the reduce stage.
 class ScriptOperator
          ScriptOperator.
 class SelectOperator
          Select operator implementation.
 class SMBMapJoinOperator
          Sorted Merge Map Join Operator.
 class TableScanOperator
          Table Scan Operator If the data is coming from the map-reduce framework, just forward it.
 class TerminalOperator<T extends Serializable>
          Terminal Operator Base Class.
 class UDTFOperator
          UDTFOperator.
 class UnionOperator
          Union Operator Just forwards.
 

Fields in org.apache.hadoop.hive.ql.exec declared as Operator
protected  Operator<? extends Serializable>[] Operator.childOperatorsArray
          Cache childOperators in an array for faster access.
 

Fields in org.apache.hadoop.hive.ql.exec with type parameters of type Operator
protected  List<Operator<? extends Serializable>> Operator.childOperators
           
 Class<? extends Operator<T>> OperatorFactory.OpTuple.opClass
           
protected  List<Operator<? extends Serializable>> Operator.parentOperators
           
 

Methods in org.apache.hadoop.hive.ql.exec that return Operator
static
<T extends Serializable>
Operator<T>
OperatorFactory.get(Class<T> opClass)
           
static
<T extends Serializable>
Operator<T>
OperatorFactory.get(Class<T> opClass, RowSchema rwsch)
           
static
<T extends Serializable>
Operator<T>
OperatorFactory.get(T conf, Operator<? extends Serializable>... oplist)
          Returns an operator given the conf and a list of children operators.
static
<T extends Serializable>
Operator<T>
OperatorFactory.get(T conf, RowSchema rwsch, Operator... oplist)
          Returns an operator given the conf and a list of children operators.
static
<T extends Serializable>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, List<Operator<? extends Serializable>> oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends Serializable>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, Operator... oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends Serializable>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, List<Operator<? extends Serializable>> oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends Serializable>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, Operator... oplist)
          Returns an operator given the conf and a list of parent operators.
 

Methods in org.apache.hadoop.hive.ql.exec that return types with arguments of type Operator
 List<Operator<? extends Serializable>> Operator.getChildOperators()
           
 List<Operator<? extends Serializable>> Operator.getParentOperators()
           
 

Methods in org.apache.hadoop.hive.ql.exec with parameters of type Operator
static void Utilities.addMapWork(MapredWork mr, Table tbl, String alias, Operator<?> work)
           
 void ExecMapper.reportStats.func(Operator op)
           
 void Operator.OperatorFunc.func(Operator<? extends Serializable> op)
           
static
<T extends Serializable>
Operator<T>
OperatorFactory.get(T conf, Operator<? extends Serializable>... oplist)
          Returns an operator given the conf and a list of children operators.
static
<T extends Serializable>
Operator<T>
OperatorFactory.get(T conf, RowSchema rwsch, Operator... oplist)
          Returns an operator given the conf and a list of children operators.
static
<T extends Serializable>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, Operator... oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends Serializable>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, Operator... oplist)
          Returns an operator given the conf and a list of parent operators.
static String Utilities.getOpTreeSkel(Operator<?> op)
           
 void Operator.removeChild(Operator<? extends Serializable> child)
           
 void Operator.removeChildAndAdoptItsChildren(Operator<? extends Serializable> child)
          Remove a child and add all of the child's children to the location of the child
 void Operator.replaceChild(Operator<? extends Serializable> child, Operator<? extends Serializable> newChild)
          Replace one child with another at the same position.
 void Operator.replaceChild(Operator<? extends Serializable> child, Operator<? extends Serializable> newChild)
          Replace one child with another at the same position.
 void Operator.replaceParent(Operator<? extends Serializable> parent, Operator<? extends Serializable> newParent)
          Replace one parent with another at the same position.
 void Operator.replaceParent(Operator<? extends Serializable> parent, Operator<? extends Serializable> newParent)
          Replace one parent with another at the same position.
static void Utilities.setColumnNameList(org.apache.hadoop.mapred.JobConf jobConf, Operator op)
           
 

Method parameters in org.apache.hadoop.hive.ql.exec with type arguments of type Operator
 List<String> GroupByOperator.genColLists(HashMap<Operator<? extends Serializable>,OpParseContext> opParseCtx)
           
static
<T extends Serializable>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, List<Operator<? extends Serializable>> oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends Serializable>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, List<Operator<? extends Serializable>> oplist)
          Returns an operator given the conf and a list of parent operators.
 void Operator.setChildOperators(List<Operator<? extends Serializable>> childOperators)
           
 void Operator.setParentOperators(List<Operator<? extends Serializable>> parentOperators)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.exec with type arguments of type Operator
OperatorFactory.OpTuple(Class<T> descClass, Class<? extends Operator<T>> opClass)
           
 

Uses of Operator in org.apache.hadoop.hive.ql.io
 

Methods in org.apache.hadoop.hive.ql.io that return types with arguments of type Operator
static List<Operator<? extends Serializable>> HiveFileFormatUtils.doGetAliasesFromPath(Map<String,ArrayList<String>> pathToAliases, Map<String,Operator<? extends Serializable>> aliasToWork, org.apache.hadoop.fs.Path dir)
          Get the list of operatators from the opeerator tree that are needed for the path
 

Method parameters in org.apache.hadoop.hive.ql.io with type arguments of type Operator
static List<Operator<? extends Serializable>> HiveFileFormatUtils.doGetAliasesFromPath(Map<String,ArrayList<String>> pathToAliases, Map<String,Operator<? extends Serializable>> aliasToWork, org.apache.hadoop.fs.Path dir)
          Get the list of operatators from the opeerator tree that are needed for the path
 

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

Methods in org.apache.hadoop.hive.ql.optimizer that return Operator
 Operator<? extends Serializable> GenMRProcContext.getCurrTopOp()
           
 Operator<? extends Serializable> GenMRProcContext.GenMapRedCtx.getCurrTopOp()
           
 Operator<? extends Serializable> GenMRProcContext.GenMRMapJoinCtx.getRootMapJoinOp()
           
 

Methods in org.apache.hadoop.hive.ql.optimizer that return types with arguments of type Operator
 LinkedHashMap<Operator<? extends Serializable>,GenMRProcContext.GenMapRedCtx> GenMRProcContext.getMapCurrCtx()
           
 HashMap<Operator<? extends Serializable>,Task<? extends Serializable>> GenMRProcContext.getOpTaskMap()
           
 HashMap<Operator<? extends Serializable>,OpParseContext> ColumnPrunerProcCtx.getOpToParseCtxMap()
           
 Map<Operator<? extends Serializable>,List<String>> ColumnPrunerProcCtx.getPrunedColLists()
           
 List<Operator<? extends Serializable>> GenMRProcContext.getRootOps()
           
 List<Operator<? extends Serializable>> GenMRProcContext.getSeenOps()
           
 

Methods in org.apache.hadoop.hive.ql.optimizer with parameters of type Operator
 List<String> ColumnPrunerProcCtx.genColLists(Operator<? extends Serializable> curOp)
          Creates the list of internal column names(these names are used in the RowResolver and are different from the external column names) that are needed in the subtree.
 List<String> ColumnPrunerProcCtx.getPrunedColList(Operator<? extends Serializable> op)
           
static void GenMapRedUtils.initMapJoinPlan(Operator<? extends Serializable> op, GenMRProcContext ctx, boolean readInputMapJoin, boolean readInputUnion, boolean setReducer, int pos)
           
static void GenMapRedUtils.initMapJoinPlan(Operator<? extends Serializable> op, GenMRProcContext opProcCtx, boolean readInputMapJoin, boolean readInputUnion, boolean setReducer, int pos, boolean createLocalPlan)
          Initialize the current plan by adding it to root tasks.
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.
 void GenMRProcContext.setCurrTopOp(Operator<? extends Serializable> currTopOp)
           
static void GenMapRedUtils.setKeyAndValueDesc(MapredWork plan, Operator<? extends Serializable> topOp)
          set key and value descriptor.
 void GenMRProcContext.GenMRMapJoinCtx.setRootMapJoinOp(Operator<? extends Serializable> rootMapJoinOp)
           
static void GenMapRedUtils.setTaskPlan(String alias_id, Operator<? extends Serializable> topOp, MapredWork plan, boolean local, GenMRProcContext opProcCtx)
          set the current task in the mapredWork.
static void GenMapRedUtils.setTaskPlan(String alias_id, Operator<? extends Serializable> topOp, MapredWork plan, boolean local, GenMRProcContext opProcCtx, PrunedPartitionList pList)
          set the current task in the mapredWork.
static void GenMapRedUtils.setTaskPlan(String path, String alias, Operator<? extends Serializable> topOp, MapredWork plan, boolean local, TableDesc tt_desc)
          set the current task in the mapredWork.
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 Operator
static MapJoinOperator MapJoinProcessor.convertMapJoin(LinkedHashMap<Operator<? extends Serializable>,OpParseContext> opParseCtxMap, JoinOperator op, QBJoinTree joinTree, int mapJoinPos, boolean noCheckOuterJoin)
          convert a regular join to a a map-side join.
 void GenMRProcContext.setMapCurrCtx(LinkedHashMap<Operator<? extends Serializable>,GenMRProcContext.GenMapRedCtx> mapCurrCtx)
           
 void GenMRProcContext.setOpTaskMap(HashMap<Operator<? extends Serializable>,Task<? extends Serializable>> opTaskMap)
           
 void GenMRProcContext.setRootOps(List<Operator<? extends Serializable>> rootOps)
           
 void GenMRProcContext.setSeenOps(List<Operator<? extends Serializable>> seenOps)
           
 

Constructors in org.apache.hadoop.hive.ql.optimizer with parameters of type Operator
GenMRProcContext.GenMapRedCtx(Task<? extends Serializable> currTask, Operator<? extends Serializable> currTopOp, String currAliasId)
           
GenMRProcContext.GenMRMapJoinCtx(String taskTmpDir, TableDesc tt_desc, Operator<? extends Serializable> rootMapJoinOp, AbstractMapJoinOperator<? extends MapJoinDesc> oldMapJoin)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.optimizer with type arguments of type Operator
ColumnPrunerProcCtx(HashMap<Operator<? extends Serializable>,OpParseContext> opToParseContextMap)
           
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 Operator in org.apache.hadoop.hive.ql.optimizer.lineage
 

Methods in org.apache.hadoop.hive.ql.optimizer.lineage that return Operator
 Operator<? extends Serializable> ExprProcCtx.getInputOperator()
          Gets the input operator.
protected static Operator<? extends Serializable> OpProcFactory.getParent(Stack<Node> stack)
          Returns the parent operator in the walk path to the current operator.
 

Methods in org.apache.hadoop.hive.ql.optimizer.lineage with parameters of type Operator
 LineageInfo.Dependency LineageCtx.Index.getDependency(Operator<? extends Serializable> op, ColumnInfo col)
          Gets the dependency for an operator, columninfo tuple.
static LineageInfo.Dependency ExprProcFactory.getExprDependency(LineageCtx lctx, Operator<? extends Serializable> inpOp, ExprNodeDesc expr)
          Gets the expression dependencies for the expression.
 void LineageCtx.Index.mergeDependency(Operator<? extends Serializable> op, ColumnInfo ci, LineageInfo.Dependency dep)
          Merges the new dependencies in dep to the existing dependencies of (op, ci).
 void LineageCtx.Index.putDependency(Operator<? extends Serializable> op, ColumnInfo col, LineageInfo.Dependency dep)
          Puts the dependency for an operator, columninfo tuple.
 

Constructors in org.apache.hadoop.hive.ql.optimizer.lineage with parameters of type Operator
ExprProcCtx(LineageCtx lctx, Operator<? extends Serializable> inpOp)
          Constructor.
 

Uses of Operator in org.apache.hadoop.hive.ql.optimizer.pcr
 

Methods in org.apache.hadoop.hive.ql.optimizer.pcr that return Operator
 Operator<? extends Serializable> PcrOpWalkerCtx.OpToDeleteInfo.getParent()
           
 

Constructors in org.apache.hadoop.hive.ql.optimizer.pcr with parameters of type Operator
PcrOpWalkerCtx.OpToDeleteInfo(Operator<? extends Serializable> parent, FilterOperator operator)
           
 

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

Methods in org.apache.hadoop.hive.ql.optimizer.physical that return types with arguments of type Operator
 List<Operator<? extends Serializable>> MapJoinResolver.LocalMapJoinProcCtx.getDummyParentOp()
           
 

Methods in org.apache.hadoop.hive.ql.optimizer.physical with parameters of type Operator
 void MapJoinResolver.LocalMapJoinProcCtx.addDummyParentOp(Operator<? extends Serializable> op)
           
 void LocalMapJoinProcFactory.LocalMapJoinProcessor.hasGroupBy(Operator<? extends Serializable> mapJoinOp, MapJoinResolver.LocalMapJoinProcCtx localMapJoinProcCtx)
           
 

Method parameters in org.apache.hadoop.hive.ql.optimizer.physical with type arguments of type Operator
 void MapJoinResolver.LocalMapJoinProcCtx.setDummyParentOp(List<Operator<? extends Serializable>> op)
           
 

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

Methods in org.apache.hadoop.hive.ql.parse that return Operator
 Operator SemanticAnalyzer.genPlan(QB qb)
           
<T extends Serializable>
Operator<T>
SemanticAnalyzer.putOpInsertMap(Operator<T> op, RowResolver rr)
           
 

Methods in org.apache.hadoop.hive.ql.parse that return types with arguments of type Operator
 LinkedHashMap<Operator<? extends Serializable>,OpParseContext> ParseContext.getOpParseCtx()
           
 HashMap<String,Operator<? extends Serializable>> ParseContext.getTopOps()
           
 HashMap<String,Operator<? extends Serializable>> ParseContext.getTopSelOps()
           
 

Methods in org.apache.hadoop.hive.ql.parse with parameters of type Operator
 RowResolver SemanticAnalyzer.getRowResolver(Operator opt)
          Get the row resolver given an operator.
<T extends Serializable>
Operator<T>
SemanticAnalyzer.putOpInsertMap(Operator<T> op, RowResolver rr)
           
 

Method parameters in org.apache.hadoop.hive.ql.parse with type arguments of type Operator
 void ParseContext.setOpParseCtx(LinkedHashMap<Operator<? extends Serializable>,OpParseContext> opParseCtx)
           
 void ParseContext.setTopOps(HashMap<String,Operator<? extends Serializable>> topOps)
           
 void ParseContext.setTopSelOps(HashMap<String,Operator<? extends Serializable>> topSelOps)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.parse with type arguments of type Operator
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)
           
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)
           
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)
           
 

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

Methods in org.apache.hadoop.hive.ql.plan that return Operator
 Operator<?> MapredWork.getReducer()
           
 

Methods in org.apache.hadoop.hive.ql.plan that return types with arguments of type Operator
 LinkedHashMap<String,Operator<? extends Serializable>> MapredWork.getAliasToWork()
           
 LinkedHashMap<String,Operator<? extends Serializable>> MapredLocalWork.getAliasToWork()
           
 List<Operator<? extends Serializable>> MapredLocalWork.getDummyParentOp()
           
 LinkedHashMap<Operator<? extends Serializable>,OpParseContext> MapredWork.getOpParseCtxMap()
           
 

Methods in org.apache.hadoop.hive.ql.plan with parameters of type Operator
 void MapredWork.addMapWork(String path, String alias, Operator<?> work, PartitionDesc pd)
           
 void MapredWork.setReducer(Operator<?> reducer)
           
 

Method parameters in org.apache.hadoop.hive.ql.plan with type arguments of type Operator
 void MapredWork.setAliasToWork(LinkedHashMap<String,Operator<? extends Serializable>> aliasToWork)
           
 void MapredLocalWork.setAliasToWork(LinkedHashMap<String,Operator<? extends Serializable>> aliasToWork)
           
 void MapredLocalWork.setDummyParentOp(List<Operator<? extends Serializable>> op)
           
 void MapredWork.setOpParseCtxMap(LinkedHashMap<Operator<? extends Serializable>,OpParseContext> opParseCtxMap)
           
 

Constructors in org.apache.hadoop.hive.ql.plan with parameters of type Operator
MapredWork(String command, LinkedHashMap<String,ArrayList<String>> pathToAliases, LinkedHashMap<String,PartitionDesc> pathToPartitionInfo, LinkedHashMap<String,Operator<? extends Serializable>> aliasToWork, TableDesc keyDesc, List<TableDesc> tagToValueDesc, Operator<?> reducer, Integer numReduceTasks, MapredLocalWork mapLocalWork, boolean hadoopSupportsSplittable)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.plan with type arguments of type Operator
MapredLocalWork(LinkedHashMap<String,Operator<? extends Serializable>> aliasToWork, LinkedHashMap<String,FetchWork> aliasToFetchWork)
           
MapredWork(String command, LinkedHashMap<String,ArrayList<String>> pathToAliases, LinkedHashMap<String,PartitionDesc> pathToPartitionInfo, LinkedHashMap<String,Operator<? extends Serializable>> aliasToWork, TableDesc keyDesc, List<TableDesc> tagToValueDesc, Operator<?> reducer, Integer numReduceTasks, MapredLocalWork mapLocalWork, boolean hadoopSupportsSplittable)
           
 

Uses of Operator in org.apache.hadoop.hive.ql.ppd
 

Methods in org.apache.hadoop.hive.ql.ppd that return Operator
 Operator<? extends Serializable> ExprWalkerInfo.getOp()
           
 

Methods in org.apache.hadoop.hive.ql.ppd with parameters of type Operator
protected static Object OpProcFactory.createFilter(Operator op, ExprWalkerInfo pushDownPreds, OpWalkerInfo owi)
           
static ExprWalkerInfo ExprWalkerProcFactory.extractPushdownPreds(OpWalkerInfo opContext, Operator<? extends Serializable> op, ExprNodeDesc pred)
           
static ExprWalkerInfo ExprWalkerProcFactory.extractPushdownPreds(OpWalkerInfo opContext, Operator<? extends Serializable> op, List<ExprNodeDesc> preds)
          Extracts pushdown predicates from the given list of predicate expression.
 ExprWalkerInfo OpWalkerInfo.getPrunedPreds(Operator<? extends Serializable> op)
           
 OpParseContext OpWalkerInfo.put(Operator<? extends Serializable> key, OpParseContext value)
           
 ExprWalkerInfo OpWalkerInfo.putPrunedPreds(Operator<? extends Serializable> op, ExprWalkerInfo value)
           
 

Constructors in org.apache.hadoop.hive.ql.ppd with parameters of type Operator
ExprWalkerInfo(Operator<? extends Serializable> op, RowResolver toRR)
           
 



Copyright © 2011 The Apache Software Foundation