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.exec.mr   
org.apache.hadoop.hive.ql.io   
org.apache.hadoop.hive.ql.optimizer   
org.apache.hadoop.hive.ql.optimizer.correlation   
org.apache.hadoop.hive.ql.optimizer.index   
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 DemuxOperator
          DemuxOperator is an operator used by MapReduce Jobs optimized by CorrelationOptimizer.
 class DummyStoreOperator
          For SortMerge joins, this is a dummy operator, which stores the row for the small table before it reaches the sort merge join operator.
 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 ListSinkOperator
          For fetch task with operator tree, row read from FetchOperator is processed via operator tree and finally arrives to this operator.
 class MapJoinOperator
          Map side Join operator implementation.
 class MapOperator
          Map operator.
 class MuxOperator
          MuxOperator is used in the Reduce side of MapReduce jobs optimized by Correlation Optimizer.
 class PTFOperator
           
 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 OperatorDesc>
          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 OperatorDesc>[] Operator.childOperatorsArray
          Cache childOperators in an array for faster access.
protected  Operator<?> FetchOperator.operator
           
 

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

Methods in org.apache.hadoop.hive.ql.exec that return Operator
 Operator<? extends OperatorDesc> Operator.clone()
           
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.get(Class<T> opClass)
           
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.get(Class<T> opClass, RowSchema rwsch)
           
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.get(T conf, Operator<? extends OperatorDesc>... oplist)
          Returns an operator given the conf and a list of children operators.
static
<T extends OperatorDesc>
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 OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, List<Operator<? extends OperatorDesc>> oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, Operator... oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, List<Operator<? extends OperatorDesc>> oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, Map<String,ExprNodeDesc> colExprMap, List<Operator<? extends OperatorDesc>> oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, Map<String,ExprNodeDesc> colExprMap, Operator... oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, Operator... oplist)
          Returns an operator given the conf and a list of parent operators.
 Operator<? extends OperatorDesc> Task.getReducer()
           
 

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

Methods in org.apache.hadoop.hive.ql.exec with parameters of type Operator
static void TestExecDriver.addMapWork(MapredWork mr, Table tbl, String alias, Operator<?> work)
           
static org.apache.hadoop.hive.ql.exec.PartitionKeySampler.FetchSampler PartitionKeySampler.createSampler(FetchWork work, HiveConf conf, JobConf job, Operator<?> operator)
           
static
<T> Set<T>
OperatorUtils.findOperators(Operator<?> start, Class<T> clazz)
           
static
<T> T
OperatorUtils.findSingleOperator(Operator<?> start, Class<T> clazz)
           
 void Operator.OperatorFunc.func(Operator<? extends OperatorDesc> op)
           
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.get(T conf, Operator<? extends OperatorDesc>... oplist)
          Returns an operator given the conf and a list of children operators.
static
<T extends OperatorDesc>
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 OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, Operator... oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, Map<String,ExprNodeDesc> colExprMap, Operator... oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends OperatorDesc>
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)
           
static void OperatorFactory.makeChild(Operator<? extends OperatorDesc> ret, Operator<? extends OperatorDesc>... oplist)
          Returns an operator given the conf and a list of children operators.
static void OperatorFactory.makeChild(Operator<? extends OperatorDesc> ret, Operator<? extends OperatorDesc>... oplist)
          Returns an operator given the conf and a list of children operators.
 void Operator.removeChild(Operator<? extends OperatorDesc> child)
           
 void Operator.removeChildAndAdoptItsChildren(Operator<? extends OperatorDesc> child)
          Remove a child and add all of the child's children to the location of the child
 void Operator.removeParent(Operator<? extends OperatorDesc> parent)
           
 void Operator.replaceChild(Operator<? extends OperatorDesc> child, Operator<? extends OperatorDesc> newChild)
          Replace one child with another at the same position.
 void Operator.replaceChild(Operator<? extends OperatorDesc> child, Operator<? extends OperatorDesc> newChild)
          Replace one child with another at the same position.
 void Operator.replaceParent(Operator<? extends OperatorDesc> parent, Operator<? extends OperatorDesc> newParent)
          Replace one parent with another at the same position.
 void Operator.replaceParent(Operator<? extends OperatorDesc> parent, Operator<? extends OperatorDesc> newParent)
          Replace one parent with another at the same position.
