| Interface | Description |
|---|---|
| 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.
|
| SemanticAnalyzer.PlannerContextFactory | |
| SubQueryUtils.ISubQueryJoinInfo |
| Class | Description |
|---|---|
| AbstractSemanticAnalyzerHook | |
| AlterTablePartMergeFilesDesc | |
| AnalyzeCommandUtils | |
| AppMasterEventProcessor |
FileSinkProcessor is a simple rule to remember seen unions for later
processing.
|
| ASTErrorNode | |
| ASTNode | |
| ASTNodeOrigin |
ASTNodeOrigin contains contextual information about the object from whose
definition a particular ASTNode originated.
|
| BaseSemanticAnalyzer |
BaseSemanticAnalyzer.
|
| BaseSemanticAnalyzer.TableSpec |
TableSpec.
|
| CalcitePlanner | |
| CalcitePlanner.ASTSearcher | |
| ColumnAccessAnalyzer | |
| ColumnAccessInfo | |
| ColumnStatsAutoGatherContext |
ColumnStatsAutoGatherContext: This is passed to the compiler when set
hive.stats.autogather=true during the INSERT OVERWRITE command.
|
| ColumnStatsList |
The list of column stats and their state.
|
| ColumnStatsSemanticAnalyzer |
ColumnStatsSemanticAnalyzer.
|
| DDLSemanticAnalyzer |
DDLSemanticAnalyzer.
|
| DruidSqlOperatorConverter |
Contains custom Druid SQL operator converter classes, contains either:
Hive specific OperatorConversion logic that can not be part of Calcite
Some temporary OperatorConversion that is not release by Calcite yet
|
| DruidSqlOperatorConverter.DruidDateArithmeticOperatorConversion |
Base class for Date Add/Sub operator conversion
|
| DruidSqlOperatorConverter.DruidDateTruncOperatorConversion |
Operator conversion form Hive TRUNC UDF to Druid Date Time UDFs.
|
| DruidSqlOperatorConverter.DruidFormUnixTimeOperatorConversion | |
| DruidSqlOperatorConverter.DruidSubstringOperatorConversion |
Druid operator converter from Hive Substring to Druid SubString.
|
| DruidSqlOperatorConverter.DruidToDateOperatorConversion |
Expression operator conversion form Hive TO_DATE operator to Druid Date cast.
|
| DruidSqlOperatorConverter.DruidUnixTimestampOperatorConversion | |
| DruidSqlOperatorConverter.UnaryFunctionOperatorConversion | |
| EximUtil |
EximUtil.
|
| EximUtil.SemanticAnalyzerWrapperContext |
Wrapper class for common BaseSemanticAnalyzer non-static members
into static generic methods without having the fn signatures
becoming overwhelming, with passing each of these into every function.
|
| ExplainConfiguration |
ExplainConfiguration
|
| ExplainSemanticAnalyzer |
ExplainSemanticAnalyzer.
|
| ExplainSQRewriteSemanticAnalyzer | |
| ExportSemanticAnalyzer |
ExportSemanticAnalyzer.
|
| FileSinkProcessor |
FileSinkProcessor is a simple rule to remember seen file sinks for later
processing.
|
| 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.
|
| GenTezUtils.DynamicListContext | |
| GenTezUtils.DynamicPartitionPrunerContext | |
| GenTezUtils.DynamicPartitionPrunerProc | |
| 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.
|
| InputSignature |
The input signature of a function or operator.
|
| JoinCond |
Join conditions Descriptor implementation.
|
| LeadLagInfo |
Lead Lag functionality
|
| LoadSemanticAnalyzer |
LoadSemanticAnalyzer.
|
| MacroSemanticAnalyzer |
MacroSemanticAnalyzer.
|
| MapReduceCompiler | |
| MaskAndFilterInfo | |
| MaterializedViewRebuildSemanticAnalyzer |
MaterializedViewRebuildSemanticAnalyzer.
|
| 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
|
| NamedJoinInfo |
NamedColsInJoin encapsulates information about using clause of join.
|
| 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.
|
| PreInsertTableDesc | |
| PrintOpTreeProcessor |
PrintOpTreeProcessor.
|
| ProcessAnalyzeTable |
ProcessAnalyzeTable sets up work for the several variants of analyze table
(normal, no 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 | |
| ReplicationSemanticAnalyzer | |
| ReplicationSpec |
Statements executed to handle replication have some additional
information relevant to the replication subsystem - this class
captures those bits of information.
|
| RowResolver |
Implementation of the Row Resolver.
|
| RuntimeValuesInfo |
Holds structures required for runtime values and mappings.
|
| SemanticAnalyzer |
Implementation of the semantic analyzer.
|
| SemanticAnalyzer.GenericUDAFInfo |
Class to store GenericUDAF related information.
|
| SemanticAnalyzerFactory |
SemanticAnalyzerFactory.
|
| SemiJoinBranchInfo | |
| SemiJoinHint | |
| SplitSample |
This class stores all the information specified in the TABLESAMPLE(...) clause.
|
| StorageFormat | |
| SubQueryDiagnostic | |
| SubQueryDiagnostic.QBSubQueryRewrite | |
| SubQueryDiagnostic.QBSubQueryRewriteNoop | |
| 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 | |
| TableMask |
The main purpose for this class is for authorization.
|
| 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.DateTimeExprProcessor |
Processor for date constants.
|
| TypeCheckProcFactory.DefaultExprProcessor |
The default processor for typechecking.
|
| TypeCheckProcFactory.IntervalExprProcessor |
Processor for interval constants.
|
| 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..
|
| UnionProcessor |
FileSinkProcessor is a simple rule to remember seen unions for later
processing.
|
| UnparseTranslator |
UnparseTranslator is used to "unparse" objects such as views when their
definition is stored.
|
| UpdateDeleteSemanticAnalyzer |
A subclass of the
SemanticAnalyzer that just handles
update, delete and merge statements. |
| WindowingComponentizer | |
| WindowingExprNodeEvaluatorFactory | |
| WindowingExprNodeEvaluatorFactory.FindLeadLagFuncExprs | |
| WindowingSpec | |
| WindowingSpec.BoundarySpec | |
| WindowingSpec.WindowExpressionSpec | |
| WindowingSpec.WindowFrameSpec | |
| WindowingSpec.WindowFunctionSpec | |
| WindowingSpec.WindowSpec |
| Exception | Description |
|---|---|
| ParseException |
ParseException.
|
| SemanticException |
Exception from SemanticAnalyzer.
|
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.