Uses of Class
org.apache.hadoop.hive.ql.parse.ASTNode

Packages that use ASTNode
org.apache.hadoop.hive.ql   
org.apache.hadoop.hive.ql.hooks   
org.apache.hadoop.hive.ql.metadata   
org.apache.hadoop.hive.ql.parse   
org.apache.hadoop.hive.ql.udf.ptf   
 

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

Methods in org.apache.hadoop.hive.ql that return ASTNode
 ASTNode QTestUtil.parseQuery(String tname)
           
 

Methods in org.apache.hadoop.hive.ql with parameters of type ASTNode
 List<Task<? extends Serializable>> QTestUtil.analyzeAST(ASTNode ast)
           
 int QTestUtil.checkParseResults(String tname, ASTNode tree)
           
 String ErrorMsg.getMsg(ASTNode tree)
           
 String ErrorMsg.getMsg(ASTNode tree, String reason)
           
static String ErrorMsg.getText(ASTNode tree)
           
 

Uses of ASTNode in org.apache.hadoop.hive.ql.hooks
 

Methods in org.apache.hadoop.hive.ql.hooks that return ASTNode
 ASTNode VerifyHooksRunInOrder.RunFirstSemanticAnalysisHook.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
           
 ASTNode VerifyHooksRunInOrder.RunSecondSemanticAnalysisHook.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
           
 

Methods in org.apache.hadoop.hive.ql.hooks with parameters of type ASTNode
 ASTNode VerifyHooksRunInOrder.RunFirstSemanticAnalysisHook.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
           
 ASTNode VerifyHooksRunInOrder.RunSecondSemanticAnalysisHook.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
           
 

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

Methods in org.apache.hadoop.hive.ql.metadata that return ASTNode
 ASTNode DummySemanticAnalyzerHook1.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
           
 ASTNode DummySemanticAnalyzerHook.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
           
 

Methods in org.apache.hadoop.hive.ql.metadata with parameters of type ASTNode
 ASTNode DummySemanticAnalyzerHook1.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
           
 ASTNode DummySemanticAnalyzerHook.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
           
 

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

Subclasses of ASTNode in org.apache.hadoop.hive.ql.parse
 class ASTErrorNode
           
 

Methods in org.apache.hadoop.hive.ql.parse that return ASTNode
static ASTNode ParseUtils.findRootNonNullToken(ASTNode tree)
          Performs a descent of the leftmost branch of a tree, stopping when either a node with a non-null token is found or the leaf level is encountered.
 ASTNode PTFInvocationSpec.PTFInputSpec.getAstNode()
           
static ASTNode PTFTranslator.getASTNode(ColumnInfo cInfo, RowResolver rr)
           
 ASTNode QBParseInfo.getClusterByForClause(String clause)
          Get the Cluster By AST for the clause.
 ASTNode QBParseInfo.getDestForClause(String clause)
           
 ASTNode QBParseInfo.getDistributeByForClause(String clause)
          Get the Distribute By AST for the clause.
 ASTNode TypeCheckCtx.getErrorSrcNode()
           
 ASTNode WindowingSpec.WindowExpressionSpec.getExpression()
           
 ASTNode WindowingSpec.ValueBoundarySpec.getExpression()
           
 ASTNode PTFInvocationSpec.PartitionExpression.getExpression()
           
 ASTNode RowResolver.getExpressionSource(ASTNode node)
          Retrieves the source expression matching a given ASTNode's string rendering exactly.
 ASTNode QBParseInfo.getGroupByForClause(String clause)
           
 ASTNode QBParseInfo.getHavingForClause(String clause)
           
 ASTNode QBParseInfo.getHints()
           
 ASTNode QBParseInfo.getJoinExpr()
           
 ASTNode QBParseInfo.getOrderByForClause(String clause)
           
 ASTNode ParseContext.getParseTree()
           
 ASTNode QBParseInfo.getSelForClause(String clause)
           
 ASTNode QBParseInfo.getSortByForClause(String clause)
          Get the Sort By AST for the clause.
 ASTNode QBParseInfo.getSrcForAlias(String alias)
           
 ASTNode ASTNodeOrigin.getUsageNode()
           
 ASTNode QBParseInfo.getWhrForClause(String clause)
           
 ASTNode ParseDriver.parse(String command)
           
 ASTNode ParseDriver.parse(String command, Context ctx)
          Parses a command, optionally assigning the parser's token stream to the given context.
 ASTNode ParseDriver.parseSelect(String command, Context ctx)
           
 ASTNode HiveSemanticAnalyzerHook.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
          Invoked before Hive performs its own semantic analysis on a statement.
 ASTNode AbstractSemanticAnalyzerHook.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
           
 