static void Utilities.setColumnNameList(JobConf jobConf, Operator op)
           
static void Utilities.setColumnTypeList(JobConf jobConf, Operator op)
           
 

Method parameters in org.apache.hadoop.hive.ql.exec with type arguments of type Operator
static
<T> Set<T>
OperatorUtils.findOperators(Collection<Operator<?>> starts, Class<T> clazz)
           
 List<String> GroupByOperator.genColLists(HashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtx)
           
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, List<Operator<? extends OperatorDesc>> oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, List<Operator<? extends OperatorDesc>> oplist)
          Returns an operator given the conf and a list of parent operators.
static
<T extends OperatorDesc>
Operator<T>
OperatorFactory.getAndMakeChild(T conf, RowSchema rwsch, Map<String,ExprNodeDesc> colExprMap, List<Operator<? extends OperatorDesc>> oplist)
          Returns an operator given the conf and a list of parent operators.
 void Operator.setChildOperators(List<Operator<? extends OperatorDesc>> childOperators)
           
 void Operator.setParentOperators(List<Operator<? extends OperatorDesc>> parentOperators)
           
static String Operator.toString(Collection<Operator<? extends OperatorDesc>> top)
           
 

Constructors in org.apache.hadoop.hive.ql.exec with parameters of type Operator
FetchOperator(FetchWork work, JobConf job, Operator<?> operator, List<VirtualColumn> vcCols)
           
 

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.exec.mr
 

Methods in org.apache.hadoop.hive.ql.exec.mr that return Operator
 Operator<? extends OperatorDesc> MapRedTask.getReducer()
           
 

Methods in org.apache.hadoop.hive.ql.exec.mr that return types with arguments of type Operator
 Collection<Operator<? extends OperatorDesc>> MapredLocalTask.getTopOperators()
           
 Collection<Operator<? extends OperatorDesc>> ExecDriver.getTopOperators()
           
 

Methods in org.apache.hadoop.hive.ql.exec.mr with parameters of type Operator
 void ExecMapper.reportStats.func(Operator op)
           
 

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 OperatorDesc>> HiveFileFormatUtils.doGetWorksFromPath(Map<String,ArrayList<String>> pathToAliases, Map<String,Operator<? extends OperatorDesc>> aliasToWork, Path dir)
          Get the list of operators from the operator 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 OperatorDesc>> HiveFileFormatUtils.doGetWorksFromPath(Map<String,ArrayList<String>> pathToAliases, Map<String,Operator<? extends OperatorDesc>> aliasToWork, Path dir)
          Get the list of operators from the operator 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 OperatorDesc> GenMRProcContext.getCurrTopOp()
           
static Operator<? extends OperatorDesc> GenMapRedUtils.putOpInsertMap(Operator<? extends OperatorDesc> op, RowResolver rr, ParseContext parseCtx)
          insert in the map for the operator to row resolver.
 

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

