Package org.apache.hadoop.hive.ql.parse

Interface Summary
HiveSemanticAnalyzerHook HiveSemanticAnalyzerHook allows Hive to be extended with custom logic for semantic analysis of QL statements.
HiveSemanticAnalyzerHookContext Context information provided by Hive to implementations of HiveSemanticAnalyzerHook.
SubQueryUtils.ISubQueryJoinInfo  
 

Class Summary
AbstractSemanticAnalyzerHook  
AlterTablePartMergeFilesDesc  
ASTErrorNode  
ASTNode  
ASTNodeOrigin ASTNodeOrigin contains contextual information about the object from whose definition a particular ASTNode originated.
BaseSemanticAnalyzer BaseSemanticAnalyzer.
BaseSemanticAnalyzer.tableSpec tableSpec.
ColumnAccessAnalyzer  
ColumnAccessInfo  
ColumnStatsSemanticAnalyzer ColumnStatsSemanticAnalyzer.
DDLSemanticAnalyzer DDLSemanticAnalyzer.
EximUtil EximUtil.
ExplainSemanticAnalyzer ExplainSemanticAnalyzer.
ExportSemanticAnalyzer ExportSemanticAnalyzer.
FileSinkProcessor FileSinkProcessor handles addition of merge, move and stats tasks for filesinks
FunctionSemanticAnalyzer FunctionSemanticAnalyzer.
GenMapRedWalker Walks the operator tree in pre order fashion.
GenTezProcContext GenTezProcContext.
GenTezUtils GenTezUtils is a collection of shared helper methods to produce TezWork
GenTezWork GenTezWork separates the operator tree into tez tasks.
GenTezWorkWalker Walks the operator tree in DFS fashion.
GlobalLimitCtx context for pruning inputs.
HiveSemanticAnalyzerHookContextImpl  
ImportSemanticAnalyzer ImportSemanticAnalyzer.
IndexUpdater  
InputSignature The input signature of a function or operator.
JoinCond Join conditions Descriptor implementation.
LeadLagInfo Lead Lag functionality
LoadSemanticAnalyzer LoadSemanticAnalyzer.
MacroSemanticAnalyzer MacroSemanticAnalyzer.
MapReduceCompiler  
MetaDataExportListener This class listens for drop events and, if set, exports the table's metadata as JSON to the trash of the user performing the drop
OpParseContext Implementation of the Operator Parse Context.
OptimizeTezProcContext OptimizeTezProcContext.
ParseContext Parse Context: The current parse context.
ParseDriver ParseDriver.
ParseError  
ParseUtils Library of utility functions used in the parse code.
PrintOpTreeProcessor PrintOpTreeProcessor.
ProcessAnalyzeTable ProcessAnalyzeTable sets up work for the several variants of analyze table (normal, no scan, partial scan.) The plan at this point will be a single table scan operator.
PrunedPartitionList The list of pruned partitions.
PTFInvocationSpec  
PTFInvocationSpec.OrderExpression  
PTFInvocationSpec.OrderSpec  
PTFInvocationSpec.PartitionedTableFunctionSpec  
PTFInvocationSpec.PartitionExpression  
PTFInvocationSpec.PartitioningSpec  
PTFInvocationSpec.PartitionSpec  
PTFInvocationSpec.PTFInputSpec  
PTFInvocationSpec.PTFQueryInputSpec  
PTFTranslator  
PTFTranslator.ValidateNoLeadLag  
QB Implementation of the query block.
QBExpr Implementation of the query block expression.
QBJoinTree Internal representation of the join tree.
QBMetaData Implementation of the metadata information related to a query block.
QBParseInfo Implementation of the parse information related to a query block.
QBSubQuery  
QBSubQuery.SubQueryTypeDef  
RowResolver Implementation of the Row Resolver.
SemanticAnalyzer Implementation of the semantic analyzer.
SemanticAnalyzerFactory SemanticAnalyzerFactory.
SplitSample This class stores all the information specified in the TABLESAMPLE(...) clause.
SubQueryUtils  
TableAccessAnalyzer TableAccessAnalyzer walks the operator graph from joins and group bys to the table scan operator backing it.
TableAccessCtx This class implements the context information that is used for typechecking phase in query compilation.
TableAccessInfo  
TableSample This class stores all the information specified in the TABLESAMPLE clause.
TaskCompiler TaskCompiler is a the base class for classes that compile operator pipelines into tasks.
TaskCompilerFactory TaskCompilerFactory is a factory class to choose the appropriate TaskCompiler.
TezCompiler TezCompiler translates the operator plan into TezTasks.
TezWalker Walks the operator tree in DFS fashion.
TypeCheckCtx This class implements the context information that is used for typechecking phase in query compilation.
TypeCheckProcFactory The Factory for creating typecheck processors.
TypeCheckProcFactory.BoolExprProcessor Processor for boolean constants.
TypeCheckProcFactory.ColumnExprProcessor Processor for table columns.
TypeCheckProcFactory.DateExprProcessor Processor for date constants.
TypeCheckProcFactory.DefaultExprProcessor The default processor for typechecking.
TypeCheckProcFactory.NullExprProcessor Processor for processing NULL expression.
TypeCheckProcFactory.NumExprProcessor Processor for processing numeric constants.
TypeCheckProcFactory.StrExprProcessor Processor for processing string constants.
TypeCheckProcFactory.SubQueryExprProcessor Processor for subquery expressions..
VariableSubstitution  
WindowingComponentizer  
WindowingExprNodeEvaluatorFactory  
WindowingExprNodeEvaluatorFactory.FindLeadLagFuncExprs  
WindowingSpec  
WindowingSpec.BoundarySpec  
WindowingSpec.CurrentRowSpec  
WindowingSpec.RangeBoundarySpec  
WindowingSpec.ValueBoundarySpec  
WindowingSpec.WindowExpressionSpec  
WindowingSpec.WindowFrameSpec  
WindowingSpec.WindowFunctionSpec  
WindowingSpec.WindowSpec  
 

Enum Summary
BaseSemanticAnalyzer.tableSpec.SpecType  
JoinType JoinType.
PTFInvocationSpec.Order  
PTFInvocationSpec.PTFQueryInputType  
QBExpr.Opcode Opcode.
QBSubQuery.SubQueryType  
WindowingSpec.Direction  
 

Exception Summary
ParseException ParseException.
SemanticException Exception from SemanticAnalyzer.
 



Copyright © 2014 The Apache Software Foundation. All rights reserved.