Uses of Class
org.apache.hadoop.hive.ql.plan.ExprNodeDesc

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

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

Fields in org.apache.hadoop.hive.ql.exec with type parameters of type ExprNodeDesc
protected  Map<String,ExprNodeDesc> Operator.colExprMap
          A map of output column name to input expression map.
 

Methods in org.apache.hadoop.hive.ql.exec that return types with arguments of type ExprNodeDesc
 Map<String,ExprNodeDesc> Operator.getColumnExprMap()
          Returns a map of output column name to input expression map Note that currently it returns only key columns for ReduceSink and GroupBy operators.
 

Methods in org.apache.hadoop.hive.ql.exec with parameters of type ExprNodeDesc
static ExprNodeEvaluator ExprNodeEvaluatorFactory.get(ExprNodeDesc desc)
           
static boolean FunctionRegistry.isOpAnd(ExprNodeDesc desc)
          Returns whether the exprNodeDesc is a node of "and".
static boolean FunctionRegistry.isOpAndOrNot(ExprNodeDesc desc)
          Returns whether the exprNodeDesc is a node of "and", "or", "not".
static boolean FunctionRegistry.isOpPositive(ExprNodeDesc desc)
          Returns whether the exprNodeDesc is a node of "positive".
 

Method parameters in org.apache.hadoop.hive.ql.exec with type arguments of type ExprNodeDesc
protected  int CommonJoinOperator.populateJoinKeyValue(Map<Byte,List<ExprNodeEvaluator>> outMap, Map<Byte,List<ExprNodeDesc>> inputMap)
           
 void Operator.setColumnExprMap(Map<String,ExprNodeDesc> colExprMap)
           
 

Uses of ExprNodeDesc in org.apache.hadoop.hive.ql.optimizer.lineage
 

Methods in org.apache.hadoop.hive.ql.optimizer.lineage with parameters of type ExprNodeDesc
static LineageInfo.Dependency ExprProcFactory.getExprDependency(LineageCtx lctx, Operator<? extends Serializable> inpOp, ExprNodeDesc expr)
          Gets the expression dependencies for the expression.
 

Uses of ExprNodeDesc in org.apache.hadoop.hive.ql.optimizer.ppr
 

Methods in org.apache.hadoop.hive.ql.optimizer.ppr that return ExprNodeDesc
static ExprNodeDesc ExprProcFactory.genPruner(String tabAlias, ExprNodeDesc pred, boolean hasNonPartCols)
          Generates the partition pruner for the expression tree.
 

Methods in org.apache.hadoop.hive.ql.optimizer.ppr that return types with arguments of type ExprNodeDesc
 HashMap<TableScanOperator,ExprNodeDesc> OpWalkerCtx.getOpToPartPruner()
           
 

Methods in org.apache.hadoop.hive.ql.optimizer.ppr with parameters of type ExprNodeDesc
static ExprNodeDesc ExprProcFactory.genPruner(String tabAlias, ExprNodeDesc pred, boolean hasNonPartCols)
          Generates the partition pruner for the expression tree.
static boolean PartitionPruner.hasColumnExpr(ExprNodeDesc desc)
          Whether the expression contains a column node or not.
static boolean PartitionPruner.onlyContainsPartnCols(Table tab, ExprNodeDesc expr)
          Find out whether the condition only contains partitioned columns.
static PrunedPartitionList PartitionPruner.prune(Table tab, ExprNodeDesc prunerExpr, HiveConf conf, String alias, Map<String,PrunedPartitionList> prunedPartitionsMap)
          Get the partition list for the table that satisfies the partition pruner condition.
 

Constructor parameters in org.apache.hadoop.hive.ql.optimizer.ppr with type arguments of type ExprNodeDesc
OpWalkerCtx(HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner)
          Constructor.
 

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

Methods in org.apache.hadoop.hive.ql.parse that return ExprNodeDesc
 ExprNodeDesc SemanticAnalyzer.genExprNodeDesc(ASTNode expr, RowResolver input)
          Generates an expression node descriptor for the expression passed in the arguments.
static ExprNodeDesc TypeCheckProcFactory.DefaultExprProcessor.getFuncExprNodeDesc(String udfName, ExprNodeDesc... children)
          This function create an ExprNodeDesc for a UDF function given the children (arguments).
static ExprNodeDesc TypeCheckProcFactory.processGByExpr(Node nd, Object procCtx)
          Function to do groupby subexpression elimination.
 

Methods in org.apache.hadoop.hive.ql.parse that return types with arguments of type ExprNodeDesc
 HashMap<TableScanOperator,ExprNodeDesc> ParseContext.getOpToPartPruner()
           
 