Methods in org.apache.hadoop.hive.ql.optimizer with parameters of type Operator
 void GenMRProcContext.GenMRUnionCtx.addListTopOperators(Operator<? extends OperatorDesc> topOperator)
           
 void GenMRProcContext.addSeenOp(Task task, Operator operator)
           
 List<String> ColumnPrunerProcCtx.genColLists(Operator<? extends OperatorDesc> 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.
protected  void SizeBasedBigTableSelectorForAutoSMJ.getListTopOps(Operator<? extends OperatorDesc> op, List<TableScanOperator> topOps)
           
 List<String> ColumnPrunerProcCtx.getPrunedColList(Operator<? extends OperatorDesc> op)
           
 boolean GenMRProcContext.isSeenOp(Task task, Operator operator)
           
static Operator<? extends OperatorDesc> GenMapRedUtils.putOpInsertMap(Operator<? extends OperatorDesc> op, RowResolver rr, ParseContext parseCtx)
          insert in the map for the operator to row resolver.
static ListSinkOperator SimpleFetchOptimizer.replaceFSwithLS(Operator<?> fileSink, String nullFormat)
           
 void GenMRProcContext.setCurrTopOp(Operator<? extends OperatorDesc> currTopOp)
           
static void GenMapRedUtils.setKeyAndValueDesc(ReduceWork plan, Operator<? extends OperatorDesc> topOp)
          set key and value descriptor.
static void GenMapRedUtils.setTaskPlan(String alias_id, Operator<? extends OperatorDesc> topOp, Task<?> task, boolean local, GenMRProcContext opProcCtx)
          set the current task in the mapredWork.
static void GenMapRedUtils.setTaskPlan(String alias_id, Operator<? extends OperatorDesc> topOp, Task<?> task, boolean local, GenMRProcContext opProcCtx, PrunedPartitionList pList)
          set the current task in the mapredWork.
static void GenMapRedUtils.setTaskPlan(String path, String alias, Operator<? extends OperatorDesc> topOp, MapWork plan, boolean local, TableDesc tt_desc)
          set the current task in the mapredWork.
 

Method parameters in org.apache.hadoop.hive.ql.optimizer with type arguments of type Operator
static MapJoinOperator MapJoinProcessor.convertMapJoin(LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtxMap, JoinOperator op, QBJoinTree joinTree, int mapJoinPos, boolean noCheckOuterJoin, boolean validateMapJoinTree)
          convert a regular join to a a map-side join.
static MapJoinOperator MapJoinProcessor.convertSMBJoinToMapJoin(Map<Operator<? extends OperatorDesc>,OpParseContext> opParseCtxMap, SMBMapJoinOperator smbJoinOp, QBJoinTree joinTree, int bigTablePos, boolean noCheckOuterJoin)
          convert a sortmerge join to a a map-side join.
 void GenMRProcContext.GenMRUnionCtx.setListTopOperators(List<Operator<? extends OperatorDesc>> listTopOperators)
           
 void GenMRProcContext.setMapCurrCtx(LinkedHashMap<Operator<? extends OperatorDesc>,GenMRProcContext.GenMapRedCtx> mapCurrCtx)
           
 void GenMRProcContext.setOpTaskMap(HashMap<Operator<? extends OperatorDesc>,Task<? extends Serializable>> opTaskMap)
           
 

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

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

Methods in org.apache.hadoop.hive.ql.optimizer.correlation with type parameters of type Operator
protected static
<T extends Operator<?>>
T[]
CorrelationUtilities.findParents(JoinOperator join, Class<T> target)
           
protected static
<T extends Operator<?>>
T
CorrelationUtilities.findPossibleParent(Operator<?> start, Class<T> target, boolean trustScript)
           
protected static
<T extends Operator<?>>
T[]
CorrelationUtilities.findPossibleParents(Operator<?> start, Class<T> target, boolean trustScript)
           
 

Methods in org.apache.hadoop.hive.ql.optimizer.correlation that return Operator
protected static
<T extends Operator<?>>
T[]
CorrelationUtilities.findParents(JoinOperator join, Class<T> target)
           
protected static
<T extends Operator<?>>
T[]
CorrelationUtilities.findPossibleParents(Operator<?> start, Class<T> target, boolean trustScript)
           
protected static Operator<?> CorrelationUtilities.getSingleChild(Operator<?> operator)
           
protected static Operator<?> CorrelationUtilities.getSingleChild(Operator<?> operator, boolean throwException)
           
protected static Operator<?> CorrelationUtilities.getSingleParent(Operator<?> operator)
           
protected static Operator<?> CorrelationUtilities.getSingleParent(Operator<?> operator, boolean throwException)
           
protected static Operator<?> CorrelationUtilities.getStartForGroupBy(ReduceSinkOperator cRS)
           
protected static Operator<? extends Serializable> CorrelationUtilities.putOpInsertMap(Operator<?> op, RowResolver rr, ParseContext context)
           
 

Methods in org.apache.hadoop.hive.ql.optimizer.correlation that return types with arguments of type Operator
static List<Operator<? extends OperatorDesc>> CorrelationUtilities.findSiblingOperators(Operator<? extends OperatorDesc> op)
          Find all sibling operators (which have the same child operator of op) of op (op included).
 

Methods in org.apache.hadoop.hive.ql.optimizer.correlation with parameters of type Operator
protected static
<T extends Operator<?>>
T
CorrelationUtilities.findPossibleParent(Operator<?> start, Class<T> target, boolean trustScript)
           
protected static
<T extends Operator<?>>
T[]
CorrelationUtilities.findPossibleParents(Operator<?> start, Class<T> target, boolean trustScript)
           
static List<Operator<? extends OperatorDesc>> CorrelationUtilities.findSiblingOperators(Operator<? extends OperatorDesc> op)
          Find all sibling operators (which have the same child operator of op) of op (op included).
protected static TableScanOperator CorrelationUtilities.findTableScanOperator(Operator<? extends OperatorDesc> startPoint)
          Search the query plan tree from startPoint to the bottom.
protected static Operator<?> CorrelationUtilities.getSingleChild(Operator<?> operator)
           
protected static Operator<?> CorrelationUtilities.getSingleChild(Operator<?> operator, boolean throwException)
           
protected static
<T> T
CorrelationUtilities.getSingleChild(Operator<?> operator, Class<T> type)
           
protected static Operator<?> CorrelationUtilities.getSingleParent(Operator<?> operator)
           
protected static Operator<?> CorrelationUtilities.getSingleParent(Operator<?> operator, boolean throwException)
           
protected static
<T> T
CorrelationUtilities.getSingleParent(Operator<?> operator, Class<T> type)
           
protected static int CorrelationUtilities.indexOf(ExprNodeDesc cexpr, ExprNodeDesc[] pexprs, Operator child, Operator[] parents, boolean[] sorted)
           
protected static int CorrelationUtilities.indexOf(ExprNodeDesc cexpr, ExprNodeDesc[] pexprs, Operator child, Operator[] parents, boolean[] sorted)
           
protected static void CorrelationUtilities.insertOperatorBetween(Operator<?> newOperator, Operator<?> parent, Operator<?> child)
           
protected static void CorrelationUtilities.insertOperatorBetween(Operator<?> newOperator, Operator<?> parent, Operator<?> child)
           
protected static void CorrelationUtilities.insertOperatorBetween(Operator<?> newOperator, Operator<?> parent, Operator<?> child)
           
protected static void CorrelationUtilities.isNullOperator(Operator<?> operator)
          throw a exception if the input operator is null
protected static Operator<? extends Serializable> CorrelationUtilities.putOpInsertMap(Operator<?> op, RowResolver rr, ParseContext context)
           
protected static void CorrelationUtilities.removeOperator(Operator<?> target, Operator<?> child, Operator<?> parent, ParseContext context)
           
protected static void CorrelationUtilities.removeOperator(Operator<?> target, Operator<?> child, Operator<?> parent, ParseContext context)
           
protected static void CorrelationUtilities.removeOperator(Operator<?> target, Operator<?> child, Operator<?> parent, ParseContext context)
           
protected static SelectOperator CorrelationUtilities.replaceOperatorWithSelect(Operator<?> operator, ParseContext context, org.apache.hadoop.hive.ql.optimizer.correlation.AbstractCorrelationProcCtx procCtx)
           
protected  Integer ReduceSinkDeDuplication.AbsctractReducerReducerProc.sameKeys(List<ExprNodeDesc> cexprs, List<ExprNodeDesc> pexprs, Operator<?> child, Operator<?> parent)
           
protected  Integer ReduceSinkDeDuplication.AbsctractReducerReducerProc.sameKeys(List<ExprNodeDesc> cexprs, List<ExprNodeDesc> pexprs, Operator<?> child, Operator<?> parent)
           
 

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

Methods in org.apache.hadoop.hive.ql.optimizer.index that return types with arguments of type Operator
 Map<Operator<? extends OperatorDesc>,OpParseContext> RewriteQueryUsingAggregateIndexCtx.getOpc()
           
 

Methods in org.apache.hadoop.hive.ql.optimizer.index with parameters of type Operator
 void RewriteQueryUsingAggregateIndexCtx.invokeRewriteQueryProc(Operator<? extends OperatorDesc> topOp)
          Walk the original operator tree using the DefaultGraphWalker using the rules.
 

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 OperatorDesc> ExprProcCtx.getInputOperator()
          Gets the input operator.
protected static Operator<? extends OperatorDesc> 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 OperatorDesc> op, ColumnInfo col)
          Gets the dependency for an operator, columninfo tuple.
