Interface | Description |
---|---|
HiveParserSqlFunctionConverter.CanAggregateDistinct |
CanAggregateDistinct.
|
HiveParserSubQueryUtils.ISubQueryJoinInfo |
ISubQueryJoinInfo.
|
Class | Description |
---|---|
HiveASTParseDriver |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.ParseDriver.
|
HiveASTParseDriver.ANTLRNoCaseStringStream |
ANTLRNoCaseStringStream.
|
HiveASTParseDriver.HiveLexerX |
HiveLexerX.
|
HiveASTParseError |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.ParseError.
|
HiveASTParseUtils |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.ParseUtils.
|
HiveParserASTBuilder |
Counterpart of hive's org.apache.hadoop.hive.ql.optimizer.calcite.translator.ASTBuilder.
|
HiveParserASTNode |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.ASTNode.
|
HiveParserASTNodeOrigin |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.ASTNodeOrigin.
|
HiveParserAuthorizationParseUtils |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.authorization.AuthorizationParseUtils.
|
HiveParserBaseSemanticAnalyzer |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.BaseSemanticAnalyzer, and also contains
code from SemanticAnalyzer and CalcitePlanner in order to limit file sizes.
|
HiveParserBaseSemanticAnalyzer.AggInfo |
Counterpart of hive's CalcitePlanner.AggInfo.
|
HiveParserBaseSemanticAnalyzer.AnalyzeRewriteContext |
Counterpart of hive's BaseSemanticAnalyzer.AnalyzeRewriteContext.
|
HiveParserBaseSemanticAnalyzer.GenericUDAFInfo |
Counterpart of hive's SemanticAnalyzer.GenericUDAFInfo.
|
HiveParserBaseSemanticAnalyzer.HiveParserRowFormatParams |
Counterpart of hive's BaseSemanticAnalyzer.RowFormatParams.
|
HiveParserBaseSemanticAnalyzer.NotNullConstraint |
Counterpart of hive's SQLNotNullConstraint.
|
HiveParserBaseSemanticAnalyzer.Phase1Ctx |
Counterpart of hive's SemanticAnalyzer.Phase1Ctx.
|
HiveParserBaseSemanticAnalyzer.PrimaryKey |
Counterpart of hive's SQLPrimaryKey.
|
HiveParserBaseSemanticAnalyzer.TableSpec |
Counterpart of hive's BaseSemanticAnalyzer.TableSpec.
|
HiveParserBetween |
Counterpart of hive's org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveBetween.
|
HiveParserContext |
Counterpart of hive's org.apache.hadoop.hive.ql.Context.
|
HiveParserDefaultGraphWalker |
Counterpart of hive's org.apache.hadoop.hive.ql.lib.DefaultGraphWalker.
|
HiveParserExpressionWalker |
Counterpart of hive's org.apache.hadoop.hive.ql.lib.ExpressionWalker.
|
HiveParserExprNodeColumnListDesc |
Counterpart of hive's org.apache.hadoop.hive.ql.plan.ExprNodeColumnListDesc.
|
HiveParserExprNodeDescUtils |
Counterpart of hive's ExprNodeDescUtils, but only contains methods that need overriding.
|
HiveParserExprNodeSubQueryDesc |
Counterpart of hive's org.apache.hadoop.hive.ql.plan.ExprNodeSubQueryDesc.
|
HiveParserExtractDate |
Counterpart of hive's org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveExtractDate.
|
HiveParserFloorDate |
Counterpart of hive's org.apache.hadoop.hive.ql.optimizer.calcite.reloperators.HiveFloorDate.
|
HiveParserIntervalDayTime |
Counterpart of hive's org.apache.hadoop.hive.common.type.HiveIntervalDayTime.
|
HiveParserIntervalYearMonth |
Counterpart of hive's org.apache.hadoop.hive.common.type.HiveIntervalYearMonth.
|
HiveParserJoinCondTypeCheckProcFactory |
Counterpart of hive's
org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinCondTypeCheckProcFactory.
|
HiveParserJoinCondTypeCheckProcFactory.JoinCondColumnExprProcessor |
Processor for table columns.
|
HiveParserJoinCondTypeCheckProcFactory.JoinCondDefaultExprProcessor |
The default processor for typechecking.
|
HiveParserJoinTypeCheckCtx |
Counterpart of hive's org.apache.hadoop.hive.ql.optimizer.calcite.translator.JoinTypeCheckCtx.
|
HiveParserNamedJoinInfo |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.NamedJoinInfo.
|
HiveParserPreCboCtx |
Counterpart of hive's CalcitePlanner.PreCboCtx.
|
HiveParserPTFInvocationSpec |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.PTFInvocationSpec.
|
HiveParserPTFInvocationSpec.OrderExpression |
OrderExpression.
|
HiveParserPTFInvocationSpec.OrderSpec |
OrderSpec.
|
HiveParserPTFInvocationSpec.PartitionedTableFunctionSpec |
PartitionedTableFunctionSpec.
|
HiveParserPTFInvocationSpec.PartitionExpression |
PartitionExpression.
|
HiveParserPTFInvocationSpec.PartitioningSpec |
PartitioningSpec.
|
HiveParserPTFInvocationSpec.PartitionSpec |
PartitionSpec.
|
HiveParserPTFInvocationSpec.PTFInputSpec |
PTFInputSpec.
|
HiveParserPTFInvocationSpec.PTFQueryInputSpec |
PTFQueryInputSpec.
|
HiveParserQB |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.QB.
|
HiveParserQBExpr |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.QBExpr.
|
HiveParserQBParseInfo |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.QBParseInfo.
|
HiveParserQBSubQuery |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.QBSubQuery.
|
HiveParserQBSubQuery.SubQueryTypeDef |
SubQueryTypeDef.
|
HiveParserQueryState |
Counterpart of hive's org.apache.hadoop.hive.ql.QueryState.
|
HiveParserRowResolver |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.RowResolver.
|
HiveParserSemanticAnalyzer |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.SemanticAnalyzer and adapted to our needs.
|
HiveParserSqlCountAggFunction |
Counterpart of hive's
org.apache.hadoop.hive.ql.optimizer.calcite.functions.HiveSqlCountAggFunction.
|
HiveParserSqlFunctionConverter |
Counterpart of hive's
org.apache.hadoop.hive.ql.optimizer.calcite.translator.SqlFunctionConverter.
|
HiveParserSqlFunctionConverter.CalciteSqlFn |
CalciteSqlFn.
|
HiveParserSqlMinMaxAggFunction |
Counterpart of hive's
org.apache.hadoop.hive.ql.optimizer.calcite.functions.HiveSqlMinMaxAggFunction.
|
HiveParserSqlSumAggFunction |
Counterpart of hive's
org.apache.hadoop.hive.ql.optimizer.calcite.functions.HiveSqlSumAggFunction.
|
HiveParserStorageFormat |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.StorageFormat.
|
HiveParserSubQueryDiagnostic |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.SubQueryDiagnostic.
|
HiveParserSubQueryDiagnostic.QBSubQueryRewrite |
Responsible for capturing SubQuery rewrites and providing the rewritten query as SQL.
|
HiveParserSubQueryDiagnostic.QBSubQueryRewriteNoop |
In the non explain code path, we don't need to track Query rewrites.
|
HiveParserSubQueryUtils |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.SubQueryUtils.
|
HiveParserTypeCheckCtx |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.TypeCheckCtx.
|
HiveParserTypeConverter |
Counterpart of hive's org.apache.hadoop.hive.ql.optimizer.calcite.translator.TypeConverter.
|
HiveParserTypeInfoUtils |
Add here what's missing in older version of hive's TypeInfoUtils.
|
HiveParserUnparseTranslator |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.UnparseTranslator.
|
HiveParserWindowingSpec |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.WindowingSpec.
|
HiveParserWindowingSpec.BoundarySpec |
BoundarySpec.
|
HiveParserWindowingSpec.WindowExpressionSpec |
WindowExpressionSpec.
|
HiveParserWindowingSpec.WindowFrameSpec |
WindowFrameSpec.
|
HiveParserWindowingSpec.WindowFunctionSpec |
WindowFunctionSpec.
|
HiveParserWindowingSpec.WindowSpec |
WindowSpec.
|
Enum | Description |
---|---|
HiveParserBaseSemanticAnalyzer.TableSpec.SpecType |
SpecType.
|
HiveParserBaseSemanticAnalyzer.TableType |
Counterpart of hive's CalcitePlanner.TableType.
|
HiveParserContext.DestClausePrefix |
DestClausePrefix.
|
HiveParserContext.Operation |
These ops require special handling in various places (note that Insert into Acid table is in
OTHER category).
|
HiveParserExprNodeSubQueryDesc.SubqueryType |
SubqueryType.
|
HiveParserPreCboCtx.Type |
Type.
|
HiveParserPTFInvocationSpec.NullOrder |
NullOrder.
|
HiveParserQBExpr.Opcode |
Opcode.
|
HiveParserQBSubQuery.SubQueryType |
SubQueryType.
|
HiveParserWindowingSpec.WindowType |
WindowType.
|
Exception | Description |
---|---|
HiveASTParseException |
Counterpart of hive's org.apache.hadoop.hive.ql.parse.ParseException.
|
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.