FlinkExtendedParser |
Most code is copied from org.apache.flink.table.planner.parse.ExtendedParser.
|
FlinkExtendedParser.AbstractRegexParseStrategy |
Strategy to parse statement to Operation by regex.
|
HiveASTHintParser |
Counterpart of hive's HintParser.g.
|
HiveASTHintParser.hint_return |
|
HiveASTHintParser.hintArgName_return |
|
HiveASTHintParser.hintArgs_return |
|
HiveASTHintParser.hintItem_return |
|
HiveASTHintParser.hintList_return |
|
HiveASTHintParser.hintName_return |
|
HiveASTLexer |
Counterpart of hive's HiveLexer.g.
|
HiveASTParser |
Counterpart of hive's HiveParser.g.
|
HiveASTParser_FromClauseASTParser |
Counterpart of hive's FromClauseParser.g.
|
HiveASTParser_FromClauseASTParser.aliasList_return |
|
HiveASTParser_FromClauseASTParser.atomjoinSource_return |
|
HiveASTParser_FromClauseASTParser.expressionList_return |
|
HiveASTParser_FromClauseASTParser.fromClause_return |
|
HiveASTParser_FromClauseASTParser.fromSource_return |
|
HiveASTParser_FromClauseASTParser.joinSource_return |
|
HiveASTParser_FromClauseASTParser.joinSourcePart_return |
|
HiveASTParser_FromClauseASTParser.joinToken_return |
|
HiveASTParser_FromClauseASTParser.lateralView_return |
|
HiveASTParser_FromClauseASTParser.partitionedTableFunction_return |
|
HiveASTParser_FromClauseASTParser.partitioningSpec_return |
|
HiveASTParser_FromClauseASTParser.partitionTableFunctionSource_return |
|
HiveASTParser_FromClauseASTParser.searchCondition_return |
|
HiveASTParser_FromClauseASTParser.splitSample_return |
|
HiveASTParser_FromClauseASTParser.subQuerySource_return |
|
HiveASTParser_FromClauseASTParser.tableAlias_return |
|
HiveASTParser_FromClauseASTParser.tableAllColumns_return |
|
HiveASTParser_FromClauseASTParser.tableBucketSample_return |
|
HiveASTParser_FromClauseASTParser.tableName_return |
|
HiveASTParser_FromClauseASTParser.tableNameColList_return |
|
HiveASTParser_FromClauseASTParser.tableOrColumn_return |
|
HiveASTParser_FromClauseASTParser.tableSample_return |
|
HiveASTParser_FromClauseASTParser.tableSource_return |
|
HiveASTParser_FromClauseASTParser.uniqueJoinExpr_return |
|
HiveASTParser_FromClauseASTParser.uniqueJoinSource_return |
|
HiveASTParser_FromClauseASTParser.uniqueJoinTableSource_return |
|
HiveASTParser_FromClauseASTParser.uniqueJoinToken_return |
|
HiveASTParser_FromClauseASTParser.valueRowConstructor_return |
|
HiveASTParser_FromClauseASTParser.valuesClause_return |
|
HiveASTParser_FromClauseASTParser.valuesTableConstructor_return |
|
HiveASTParser_FromClauseASTParser.viewName_return |
|
HiveASTParser_FromClauseASTParser.virtualTableSource_return |
|
HiveASTParser_FromClauseASTParser.whereClause_return |
|
HiveASTParser_IdentifiersASTParser |
Counterpart of hive's IdentifiersParser.g.
|
HiveASTParser_IdentifiersASTParser.atomExpression_return |
|
HiveASTParser_IdentifiersASTParser.booleanValue_return |
|
HiveASTParser_IdentifiersASTParser.booleanValueTok_return |
|
HiveASTParser_IdentifiersASTParser.caseExpression_return |
|
HiveASTParser_IdentifiersASTParser.castExpression_return |
|
HiveASTParser_IdentifiersASTParser.charSetStringLiteral_return |
|
HiveASTParser_IdentifiersASTParser.clusterByClause_return |
|
HiveASTParser_IdentifiersASTParser.columnRefOrderInParenthesis_return |
|
HiveASTParser_IdentifiersASTParser.columnRefOrderNotInParenthesis_return |
|
HiveASTParser_IdentifiersASTParser.constant_return |
|
HiveASTParser_IdentifiersASTParser.dateLiteral_return |
|
HiveASTParser_IdentifiersASTParser.descFuncNames_return |
|
HiveASTParser_IdentifiersASTParser.distributeByClause_return |
|
HiveASTParser_IdentifiersASTParser.dropPartitionOperator_return |
|
HiveASTParser_IdentifiersASTParser.dropPartitionSpec_return |
|
HiveASTParser_IdentifiersASTParser.dropPartitionVal_return |
|
HiveASTParser_IdentifiersASTParser.expression_return |
|
HiveASTParser_IdentifiersASTParser.expressionPart_return |
|
HiveASTParser_IdentifiersASTParser.expressions_return |
|
HiveASTParser_IdentifiersASTParser.expressionsInParenthesis_return |
|
HiveASTParser_IdentifiersASTParser.expressionsNotInParenthesis_return |
|
HiveASTParser_IdentifiersASTParser.extractExpression_return |
|
HiveASTParser_IdentifiersASTParser.floorDateQualifiers_return |
|
HiveASTParser_IdentifiersASTParser.floorExpression_return |
|
HiveASTParser_IdentifiersASTParser.function_return |
|
HiveASTParser_IdentifiersASTParser.functionIdentifier_return |
|
HiveASTParser_IdentifiersASTParser.functionName_return |
|
HiveASTParser_IdentifiersASTParser.groupby_expression_return |
|
HiveASTParser_IdentifiersASTParser.groupByClause_return |
|
HiveASTParser_IdentifiersASTParser.groupByEmpty_return |
|
HiveASTParser_IdentifiersASTParser.groupingExpressionSingle_return |
|
HiveASTParser_IdentifiersASTParser.groupingSetExpression_return |
|
HiveASTParser_IdentifiersASTParser.groupingSetExpressionMultiple_return |
|
HiveASTParser_IdentifiersASTParser.havingClause_return |
|
HiveASTParser_IdentifiersASTParser.havingCondition_return |
|
HiveASTParser_IdentifiersASTParser.identifier_return |
|
HiveASTParser_IdentifiersASTParser.intervalExpression_return |
|
HiveASTParser_IdentifiersASTParser.intervalLiteral_return |
|
HiveASTParser_IdentifiersASTParser.intervalQualifiers_return |
|
HiveASTParser_IdentifiersASTParser.intervalValue_return |
|
HiveASTParser_IdentifiersASTParser.nonReserved_return |
|
HiveASTParser_IdentifiersASTParser.nullCondition_return |
|
HiveASTParser_IdentifiersASTParser.orderByClause_return |
|
HiveASTParser_IdentifiersASTParser.partitionByClause_return |
|
HiveASTParser_IdentifiersASTParser.partitionSpec_return |
|
HiveASTParser_IdentifiersASTParser.partitionVal_return |
|
HiveASTParser_IdentifiersASTParser.precedenceAmpersandExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceAmpersandOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceAndExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceAndOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceBitwiseOrExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceBitwiseOrOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceBitwiseXorExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceBitwiseXorOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceConcatenateExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceConcatenateOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceEqualExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceEqualOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceFieldExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceNotExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceNotOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceOrExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceOrOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedencePlusExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedencePlusOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceRegexpOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceSimilarExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceSimilarExpressionAtom_return |
|
HiveASTParser_IdentifiersASTParser.precedenceSimilarExpressionIn_return |
|
HiveASTParser_IdentifiersASTParser.precedenceSimilarExpressionMain_return |
|
HiveASTParser_IdentifiersASTParser.precedenceSimilarExpressionPart_return |
|
HiveASTParser_IdentifiersASTParser.precedenceSimilarExpressionPartNot_return |
|
HiveASTParser_IdentifiersASTParser.precedenceSimilarOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceStarExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceStarOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceUnaryOperator_return |
|
HiveASTParser_IdentifiersASTParser.precedenceUnaryPrefixExpression_return |
|
HiveASTParser_IdentifiersASTParser.precedenceUnarySuffixExpression_return |
|
HiveASTParser_IdentifiersASTParser.principalIdentifier_return |
|
HiveASTParser_IdentifiersASTParser.rollupOldSyntax_return |
|
HiveASTParser_IdentifiersASTParser.rollupStandard_return |
|
HiveASTParser_IdentifiersASTParser.sortByClause_return |
|
HiveASTParser_IdentifiersASTParser.sql11ReservedKeywordsUsedAsFunctionName_return |
|
HiveASTParser_IdentifiersASTParser.stringLiteralSequence_return |
|
HiveASTParser_IdentifiersASTParser.subQueryExpression_return |
|
HiveASTParser_IdentifiersASTParser.sysFuncNames_return |
|
HiveASTParser_IdentifiersASTParser.tableOrPartition_return |
|
HiveASTParser_IdentifiersASTParser.timeQualifiers_return |
|
HiveASTParser_IdentifiersASTParser.timestampLiteral_return |
|
HiveASTParser_IdentifiersASTParser.whenExpression_return |
|
HiveASTParser_SelectClauseASTParser |
Counterpart of hive's SelectClauseParser.g.
|
HiveASTParser_SelectClauseASTParser.selectClause_return |
|
HiveASTParser_SelectClauseASTParser.selectExpression_return |
|
HiveASTParser_SelectClauseASTParser.selectExpressionList_return |
|
HiveASTParser_SelectClauseASTParser.selectItem_return |
|
HiveASTParser_SelectClauseASTParser.selectList_return |
|
HiveASTParser_SelectClauseASTParser.selectTrfmClause_return |
|
HiveASTParser_SelectClauseASTParser.trfmClause_return |
|
HiveASTParser_SelectClauseASTParser.window_clause_return |
|
HiveASTParser_SelectClauseASTParser.window_defn_return |
|
HiveASTParser_SelectClauseASTParser.window_frame_boundary_return |
|
HiveASTParser_SelectClauseASTParser.window_frame_return |
|
HiveASTParser_SelectClauseASTParser.window_frame_start_boundary_return |
|
HiveASTParser_SelectClauseASTParser.window_range_expression_return |
|
HiveASTParser_SelectClauseASTParser.window_specification_return |
|
HiveASTParser_SelectClauseASTParser.window_value_expression_return |
|
HiveASTParser.abortTransactionStatement_return |
|
HiveASTParser.adminOptionFor_return |
|
HiveASTParser.alterColConstraint_return |
|
HiveASTParser.alterColumnConstraint_return |
|
HiveASTParser.alterConstraintWithName_return |
|
HiveASTParser.alterDatabaseStatementSuffix_return |
|
HiveASTParser.alterDatabaseSuffixProperties_return |
|
HiveASTParser.alterDatabaseSuffixSetLocation_return |
|
HiveASTParser.alterDatabaseSuffixSetOwner_return |
|
HiveASTParser.alterForeignKeyConstraint_return |
|
HiveASTParser.alterForeignKeyWithName_return |
|
HiveASTParser.alterIndexStatementSuffix_return |
|
HiveASTParser.alterStatement_return |
|
HiveASTParser.alterStatementChangeColPosition_return |
|
HiveASTParser.alterStatementPartitionKeyType_return |
|
HiveASTParser.alterStatementSuffixAddCol_return |
|
HiveASTParser.alterStatementSuffixAddConstraint_return |
|
HiveASTParser.alterStatementSuffixAddPartitions_return |
|
HiveASTParser.alterStatementSuffixAddPartitionsElement_return |
|
HiveASTParser.alterStatementSuffixArchive_return |
|
HiveASTParser.alterStatementSuffixBucketNum_return |
|
HiveASTParser.alterStatementSuffixClusterbySortby_return |
|
HiveASTParser.alterStatementSuffixCompact_return |
|
HiveASTParser.alterStatementSuffixDropConstraint_return |
|
HiveASTParser.alterStatementSuffixDropPartitions_return |
|
HiveASTParser.alterStatementSuffixExchangePartition_return |
|
HiveASTParser.alterStatementSuffixFileFormat_return |
|
HiveASTParser.alterStatementSuffixLocation_return |
|
HiveASTParser.alterStatementSuffixMergeFiles_return |
|
HiveASTParser.alterStatementSuffixProperties_return |
|
HiveASTParser.alterStatementSuffixRename_return |
|
HiveASTParser.alterStatementSuffixRenameCol_return |
|
HiveASTParser.alterStatementSuffixRenamePart_return |
|
HiveASTParser.alterStatementSuffixSerdeProperties_return |
|
HiveASTParser.alterStatementSuffixSkewedby_return |
|
HiveASTParser.alterStatementSuffixStatsPart_return |
|
HiveASTParser.alterStatementSuffixTouch_return |
|
HiveASTParser.alterStatementSuffixUnArchive_return |
|
HiveASTParser.alterStatementSuffixUpdateStats_return |
|
HiveASTParser.alterStatementSuffixUpdateStatsCol_return |
|
HiveASTParser.alterTableStatementSuffix_return |
|
HiveASTParser.alterTblPartitionStatementSuffix_return |
|
HiveASTParser.alterTblPartitionStatementSuffixSkewedLocation_return |
|
HiveASTParser.alterViewStatementSuffix_return |
|
HiveASTParser.alterViewSuffixProperties_return |
|
HiveASTParser.analyzeStatement_return |
|
HiveASTParser.atomSelectStatement_return |
|
HiveASTParser.autoRebuild_return |
|
HiveASTParser.blocking_return |
|
HiveASTParser.body_return |
|
HiveASTParser.colConstraint_return |
|
HiveASTParser.colType_return |
|
HiveASTParser.colTypeList_return |
|
HiveASTParser.columnAssignmentClause_return |
|
HiveASTParser.columnConstraintType_return |
|
HiveASTParser.columnName_return |
|
HiveASTParser.columnNameColonType_return |
|
HiveASTParser.columnNameColonTypeList_return |
|
HiveASTParser.columnNameComment_return |
|
HiveASTParser.columnNameCommentList_return |
|
HiveASTParser.columnNameList_return |
|
HiveASTParser.columnNameOrder_return |
|
HiveASTParser.columnNameOrderList_return |
|
HiveASTParser.columnNameType_return |
|
HiveASTParser.columnNameTypeConstraint_return |
|
HiveASTParser.columnNameTypeList_return |
|
HiveASTParser.columnNameTypeOrConstraint_return |
|
HiveASTParser.columnNameTypeOrConstraintList_return |
|
HiveASTParser.columnParenthesesList_return |
|
HiveASTParser.columnRefOrder_return |
|
HiveASTParser.commitStatement_return |
|
HiveASTParser.constraintOptsAlter_return |
|
HiveASTParser.constraintOptsCreate_return |
|
HiveASTParser.constraintTraits_return |
|
HiveASTParser.createDatabaseStatement_return |
|
HiveASTParser.createFunctionStatement_return |
|
HiveASTParser.createIndexStatement_return |
|
HiveASTParser.createMacroStatement_return |
|
HiveASTParser.createMaterializedViewStatement_return |
|
HiveASTParser.createRoleStatement_return |
|
HiveASTParser.createTableStatement_return |
|
HiveASTParser.createViewStatement_return |
|
HiveASTParser.cteStatement_return |
|
HiveASTParser.databaseComment_return |
|
HiveASTParser.dbLocation_return |
|
HiveASTParser.dbProperties_return |
|
HiveASTParser.dbPropertiesList_return |
|
HiveASTParser.ddlStatement_return |
|
HiveASTParser.deleteStatement_return |
|
HiveASTParser.descStatement_return |
|
HiveASTParser.destination_return |
|
HiveASTParser.dropDatabaseStatement_return |
|
HiveASTParser.dropFunctionStatement_return |
|
HiveASTParser.dropIndexStatement_return |
|
HiveASTParser.dropMacroStatement_return |
|
HiveASTParser.dropMaterializedViewStatement_return |
|
HiveASTParser.dropRoleStatement_return |
|
HiveASTParser.dropTableStatement_return |
|
HiveASTParser.dropViewStatement_return |
|
HiveASTParser.enableSpecification_return |
|
HiveASTParser.enableValidateSpecification_return |
|
HiveASTParser.execStatement_return |
|
HiveASTParser.explainOption_return |
|
HiveASTParser.explainStatement_return |
|
HiveASTParser.exportStatement_return |
|
HiveASTParser.extColumnName_return |
|
HiveASTParser.fileFormat_return |
|
HiveASTParser.fromStatement_return |
|
HiveASTParser.grantOptionFor_return |
|
HiveASTParser.grantPrivileges_return |
|
HiveASTParser.grantRole_return |
|
HiveASTParser.ifExists_return |
|
HiveASTParser.ifNotExists_return |
|
HiveASTParser.importStatement_return |
|
HiveASTParser.indexComment_return |
|
HiveASTParser.indexProperties_return |
|
HiveASTParser.indexPropertiesList_return |
|
HiveASTParser.indexPropertiesPrefixed_return |
|
HiveASTParser.indexTblName_return |
|
HiveASTParser.insertClause_return |
|
HiveASTParser.isolationLevel_return |
|
HiveASTParser.keyProperty_return |
|
HiveASTParser.keyValueProperty_return |
|
HiveASTParser.levelOfIsolation_return |
|
HiveASTParser.limitClause_return |
|
HiveASTParser.listType_return |
|
HiveASTParser.loadStatement_return |
|
HiveASTParser.lockDatabase_return |
|
HiveASTParser.lockMode_return |
|
HiveASTParser.lockStatement_return |
|
HiveASTParser.mapType_return |
|
HiveASTParser.mergeStatement_return |
|
HiveASTParser.metastoreCheck_return |
|
HiveASTParser.nullOrdering_return |
|
HiveASTParser.orderSpecification_return |
|
HiveASTParser.orReplace_return |
|
HiveASTParser.partitionLocation_return |
|
HiveASTParser.partTypeExpr_return |
|
HiveASTParser.primitiveType_return |
|
HiveASTParser.principalName_return |
|
HiveASTParser.principalSpecification_return |
|
HiveASTParser.privilegeIncludeColObject_return |
|
HiveASTParser.privilegeList_return |
|
HiveASTParser.privilegeObject_return |
|
HiveASTParser.privilegeType_return |
|
HiveASTParser.privlegeDef_return |
|
HiveASTParser.privObject_return |
|
HiveASTParser.privObjectCols_return |
|
HiveASTParser.queryStatementExpression_return |
|
HiveASTParser.queryStatementExpressionBody_return |
|
HiveASTParser.recordReader_return |
|
HiveASTParser.recordWriter_return |
|
HiveASTParser.regularBody_return |
|
HiveASTParser.reloadFunctionStatement_return |
|
HiveASTParser.relySpecification_return |
|
HiveASTParser.replDumpStatement_return |
|
HiveASTParser.replicationClause_return |
|
HiveASTParser.replLoadStatement_return |
|
HiveASTParser.replStatusStatement_return |
|
HiveASTParser.resource_return |
|
HiveASTParser.resourceList_return |
|
HiveASTParser.resourceType_return |
|
HiveASTParser.restrictOrCascade_return |
|
HiveASTParser.revokePrivileges_return |
|
HiveASTParser.revokeRole_return |
|
HiveASTParser.rewriteDisabled_return |
|
HiveASTParser.rewriteEnabled_return |
|
HiveASTParser.rollbackStatement_return |
|
HiveASTParser.rowFormat_return |
|
HiveASTParser.rowFormatDelimited_return |
|
HiveASTParser.rowFormatSerde_return |
|
HiveASTParser.selectStatement_return |
|
HiveASTParser.selectStatementWithCTE_return |
|
HiveASTParser.setAutoCommitStatement_return |
|
HiveASTParser.setColumnsClause_return |
|
HiveASTParser.setOperator_return |
|
HiveASTParser.setOpSelectStatement_return |
|
HiveASTParser.setRole_return |
|
HiveASTParser.showCurrentRole_return |
|
HiveASTParser.showFunctionIdentifier_return |
|
HiveASTParser.showGrants_return |
|
HiveASTParser.showRoleGrants_return |
|
HiveASTParser.showRolePrincipals_return |
|
HiveASTParser.showRoles_return |
|
HiveASTParser.showStatement_return |
|
HiveASTParser.showStmtIdentifier_return |
|
HiveASTParser.singleFromStatement_return |
|
HiveASTParser.skewedColumnValue_return |
|
HiveASTParser.skewedColumnValuePair_return |
|
HiveASTParser.skewedColumnValuePairList_return |
|
HiveASTParser.skewedColumnValues_return |
|
HiveASTParser.skewedLocationMap_return |
|
HiveASTParser.skewedLocations_return |
|
HiveASTParser.skewedLocationsList_return |
|
HiveASTParser.skewedValueElement_return |
|
HiveASTParser.skewedValueLocationElement_return |
|
HiveASTParser.sqlTransactionStatement_return |
|
HiveASTParser.startTransactionStatement_return |
|
HiveASTParser.statement_return |
|
HiveASTParser.storedAsDirs_return |
|
HiveASTParser.structType_return |
|
HiveASTParser.switchDatabaseStatement_return |
|
HiveASTParser.tableBuckets_return |
|
HiveASTParser.tableComment_return |
|
HiveASTParser.tableConstraint_return |
|
HiveASTParser.tableConstraintType_return |
|
HiveASTParser.tableFileFormat_return |
|
HiveASTParser.tableLocation_return |
|
HiveASTParser.tablePartition_return |
|
HiveASTParser.tablePartitionPrefix_return |
|
HiveASTParser.tableProperties_return |
|
HiveASTParser.tablePropertiesList_return |
|
HiveASTParser.tablePropertiesPrefixed_return |
|
HiveASTParser.tableRowFormat_return |
|
HiveASTParser.tableRowFormatCollItemsIdentifier_return |
|
HiveASTParser.tableRowFormatFieldIdentifier_return |
|
HiveASTParser.tableRowFormatLinesIdentifier_return |
|
HiveASTParser.tableRowFormatMapKeysIdentifier_return |
|
HiveASTParser.tableRowNullFormat_return |
|
HiveASTParser.tableSkewed_return |
|
HiveASTParser.tabPartColTypeExpr_return |
|
HiveASTParser.tabTypeExpr_return |
|
HiveASTParser.transactionAccessMode_return |
|
HiveASTParser.transactionMode_return |
|
HiveASTParser.truncateTableStatement_return |
|
HiveASTParser.type_return |
|
HiveASTParser.unionType_return |
|
HiveASTParser.unlockDatabase_return |
|
HiveASTParser.unlockStatement_return |
|
HiveASTParser.updateOrDelete_return |
|
HiveASTParser.updateStatement_return |
|
HiveASTParser.validateSpecification_return |
|
HiveASTParser.vectorizationOnly_return |
|
HiveASTParser.vectorizatonDetail_return |
|
HiveASTParser.viewPartition_return |
|
HiveASTParser.whenClauses_return |
|
HiveASTParser.whenMatchedAndClause_return |
|
HiveASTParser.whenMatchedThenClause_return |
|
HiveASTParser.whenNotMatchedClause_return |
|
HiveASTParser.withAdminOption_return |
|
HiveASTParser.withClause_return |
|
HiveASTParser.withGrantOption_return |
|
HiveParserCreateViewInfo |
Information for create view operation.
|
HiveParserDDLSemanticAnalyzer |
Ported hive's org.apache.hadoop.hive.ql.parse.DDLSemanticAnalyzer, and also incorporated
functionalities from SemanticAnalyzer and FunctionSemanticAnalyzer.
|
HiveParserErrorMsg |
Util class to generate error messages with HiveParserASTNode.
|
HiveParserLoadSemanticAnalyzer |
Ported hive's org.apache.hadoop.hive.ql.parse.LoadSemanticAnalyzer.
|