static LineageInfo.Dependency ExprProcFactory.getExprDependency(LineageCtx lctx, Operator<? extends OperatorDesc> inpOp, ExprNodeDesc expr)
          Gets the expression dependencies for the expression.
 void LineageCtx.Index.mergeDependency(Operator<? extends OperatorDesc> 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 OperatorDesc> 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 OperatorDesc> 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 OperatorDesc> PcrOpWalkerCtx.OpToDeleteInfo.getParent()
           
 

Constructors in org.apache.hadoop.hive.ql.optimizer.pcr with parameters of type Operator
PcrOpWalkerCtx.OpToDeleteInfo(Operator<? extends OperatorDesc> 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 Operator
protected static Operator<? extends OperatorDesc> BucketingSortingOpProcFactory.getParent(Stack<Node> stack)
          Returns the parent operator in the walk path to the current operator.
 

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

Methods in org.apache.hadoop.hive.ql.optimizer.physical with parameters of type Operator
 void MapJoinResolver.LocalMapJoinProcCtx.addDummyParentOp(Operator<? extends OperatorDesc> op)
           
 List<BucketingSortingCtx.BucketCol> BucketingSortingCtx.getBucketedCols(Operator<? extends OperatorDesc> op)
           
 List<BucketingSortingCtx.SortCol> BucketingSortingCtx.getSortedCols(Operator<? extends OperatorDesc> op)
           
 void LocalMapJoinProcFactory.LocalMapJoinProcessor.hasGroupBy(Operator<? extends OperatorDesc> mapJoinOp, MapJoinResolver.LocalMapJoinProcCtx localMapJoinProcCtx)
           
protected  Object BucketingSortingOpProcFactory.GroupByInferrer.processGroupBy(Operator<? extends OperatorDesc> parent, GroupByOperator gop, BucketingSortingCtx bctx)
          Process a GroupByOperator to determine which if any columns the output is bucketed and sorted by, assumes the columns output by the parent which are bucketed and sorted have already been determined.
 void BucketingSortingCtx.setBucketedCols(Operator<? extends OperatorDesc> op, List<BucketingSortingCtx.BucketCol> bucketCols)
           
 void BucketingSortingCtx.setSortedCols(Operator<? extends OperatorDesc> op, List<BucketingSortingCtx.SortCol> sortedCols)
           
 

Method parameters in org.apache.hadoop.hive.ql.optimizer.physical with type arguments of type Operator
 void MapJoinResolver.LocalMapJoinProcCtx.setDummyParentOp(List<Operator<? extends OperatorDesc>> 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)
           
 Operator<?> ParseContext.getFetchSource()
           
<T extends OperatorDesc>
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
 Map<String,Operator<? extends OperatorDesc>> QBJoinTree.getAliasToOpInfo()
           
 Map<Operator<? extends OperatorDesc>,Map<String,List<String>>> TableAccessInfo.getOperatorToTableAccessMap()
           
 LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> ParseContext.getOpParseCtx()
           
 HashMap<String,Operator<? extends OperatorDesc>> ParseContext.getTopOps()
           
 HashMap<String,Operator<? extends OperatorDesc>> ParseContext.getTopSelOps()
           
 

Methods in org.apache.hadoop.hive.ql.parse with parameters of type Operator
 void TableAccessInfo.add(Operator<? extends OperatorDesc> op, Map<String,List<String>> tableToKeysMap)
           
 void TableAccessCtx.addOperatorTableAccess(Operator<? extends OperatorDesc> op, Map<String,List<String>> tableToKeysMap)
           
static TableScanOperator TableAccessAnalyzer.genRootTableScan(Operator<? extends OperatorDesc> op, List<String> keyNames)
          This method traces up from the given operator to the root of the operator graph until a TableScanOperator is reached.
 RowResolver SemanticAnalyzer.getRowResolver(Operator opt)
          Get the row resolver given an operator.
<T extends OperatorDesc>
Operator<T>
SemanticAnalyzer.putOpInsertMap(Operator<T> op, RowResolver rr)
           
 OpParseContext ParseContext.removeOpParseCtx(Operator<? extends OperatorDesc> op)
          Remove the OpParseContext of a specific operator op
 void ParseContext.setFetchSource(Operator<?> fetchSource)
           
 void ParseContext.updateOpParseCtx(Operator<? extends OperatorDesc> op, OpParseContext newOpParseContext)
          Update the OpParseContext of operator op to newOpParseContext.
 

Method parameters in org.apache.hadoop.hive.ql.parse with type arguments of type Operator
 void QBJoinTree.setAliasToOpInfo(Map<String,Operator<? extends OperatorDesc>> aliasToOpInfo)
           
 void ParseContext.setOpParseCtx(LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtx)
           
 void ParseContext.setTopOps(HashMap<String,Operator<? extends OperatorDesc>> topOps)
           
 void ParseContext.setTopSelOps(HashMap<String,Operator<? extends OperatorDesc>> 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 OperatorDesc>> topOps, HashMap<String,Operator<? extends OperatorDesc>> topSelOps, LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtx, Map<JoinOperator,QBJoinTree> joinContext, Map<SMBMapJoinOperator,QBJoinTree> smbMapJoinContext, HashMap<TableScanOperator,Table> topToTable, HashMap<TableScanOperator,Map<String,String>> topToProps, Map<FileSinkOperator,Table> fsopToTable, 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, GlobalLimitCtx globalLimitCtx, HashMap<String,SplitSample> nameToSplitSample, HashSet<ReadEntity> semanticInputs, List<Task<? extends Serializable>> rootTasks, Map<TableScanOperator,Map<String,ExprNodeDesc>> opToPartToSkewedPruner, Map<String,ReadEntity> viewAliasToInput, List<ReduceSinkOperator> reduceSinkOperatorsAddedByEnforceBucketingSorting, QueryProperties queryProperties)
           
ParseContext(HiveConf conf, QB qb, ASTNode ast, HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner, HashMap<TableScanOperator,PrunedPartitionList> opToPartList, HashMap<String,Operator<? extends OperatorDesc>> topOps, HashMap<String,Operator<? extends OperatorDesc>> topSelOps, LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtx, Map<JoinOperator,QBJoinTree> joinContext, Map<SMBMapJoinOperator,QBJoinTree> smbMapJoinContext, HashMap<TableScanOperator,Table> topToTable, HashMap<TableScanOperator,Map<String,String>> topToProps, Map<FileSinkOperator,Table> fsopToTable, 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, GlobalLimitCtx globalLimitCtx, HashMap<String,SplitSample> nameToSplitSample, HashSet<ReadEntity> semanticInputs, List<Task<? extends Serializable>> rootTasks, Map<TableScanOperator,Map<String,ExprNodeDesc>> opToPartToSkewedPruner, Map<String,ReadEntity> viewAliasToInput, List<ReduceSinkOperator> reduceSinkOperatorsAddedByEnforceBucketingSorting, QueryProperties queryProperties)
           
ParseContext(HiveConf conf, QB qb, ASTNode ast, HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner, HashMap<TableScanOperator,PrunedPartitionList> opToPartList, HashMap<String,Operator<? extends OperatorDesc>> topOps, HashMap<String,Operator<? extends OperatorDesc>> topSelOps, LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> opParseCtx, Map<JoinOperator,QBJoinTree> joinContext, Map<SMBMapJoinOperator,QBJoinTree> smbMapJoinContext, HashMap<TableScanOperator,Table> topToTable, HashMap<TableScanOperator,Map<String,String>> topToProps, Map<FileSinkOperator,Table> fsopToTable, 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, GlobalLimitCtx globalLimitCtx, HashMap<String,SplitSample> nameToSplitSample, HashSet<ReadEntity> semanticInputs, List<Task<? extends Serializable>> rootTasks, Map<TableScanOperator,Map<String,ExprNodeDesc>> opToPartToSkewedPruner, Map<String,ReadEntity> viewAliasToInput, List<ReduceSinkOperator> reduceSinkOperatorsAddedByEnforceBucketingSorting, QueryProperties queryProperties)
           
 

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

Methods in org.apache.hadoop.hive.ql.plan that return Operator
 Operator<?> ReduceWork.getReducer()
           
static Operator<?> ExprNodeDescUtils.getSingleParent(Operator<?> current, Operator<?> terminal)
           
 Operator<?> FetchWork.getSource()
           
 

Methods in org.apache.hadoop.hive.ql.plan that return types with arguments of type Operator
 LinkedHashMap<String,Operator<? extends OperatorDesc>> MapredLocalWork.getAliasToWork()
           
 LinkedHashMap<String,Operator<? extends OperatorDesc>> MapWork.getAliasToWork()
           
 List<Operator<?>> BaseWork.getAllOperators()
           
 List<Operator<?>> MapredWork.getAllOperators()
           
protected  List<Operator<?>> ReduceWork.getAllRootOperators()
           
protected  List<Operator<?>> MapWork.getAllRootOperators()
           
protected abstract  List<Operator<?>> BaseWork.getAllRootOperators()
           
 List<Operator<? extends OperatorDesc>> MapredLocalWork.getDummyParentOp()
           
 LinkedHashMap<Operator<? extends OperatorDesc>,OpParseContext> MapWork.getOpParseCtxMap()
           
 ArrayList<Operator<?>> MapWork.getWorks()
           
 

Methods in org.apache.hadoop.hive.ql.plan with parameters of type Operator
 void MapWork.addMapWork(String path, String alias, Operator<?> work, PartitionDesc pd)
           
static ExprNodeDesc ExprNodeDescUtils.backtrack(ExprNodeDesc source, Operator<?> current, Operator<?> terminal)
           
static ExprNodeDesc ExprNodeDescUtils.backtrack(ExprNodeDesc source, Operator<?> current, Operator<?> terminal)
           
static ArrayList<ExprNodeDesc> ExprNodeDescUtils.backtrack(List<ExprNodeDesc> sources, Operator<?> current, Operator<?> terminal)
          Convert expressions in current operator to those in terminal operator, which is an ancestor of current or null (back to top operator).
static ArrayList<ExprNodeDesc> ExprNodeDescUtils.backtrack(List<ExprNodeDesc> sources, Operator<?> current, Operator<?> terminal)
          Convert expressions in current operator to those in terminal operator, which is an ancestor of current or null (back to top operator).
static Operator<?> ExprNodeDescUtils.getSingleParent(Operator<?> current, Operator<?> terminal)
           
static Operator<?> ExprNodeDescUtils.getSingleParent(Operator<?> current, Operator<?> terminal)
           
 void ReduceWork.setReducer(Operator<?> reducer)
           
 void FetchWork.setSource(Operator<?> source)
           
 

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

Constructor parameters in org.apache.hadoop.hive.ql.plan with type arguments of type Operator
MapredLocalWork(LinkedHashMap<String,Operator<? extends OperatorDesc>> aliasToWork, LinkedHashMap<String,FetchWork> aliasToFetchWork)
           
MuxDesc(List<Operator<? extends OperatorDesc>> ops)
           
 

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

Methods in org.apache.hadoop.hive.ql.ppd that return Operator
 Operator<? extends OperatorDesc> 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 OperatorDesc> op, ExprNodeDesc pred)
           
static ExprWalkerInfo ExprWalkerProcFactory.extractPushdownPreds(OpWalkerInfo opContext, Operator<? extends OperatorDesc> op, List<ExprNodeDesc> preds)
          Extracts pushdown predicates from the given list of predicate expression.
 ExprWalkerInfo OpWalkerInfo.getPrunedPreds(Operator<? extends OperatorDesc> op)
           
 OpParseContext OpWalkerInfo.put(Operator<? extends OperatorDesc> key, OpParseContext value)
           
 ExprWalkerInfo OpWalkerInfo.putPrunedPreds(Operator<? extends OperatorDesc> op, ExprWalkerInfo value)
           
 

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



Copyright © 2012 The Apache Software Foundation