Methods in org.apache.hadoop.hive.ql.parse that return types with arguments of type ASTNode
 Map<ASTNode,ExprNodeDesc> SemanticAnalyzer.genAllExprNodeDesc(ASTNode expr, RowResolver input)
          Generates an expression node descriptors for the expression and children of it with default TypeCheckCtx.
 Map<ASTNode,ExprNodeDesc> SemanticAnalyzer.genAllExprNodeDesc(ASTNode expr, RowResolver input, TypeCheckCtx tcCtx)
          Generates all of the expression node descriptors for the expression and children of it passed in the arguments.
static Map<ASTNode,ExprNodeDesc> TypeCheckProcFactory.genExprNode(ASTNode expr, TypeCheckCtx tcCtx)
           
 HashMap<String,ASTNode> QBParseInfo.getAggregationExprsForClause(String clause)
           
 Map<String,ArrayList<ASTNode>> QBParseInfo.getAliasToLateralViews()
           
 Map<ASTNode,String> QBParseInfo.getAllExprToColumnAlias()
           
 ArrayList<ASTNode> WindowingSpec.WindowFunctionSpec.getArgs()
           
 ArrayList<ASTNode> PTFInvocationSpec.PartitionedTableFunctionSpec.getArgs()
           
 LinkedHashMap<String,LinkedHashMap<String,ASTNode>> QBParseInfo.getDestToAggregationExprs()
           
 HashMap<String,ASTNode> QBParseInfo.getDestToClusterBy()
           
 HashMap<String,List<ASTNode>> QBParseInfo.getDestToDistinctFuncExprs()
           
 HashMap<String,ASTNode> QBParseInfo.getDestToDistributeBy()
           
 HashMap<String,ASTNode> QBParseInfo.getDestToGroupBy()
           
 Map<String,ASTNode> QBParseInfo.getDestToHaving()
           
 HashMap<String,ASTNode> QBParseInfo.getDestToLateralView()
           
 HashMap<String,ASTNode> QBParseInfo.getDestToOrderBy()
           
 HashMap<String,ASTNode> QBParseInfo.getDestToSortBy()
           
 HashMap<String,ASTNode> QBParseInfo.getDestToWhereExpr()
           
 List<ASTNode> QBParseInfo.getDistinctFuncExprsForClause(String clause)
           
 Map<String,ASTNode> RowResolver.getExpressionMap()
           
 ArrayList<ArrayList<ASTNode>> QBJoinTree.getExpressions()
           
 ArrayList<ASTNode> TableSample.getExprs()
          Gets the ON part's expression list.
 ArrayList<ArrayList<ASTNode>> QBJoinTree.getFilters()
           
 ArrayList<ArrayList<ASTNode>> QBJoinTree.getFiltersForPushing()
           
 List<ASTNode> QBParseInfo.getLateralViewsForAlias(String alias)
           
 HashMap<ASTNode,PTFInvocationSpec> QB.getPTFNodeToSpec()
           
 ArrayList<ASTNode> QBJoinTree.getRHSSemijoinColumns(String alias)
           
 HashMap<String,ASTNode> QBParseInfo.getWindowingExprsForClause(String clause)
           
 