Methods in org.apache.hadoop.hive.ql.parse with parameters of type ExprNodeDesc
static ExprNodeDesc TypeCheckProcFactory.DefaultExprProcessor.getFuncExprNodeDesc(String udfName, ExprNodeDesc... children)
          This function create an ExprNodeDesc for a UDF function given the children (arguments).
 

Method parameters in org.apache.hadoop.hive.ql.parse with type arguments of type ExprNodeDesc
static boolean TypeCheckProcFactory.DefaultExprProcessor.isRedundantConversionFunction(ASTNode expr, boolean isFunction, ArrayList<ExprNodeDesc> children)
           
 void ParseContext.setOpToPartPruner(HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.parse with type arguments of type ExprNodeDesc
ParseContext(HiveConf conf, QB qb, ASTNode ast, HashMap<TableScanOperator,ExprNodeDesc> opToPartPruner, 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 ExprNodeDesc in org.apache.hadoop.hive.ql.plan
 

Subclasses of ExprNodeDesc in org.apache.hadoop.hive.ql.plan
 class ExprNodeColumnDesc
          ExprNodeColumnDesc.
 class ExprNodeConstantDesc
          A constant expression.
 class ExprNodeFieldDesc
          ExprNodeFieldDesc.
 class ExprNodeGenericFuncDesc
          Describes a GenericFunc node.
 class ExprNodeNullDesc
          ExprNodeNullDesc.
 

Methods in org.apache.hadoop.hive.ql.plan that return ExprNodeDesc
 ExprNodeDesc ExprNodeNullDesc.clone()
           
 ExprNodeDesc ExprNodeConstantDesc.clone()
           
 ExprNodeDesc ExprNodeFieldDesc.clone()
           
abstract  ExprNodeDesc ExprNodeDesc.clone()
           
 ExprNodeDesc ExprNodeColumnDesc.clone()
           
 ExprNodeDesc ExprNodeGenericFuncDesc.clone()
           
 ExprNodeDesc ExtractDesc.getCol()
           
 ExprNodeDesc ExprNodeFieldDesc.getDesc()
           
 ExprNodeDesc FilterDesc.getPredicate()
           
 

Methods in org.apache.hadoop.hive.ql.plan that return types with arguments of type ExprNodeDesc
 List<ExprNodeDesc> ExprNodeGenericFuncDesc.getChildExprs()
           
 List<ExprNodeDesc> ExprNodeFieldDesc.getChildren()
           
 List<ExprNodeDesc> ExprNodeDesc.getChildren()
           
 List<ExprNodeDesc> ExprNodeGenericFuncDesc.getChildren()
           
 ArrayList<ExprNodeDesc> SelectDesc.getColList()
           
 Map<Byte,List<ExprNodeDesc>> JoinDesc.getExprs()
           
 ArrayList<ExprNodeDesc> ReduceSinkDesc.getKeyCols()
           
 ArrayList<ExprNodeDesc> GroupByDesc.getKeys()
           
 Map<Byte,List<ExprNodeDesc>> MapJoinDesc.getKeys()
           
 ArrayList<ExprNodeDesc> AggregationDesc.getParameters()
           
 ArrayList<ExprNodeDesc> FileSinkDesc.getPartitionCols()
           
 ArrayList<ExprNodeDesc> ReduceSinkDesc.getPartitionCols()
           
 ArrayList<ExprNodeDesc> ReduceSinkDesc.getValueCols()
           
 

Methods in org.apache.hadoop.hive.ql.plan with parameters of type ExprNodeDesc
 void ExtractDesc.setCol(ExprNodeDesc col)
           
 void ExprNodeFieldDesc.setDesc(ExprNodeDesc desc)
           
 void FilterDesc.setPredicate(ExprNodeDesc predicate)
           
 

Method parameters in org.apache.hadoop.hive.ql.plan with type arguments of type ExprNodeDesc
static List<FieldSchema> PlanUtils.getFieldSchemasFromColumnList(List<ExprNodeDesc> cols, List<String> outputColumnNames, int start, String fieldPrefix)
          Convert the ColumnList to FieldSchema list.
static List<FieldSchema> PlanUtils.getFieldSchemasFromColumnList(List<ExprNodeDesc> cols, String fieldPrefix)
          Convert the ColumnList to FieldSchema list.
static ReduceSinkDesc PlanUtils.getReduceSinkDesc(ArrayList<ExprNodeDesc> keyCols, ArrayList<ExprNodeDesc> valueCols, List<String> outputColumnNames, boolean includeKeyCols, int tag, ArrayList<ExprNodeDesc> partitionCols, String order, int numReducers)
          Create the reduce sink descriptor.
static ReduceSinkDesc PlanUtils.getReduceSinkDesc(ArrayList<ExprNodeDesc> keyCols, ArrayList<ExprNodeDesc> valueCols, List<String> outputColumnNames, boolean includeKeyCols, int tag, ArrayList<ExprNodeDesc> partitionCols, String order, int numReducers)
          Create the reduce sink descriptor.
static ReduceSinkDesc PlanUtils.getReduceSinkDesc(ArrayList<ExprNodeDesc> keyCols, ArrayList<ExprNodeDesc> valueCols, List<String> outputColumnNames, boolean includeKeyCols, int tag, ArrayList<ExprNodeDesc> partitionCols, String order, int numReducers)
          Create the reduce sink descriptor.
static ReduceSinkDesc PlanUtils.getReduceSinkDesc(ArrayList<ExprNodeDesc> keyCols, ArrayList<ExprNodeDesc> valueCols, List<String> outputColumnNames, boolean includeKey, int tag, int numPartitionFields, int numReducers)
          Create the reduce sink descriptor.
static ReduceSinkDesc PlanUtils.getReduceSinkDesc(ArrayList<ExprNodeDesc> keyCols, ArrayList<ExprNodeDesc> valueCols, List<String> outputColumnNames, boolean includeKey, int tag, int numPartitionFields, int numReducers)
          Create the reduce sink descriptor.
static ExprNodeGenericFuncDesc ExprNodeGenericFuncDesc.newInstance(GenericUDF genericUDF, List<ExprNodeDesc> children)
          Create a exprNodeGenericFuncDesc based on the genericUDFClass and the children parameters.
 void ExprNodeGenericFuncDesc.setChildExprs(List<ExprNodeDesc> children)
           
 void SelectDesc.setColList(ArrayList<ExprNodeDesc> colList)
           
 void JoinDesc.setExprs(Map<Byte,List<ExprNodeDesc>> exprs)
           
 void ReduceSinkDesc.setKeyCols(ArrayList<ExprNodeDesc> keyCols)
           
 void GroupByDesc.setKeys(ArrayList<ExprNodeDesc> keys)
           
 void MapJoinDesc.setKeys(Map<Byte,List<ExprNodeDesc>> keys)
           
 void AggregationDesc.setParameters(ArrayList<ExprNodeDesc> parameters)
           
 void FileSinkDesc.setPartitionCols(ArrayList<ExprNodeDesc> partitionCols)
           
 void ReduceSinkDesc.setPartitionCols(ArrayList<ExprNodeDesc> partitionCols)
           
 void ReduceSinkDesc.setValueCols(ArrayList<ExprNodeDesc> valueCols)
           
 

Constructors in org.apache.hadoop.hive.ql.plan with parameters of type ExprNodeDesc
ExprNodeFieldDesc(TypeInfo typeInfo, ExprNodeDesc desc, String fieldName, Boolean isList)
           
ExtractDesc(ExprNodeDesc col)
           
FilterDesc(ExprNodeDesc predicate, boolean isSamplingPred)
           
FilterDesc(ExprNodeDesc predicate, boolean isSamplingPred, FilterDesc.sampleDesc sampleDescr)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.plan with type arguments of type ExprNodeDesc
AggregationDesc(String genericUDAFName, GenericUDAFEvaluator genericUDAFEvaluator, ArrayList<ExprNodeDesc> parameters, boolean distinct, GenericUDAFEvaluator.Mode mode)
           
ExprNodeGenericFuncDesc(TypeInfo typeInfo, GenericUDF genericUDF, List<ExprNodeDesc> children)
           
FileSinkDesc(String dirName, TableDesc tableInfo, boolean compressed, int destTableId, boolean multiFileSpray, int numFiles, int totalFiles, ArrayList<ExprNodeDesc> partitionCols, DynamicPartitionCtx dpCtx)
           
GroupByDesc(GroupByDesc.Mode mode, ArrayList<String> outputColumnNames, ArrayList<ExprNodeDesc> keys, ArrayList<AggregationDesc> aggregators, boolean groupKeyNotReductionKey)
           
GroupByDesc(GroupByDesc.Mode mode, ArrayList<String> outputColumnNames, ArrayList<ExprNodeDesc> keys, ArrayList<AggregationDesc> aggregators, boolean groupKeyNotReductionKey, boolean bucketGroup)
           
JoinDesc(Map<Byte,List<ExprNodeDesc>> exprs, List<String> outputColumnNames)
           
JoinDesc(Map<Byte,List<ExprNodeDesc>> exprs, List<String> outputColumnNames, boolean noOuterJoin, JoinCondDesc[] conds)
           
JoinDesc(Map<Byte,List<ExprNodeDesc>> exprs, List<String> outputColumnNames, JoinCondDesc[] conds)
           
MapJoinDesc(Map<Byte,List<ExprNodeDesc>> keys, TableDesc keyTblDesc, Map<Byte,List<ExprNodeDesc>> values, List<TableDesc> valueTblDescs, List<String> outputColumnNames, int posBigTable, JoinCondDesc[] conds)
           
MapJoinDesc(Map<Byte,List<ExprNodeDesc>> keys, TableDesc keyTblDesc, Map<Byte,List<ExprNodeDesc>> values, List<TableDesc> valueTblDescs, List<String> outputColumnNames, int posBigTable, JoinCondDesc[] conds)
           
ReduceSinkDesc(ArrayList<ExprNodeDesc> keyCols, ArrayList<ExprNodeDesc> valueCols, ArrayList<String> outputKeyColumnNames, ArrayList<String> outputValueolumnNames, int tag, ArrayList<ExprNodeDesc> partitionCols, int numReducers, TableDesc keySerializeInfo, TableDesc valueSerializeInfo)
           
ReduceSinkDesc(ArrayList<ExprNodeDesc> keyCols, ArrayList<ExprNodeDesc> valueCols, ArrayList<String> outputKeyColumnNames, ArrayList<String> outputValueolumnNames, int tag, ArrayList<ExprNodeDesc> partitionCols, int numReducers, TableDesc keySerializeInfo, TableDesc valueSerializeInfo)
           
ReduceSinkDesc(ArrayList<ExprNodeDesc> keyCols, ArrayList<ExprNodeDesc> valueCols, ArrayList<String> outputKeyColumnNames, ArrayList<String> outputValueolumnNames, int tag, ArrayList<ExprNodeDesc> partitionCols, int numReducers, TableDesc keySerializeInfo, TableDesc valueSerializeInfo)
           
SelectDesc(ArrayList<ExprNodeDesc> colList, ArrayList<String> outputColumnNames)
           
SelectDesc(ArrayList<ExprNodeDesc> colList, ArrayList<String> outputColumnNames, boolean selectStar)
           
SelectDesc(ArrayList<ExprNodeDesc> colList, boolean selectStar, boolean selStarNoCompute)
           
 

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

Methods in org.apache.hadoop.hive.ql.ppd that return ExprNodeDesc
 ExprNodeDesc ExprWalkerInfo.getConvertedNode(Node nd)
           
 

Methods in org.apache.hadoop.hive.ql.ppd that return types with arguments of type ExprNodeDesc
 Map<String,List<ExprNodeDesc>> ExprWalkerInfo.getFinalCandidates()
          Returns the list of pushdown expressions for each alias that appear in the current operator's RowResolver.
 

Methods in org.apache.hadoop.hive.ql.ppd with parameters of type ExprNodeDesc
 void ExprWalkerInfo.addAlias(ExprNodeDesc expr, String alias)
          Adds the specified alias to the specified expr.
 void ExprWalkerInfo.addConvertedNode(ExprNodeDesc oldNode, ExprNodeDesc newNode)
          adds a replacement node for this expression.
 void ExprWalkerInfo.addFinalCandidate(ExprNodeDesc expr)
          Adds the specified expr as the top-most pushdown expr (ie all its children can be pushed).
static ExprWalkerInfo ExprWalkerProcFactory.extractPushdownPreds(OpWalkerInfo opContext, Operator<? extends Serializable> op, ExprNodeDesc pred)
           
 String ExprWalkerInfo.getAlias(ExprNodeDesc expr)
          Returns the alias of the specified expr.
 boolean ExprWalkerInfo.isCandidate(ExprNodeDesc expr)
          Returns true if the specified expression is pushdown candidate else false.
 void ExprWalkerInfo.setIsCandidate(ExprNodeDesc expr, boolean b)
          Marks the specified expr to the specified value.
 

Method parameters in org.apache.hadoop.hive.ql.ppd with type arguments of type ExprNodeDesc
static ExprWalkerInfo ExprWalkerProcFactory.extractPushdownPreds(OpWalkerInfo opContext, Operator<? extends Serializable> op, List<ExprNodeDesc> preds)
          Extracts pushdown predicates from the given list of predicate expression.
 



Copyright © 2010 The Apache Software Foundation