Methods in org.apache.hadoop.hive.ql.parse with parameters of type ASTNode
 void WindowingSpec.WindowFunctionSpec.addArg(ASTNode arg)
           
 void PTFInvocationSpec.PartitionedTableFunctionSpec.addArg(ASTNode arg)
           
 void QBParseInfo.addLateralViewForAlias(String alias, ASTNode lateralView)
           
 void QB.addPTFNodeToSpec(ASTNode node, PTFInvocationSpec spec)
           
 void QBJoinTree.addRHSSemijoinColumns(String alias, ASTNode column)
          Remeber the mapping of table alias to set of columns.
 void QBParseInfo.addWindowingExprToClause(String clause, ASTNode windowingExprNode)
           
 void ColumnStatsSemanticAnalyzer.analyze(ASTNode ast, Context origCtx)
           
 void BaseSemanticAnalyzer.analyze(ASTNode ast, Context ctx)
           
protected  void BaseSemanticAnalyzer.analyzeDDLSkewedValues(List<List<String>> skewedValues, ASTNode child)
          Handle skewed values in DDL.
 void SemanticAnalyzer.analyzeInternal(ASTNode ast)
           
 void ExportSemanticAnalyzer.analyzeInternal(ASTNode ast)
           
abstract  void BaseSemanticAnalyzer.analyzeInternal(ASTNode ast)
           
 void LoadSemanticAnalyzer.analyzeInternal(ASTNode ast)
           
 void MacroSemanticAnalyzer.analyzeInternal(ASTNode ast)
           
 void ExplainSemanticAnalyzer.analyzeInternal(ASTNode ast)
           
 void DDLSemanticAnalyzer.analyzeInternal(ASTNode ast)
           
 void FunctionSemanticAnalyzer.analyzeInternal(ASTNode ast)
           
 void ImportSemanticAnalyzer.analyzeInternal(ASTNode ast)
           
protected  List<String> BaseSemanticAnalyzer.analyzeSkewedTablDDLColNames(List<String> skewedColNames, ASTNode child)
          Analyze list bucket column names
protected  boolean BaseSemanticAnalyzer.analyzeStoredAdDirs(ASTNode child)
          process stored as directories
 PTFDesc.PTFExpressionDef PTFTranslator.buildExpressionDef(PTFDesc.ShapeDetails inpShape, ASTNode arg)
           
 boolean SemanticAnalyzer.doPhase1(ASTNode ast, QB qb, org.apache.hadoop.hive.ql.parse.SemanticAnalyzer.Phase1Ctx ctx_1)
          Phase 1: (including, but not limited to): 1.
 void SemanticAnalyzer.doPhase1QBExpr(ASTNode ast, QBExpr qbexpr, String id, String alias)
           
static ASTNode ParseUtils.findRootNonNullToken(ASTNode tree)
          Performs a descent of the leftmost branch of a tree, stopping when either a node with a non-null token is found or the leaf level is encountered.
 Map<ASTNode,ExprNodeDesc> SemanticAnalyzer.genAllExprNodeDesc(ASTNode expr, RowResolver input)
          Generates an expression node descriptors for the expression and children of it with default TypeCheckCtx.
 Map<ASTNode,ExprNodeDesc> SemanticAnalyzer.genAllExprNodeDesc(ASTNode expr, RowResolver input, TypeCheckCtx tcCtx)
          Generates all of the expression node descriptors for the expression and children of it passed in the arguments.
static String SemanticAnalyzer.generateErrorMessage(ASTNode ast, String message)
           
static Map<ASTNode,ExprNodeDesc> TypeCheckProcFactory.genExprNode(ASTNode expr, TypeCheckCtx tcCtx)
           
 ExprNodeDesc SemanticAnalyzer.genExprNodeDesc(ASTNode expr, RowResolver input)
          Generates an expression node descriptor for the expression with TypeCheckCtx.
 ExprNodeDesc SemanticAnalyzer.genExprNodeDesc(ASTNode expr, RowResolver input, TypeCheckCtx tcCtx)
          Returns expression node descriptor for the expression.
static BaseSemanticAnalyzer SemanticAnalyzerFactory.get(HiveConf conf, ASTNode tree)
           
protected  List<String> BaseSemanticAnalyzer.getColumnNames(ASTNode ast)
           
protected  List<Order> BaseSemanticAnalyzer.getColumnNamesOrder(ASTNode ast)
           
protected  List<FieldSchema> BaseSemanticAnalyzer.getColumns(ASTNode ast)
           
static List<FieldSchema> BaseSemanticAnalyzer.getColumns(ASTNode ast, boolean lowerCase)
          Get the list of FieldSchema out of the ASTNode.
 ColumnInfo RowResolver.getExpression(ASTNode node)
          Retrieves the ColumnInfo corresponding to a source expression which exactly matches the string rendering of the given ASTNode.
 ASTNode RowResolver.getExpressionSource(ASTNode node)
          Retrieves the source expression matching a given ASTNode's string rendering exactly.
 String QBParseInfo.getExprToColumnAlias(ASTNode expr)
           
static String TypeCheckProcFactory.DefaultExprProcessor.getFunctionText(ASTNode expr, boolean isFunction)
           
 PTFInvocationSpec QB.getPTFInvocationSpec(ASTNode node)
           
protected  List<String> BaseSemanticAnalyzer.getSkewedValueFromASTNode(ASTNode ast)
          Given a ASTNode, return list of values.
static String DDLSemanticAnalyzer.getTypeName(ASTNode node)
           
protected static String BaseSemanticAnalyzer.getTypeStringFromAST(ASTNode typeNode)
           
static String BaseSemanticAnalyzer.getUnescapedName(ASTNode tableOrColumnNode)
          Get dequoted name from a table/column node.
static String BaseSemanticAnalyzer.getUnescapedName(ASTNode tableOrColumnNode, String currentDatabase)
           
static String BaseSemanticAnalyzer.getUnescapedUnqualifiedTableName(ASTNode node)
          Get the unqualified name from a table node.
static VarcharTypeParams ParseUtils.getVarcharParams(String typeName, ASTNode node)
           
protected  void BaseSemanticAnalyzer.handleGenericFileFormat(ASTNode node)
           
 boolean QBParseInfo.hasExprToColumnAlias(ASTNode expr)
           
static boolean ParseUtils.isJoinToken(ASTNode node)
          Tests whether the parse tree node is a join token.
 ASTNode HiveSemanticAnalyzerHook.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
          Invoked before Hive performs its own semantic analysis on a statement.
 ASTNode AbstractSemanticAnalyzerHook.preAnalyze(HiveSemanticAnalyzerHookContext context, ASTNode ast)
           
protected  void SemanticAnalyzer.processNoScanCommand(ASTNode tree)
          process analyze ...
protected  void SemanticAnalyzer.processPartialScanCommand(ASTNode tree)
          process analyze ...
 void RowResolver.putExpression(ASTNode node, ColumnInfo colInfo)
          Puts a resolver entry corresponding to a source expression which is to be used for identical expression recognition (e.g.
static void BaseSemanticAnalyzer.readProps(ASTNode prop, Map<String,String> mapProp)
          Converts parsed key/value properties pairs into a map.
 void PTFInvocationSpec.PTFInputSpec.setAstNode(ASTNode astNode)
           
 void QBParseInfo.setClusterByExprForClause(String clause, ASTNode ast)
          Set the Cluster By AST for the clause.
 void QBParseInfo.setDestForClause(String clause, ASTNode ast)
           
 void QBParseInfo.setDistributeByExprForClause(String clause, ASTNode ast)
          Set the Distribute By AST for the clause.
 void TypeCheckCtx.setError(String error, ASTNode errorSrcNode)
           
 void WindowingSpec.WindowExpressionSpec.setExpression(ASTNode expression)
           
 void WindowingSpec.ValueBoundarySpec.setExpression(ASTNode expression)
           
 void PTFInvocationSpec.PartitionExpression.setExpression(ASTNode expression)
           
 void QBParseInfo.setExprToColumnAlias(ASTNode expr, String alias)
           
 void QBParseInfo.setGroupByExprForClause(String clause, ASTNode ast)
           
 void QBParseInfo.setHavingExprForClause(String clause, ASTNode ast)
           
 void QBParseInfo.setHints(ASTNode hint)
           
 void QBParseInfo.setJoinExpr(ASTNode joinExpr)
           
 void QBParseInfo.setOrderByExprForClause(String clause, ASTNode ast)
           
 void ParseContext.setParseTree(ASTNode ast)
           
 void QBParseInfo.setSelExprForClause(String clause, ASTNode ast)
           
 void QBParseInfo.setSortByExprForClause(String clause, ASTNode ast)
          Set the Sort By AST for the clause.
 void QBParseInfo.setSrcForAlias(String alias, ASTNode ast)
           
 void QBParseInfo.setWhrExprForClause(String clause, ASTNode ast)
           
static void PTFTranslator.validateNoLeadLagInValueBoundarySpec(ASTNode node)
           
static void BaseSemanticAnalyzer.validatePartSpec(Table tbl, Map<String,String> partSpec, ASTNode astNode, HiveConf conf)
           
 

Method parameters in org.apache.hadoop.hive.ql.parse with type arguments of type ASTNode
 void QBParseInfo.addAggregationExprsForClause(String clause, LinkedHashMap<String,ASTNode> aggregationTrees)
           
 void QBJoinTree.addRHSSemijoinColumns(String alias, ArrayList<ASTNode> columns)
          Remeber the mapping of table alias to set of columns.
 void QBParseInfo.setAggregationExprsForClause(String clause, LinkedHashMap<String,ASTNode> aggregationTrees)
           
 void WindowingSpec.WindowFunctionSpec.setArgs(ArrayList<ASTNode> args)
           
 void PTFInvocationSpec.PartitionedTableFunctionSpec.setArgs(ArrayList<ASTNode> args)
           
 void QBParseInfo.setDistinctFuncExprsForClause(String clause, List<ASTNode> ast)
           
 void RowResolver.setExpressionMap(Map<String,ASTNode> expressionMap)
           
 void QBJoinTree.setExpressions(ArrayList<ArrayList<ASTNode>> expressions)
           
 void TableSample.setExprs(ArrayList<ASTNode> exprs)
          Sets the expression list.
 void QBJoinTree.setFilters(ArrayList<ArrayList<ASTNode>> filters)
           
 void QBJoinTree.setFiltersForPushing(ArrayList<ArrayList<ASTNode>> filters)
           
 

Constructors in org.apache.hadoop.hive.ql.parse with parameters of type ASTNode
ASTNode(ASTNode node)
           
ASTNodeOrigin(String objectType, String objectName, String objectDefinition, String usageAlias, ASTNode usageNode)
           
BaseSemanticAnalyzer.tableSpec(Hive db, HiveConf conf, ASTNode ast)
           
BaseSemanticAnalyzer.tableSpec(Hive db, HiveConf conf, ASTNode ast, boolean allowDynamicPartitionsSpec, boolean allowPartialPartitionsSpec)
           
ColumnStatsSemanticAnalyzer(HiveConf conf, ASTNode tree)
           
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)
           
 

Constructor parameters in org.apache.hadoop.hive.ql.parse with type arguments of type ASTNode
TableSample(String num, String den, ArrayList<ASTNode> exprs)
          Constructs the TableSample given the numerator, denominator and the list of ON clause expressions.
 

Uses of ASTNode in org.apache.hadoop.hive.ql.udf.ptf
 

Methods in org.apache.hadoop.hive.ql.udf.ptf with parameters of type ASTNode
static ExprNodeDesc MatchPath.ResultExpressionParser.buildExprNode(ASTNode expr, TypeCheckCtx typeCheckCtx)
           
 



Copyright © 2012 The Apache Software Foundation