Package org.apache.spark.sql.errors
Class QueryParsingErrors
Object
org.apache.spark.sql.errors.QueryParsingErrors
Object for grouping all error messages of the query parsing. Currently it includes all
ParseException.
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionstatic Throwable
addCatalogInCacheTableAsSelectNotAllowedError
(String quoted, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CacheTableContext ctx) static Throwable
cannotCleanReservedNamespacePropertyError
(String property, org.antlr.v4.runtime.ParserRuleContext ctx, String msg) static Throwable
cannotCleanReservedTablePropertyError
(String property, org.antlr.v4.runtime.ParserRuleContext ctx, String msg) static Throwable
cannotParseValueTypeError
(String valueType, String value, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TypeConstructorContext ctx) static Throwable
cannotResolveWindowReferenceError
(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx) static Throwable
charTypeMissingLengthError
(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx) static Throwable
clusterByWithBucketing
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
clusterByWithPartitionedBy
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
columnAliasInOperationNotAllowedError
(String op, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TableAliasContext ctx) static Throwable
combinationQueryResultClausesUnsupportedError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.QueryOrganizationContext ctx) static Throwable
computeStatisticsNotExpectedError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentifierContext ctx) static Throwable
createFuncWithBothIfNotExistsAndReplaceError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
createTempTableNotSpecifyProviderError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateTableContext ctx) static Throwable
createViewWithBothIfNotExistsAndReplaceError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx) static Throwable
dataTypeUnsupportedError
(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx) static Throwable
defaultColumnNotEnabledError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
defaultColumnNotImplementedYetError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
defaultColumnReferencesNotAllowedInPartitionSpec
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
defineTempFuncWithIfNotExistsError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
defineTempViewWithIfNotExistsError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx) static Throwable
descColumnForPartitionUnsupportedError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.DescribeRelationContext ctx) static Throwable
directoryPathAndOptionsPathBothSpecifiedError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertOverwriteDirContext ctx) static Throwable
distributeByUnsupportedError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.QueryOrganizationContext ctx) static Throwable
duplicateArgumentNamesError
(scala.collection.immutable.Seq<String> arguments, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
duplicateClausesError
(String clauseName, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
duplicateCteDefinitionNamesError
(String duplicateNames, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CtesContext ctx) static Throwable
duplicatedTablePathsFoundError
(String pathOne, String pathTwo, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
duplicateKeysError
(String key, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
duplicateTableColumnDescriptor
(org.antlr.v4.runtime.ParserRuleContext ctx, String columnName, String optionName, boolean isCreate, String alterType) static Throwable
emptyInputForTableSampleError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
emptyPartitionKeyError
(String key, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PartitionSpecContext ctx) static Throwable
emptySourceForMergeError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) static Throwable
fromToIntervalUnsupportedError
(String from, String to, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
functionNameUnsupportedError
(String functionName, org.antlr.v4.runtime.ParserRuleContext ctx) static QueryContext[]
getQueryContext
(QueryContext context) static String
getSummary
(QueryContext sqlContext) static Throwable
identityColumnDuplicatedSequenceGeneratorOption
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentityColSpecContext ctx, String sequenceGeneratorOption) static Throwable
identityColumnIllegalStep
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentityColSpecContext ctx) static Throwable
identityColumnUnsupportedDataType
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentityColumnContext ctx, String dataType) static Throwable
incompatibleJoinTypesError
(String joinType1, String joinType2, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
insertedValueNumberNotMatchFieldNumberError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.NotMatchedClauseContext ctx) static Throwable
static Throwable
intervalValueOutOfRangeError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IntervalContext ctx) static Throwable
invalidBucketsNumberError
(String describe, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx) static Throwable
invalidByteLengthLiteralError
(String bytesStr, org.apache.spark.sql.catalyst.parser.SqlBaseParser.SampleByBytesContext ctx) static Throwable
invalidDatetimeUnitError
(org.antlr.v4.runtime.ParserRuleContext ctx, String functionName, String invalidValue) static Throwable
invalidEscapeStringError
(String invalidEscape, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PredicateContext ctx) static Throwable
invalidFromToUnitValueError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IntervalValueContext ctx) static Throwable
invalidGroupingSetError
(String element, org.apache.spark.sql.catalyst.parser.SqlBaseParser.GroupingAnalyticsContext ctx) static Throwable
invalidIdentifierError
(String ident, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
invalidInsertIntoError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertIntoContext ctx) static Throwable
invalidIntervalFormError
(String value, org.apache.spark.sql.catalyst.parser.SqlBaseParser.MultiUnitsIntervalContext ctx) static Throwable
invalidLateralJoinRelationError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.RelationPrimaryContext ctx) static Throwable
invalidNameForDropTempFunc
(scala.collection.immutable.Seq<String> name, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
invalidNumericLiteralRangeError
(String rawStrippedQualifier, scala.math.BigDecimal minValue, scala.math.BigDecimal maxValue, String typeName, org.apache.spark.sql.catalyst.parser.SqlBaseParser.NumberContext ctx) static Throwable
invalidPropertyKeyForSetQuotedConfigurationError
(String keyCandidate, String valueStr, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
invalidPropertyValueForSetQuotedConfigurationError
(String valueCandidate, String keyStr, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
invalidStatementError
(String operation, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
invalidTableFunctionIdentifierArgumentMissingParentheses
(org.antlr.v4.runtime.ParserRuleContext ctx, String argumentName) static Throwable
invalidTableValuedFunctionNameError
(scala.collection.immutable.Seq<String> name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TableValuedFunctionContext ctx) static Throwable
invalidTimeTravelSpec
(String reason, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
invalidTimeZoneDisplacementValueError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.SetTimeZoneContext ctx) static Throwable
invalidWindowReferenceError
(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx) static Throwable
lateralJoinWithUsingJoinUnsupportedError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
lateralWithPivotInFromClauseNotAllowedError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
lateralWithUnpivotInFromClauseNotAllowedError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
literalValueTypeUnsupportedError
(String unsupportedType, scala.collection.immutable.Seq<String> supportedTypes, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TypeConstructorContext ctx) static Throwable
mergeStatementWithoutWhenClauseError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) static Throwable
mixedIntervalUnitsError
(String literal, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
moreThanOneFromToUnitInIntervalLiteralError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
nestedTypeMissingElementTypeError
(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx) static Throwable
nonLastMatchedClauseOmitConditionError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) static Throwable
nonLastNotMatchedBySourceClauseOmitConditionError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) static Throwable
nonLastNotMatchedClauseOmitConditionError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) static Throwable
notAllowedToAddDBPrefixForTempViewError
(scala.collection.immutable.Seq<String> nameParts, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx) static Throwable
operationInHiveStyleCommandUnsupportedError
(String operation, String command, org.apache.spark.sql.catalyst.parser.SqlBaseParser.StatementContext ctx, scala.Option<String> msgOpt) static Throwable
operationNotAllowedError
(String message, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
parameterMarkerNotAllowed
(String statement, org.apache.spark.sql.catalyst.trees.Origin origin) static Throwable
parserStackOverflow
(org.antlr.v4.runtime.ParserRuleContext parserRuleContext) static Throwable
partitionTransformNotExpectedError
(String name, String expr, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx) static Throwable
propertiesAndDbPropertiesBothSpecifiedError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateNamespaceContext ctx) static Throwable
repetitiveWindowDefinitionError
(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx) static Throwable
rowFormatNotUsedWithStoredAsError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateTableLikeContext ctx) static Throwable
showFunctionsInvalidPatternError
(String pattern, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
showFunctionsUnsupportedError
(String identifier, org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentifierContext ctx) static Throwable
specifyingDBInCreateTempFuncError
(String databaseName, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
sqlStatementUnsupportedError
(String sqlText, org.apache.spark.sql.catalyst.trees.Origin position) static Throwable
storedAsAndStoredByBothSpecifiedError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFileFormatContext ctx) static Throwable
tableSampleByBytesUnsupportedError
(String msg, org.apache.spark.sql.catalyst.parser.SqlBaseParser.SampleMethodContext ctx) static Throwable
temporaryViewWithSchemaBindingMode
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.StatementContext ctx) static String
toDSOption
(String option) static String
static String
static String
static String
static String
static String
toSQLType
(org.apache.spark.sql.types.AbstractDataType t) static String
toSQLValue
(double value) static String
toSQLValue
(float value) static String
toSQLValue
(int value) static String
toSQLValue
(long value) static String
toSQLValue
(short value) static String
toSQLValue
(String value) static String
toSQLValue
(org.apache.spark.unsafe.types.UTF8String value) static Throwable
transformNotSupportQuantifierError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
transformWithSerdeUnsupportedError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
trimOptionUnsupportedError
(int trimOption, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TrimContext ctx) static Throwable
unclosedBracketedCommentError
(String command, org.apache.spark.sql.catalyst.trees.Origin start, org.apache.spark.sql.catalyst.trees.Origin stop) static Throwable
unexpectedFormatForResetConfigurationError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.ResetConfigurationContext ctx) static Throwable
unexpectedFormatForSetConfigurationError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
unpivotWithPivotInFromClauseNotAllowedError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
unsupportedFunctionNameError
(scala.collection.immutable.Seq<String> funcName, org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
unsupportedLateralJoinTypeError
(org.antlr.v4.runtime.ParserRuleContext ctx, String joinType) static Throwable
unsupportedLocalFileSchemeError
(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertOverwriteDirContext ctx, String actualSchema) static Throwable
useDefinedRecordReaderOrWriterClassesError
(org.antlr.v4.runtime.ParserRuleContext ctx) static Throwable
wrongNumberArgumentsForTransformError
(String name, int actualNum, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx)
-
Constructor Details
-
QueryParsingErrors
public QueryParsingErrors()
-
-
Method Details
-
invalidInsertIntoError
public static Throwable invalidInsertIntoError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertIntoContext ctx) -
parserStackOverflow
public static Throwable parserStackOverflow(org.antlr.v4.runtime.ParserRuleContext parserRuleContext) -
insertOverwriteDirectoryUnsupportedError
-
columnAliasInOperationNotAllowedError
-
emptySourceForMergeError
public static Throwable emptySourceForMergeError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) -
insertedValueNumberNotMatchFieldNumberError
public static Throwable insertedValueNumberNotMatchFieldNumberError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.NotMatchedClauseContext ctx) -
mergeStatementWithoutWhenClauseError
public static Throwable mergeStatementWithoutWhenClauseError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) -
nonLastMatchedClauseOmitConditionError
public static Throwable nonLastMatchedClauseOmitConditionError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) -
nonLastNotMatchedClauseOmitConditionError
public static Throwable nonLastNotMatchedClauseOmitConditionError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) -
nonLastNotMatchedBySourceClauseOmitConditionError
public static Throwable nonLastNotMatchedBySourceClauseOmitConditionError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) -
emptyPartitionKeyError
-
combinationQueryResultClausesUnsupportedError
public static Throwable combinationQueryResultClausesUnsupportedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.QueryOrganizationContext ctx) -
distributeByUnsupportedError
public static Throwable distributeByUnsupportedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.QueryOrganizationContext ctx) -
transformNotSupportQuantifierError
public static Throwable transformNotSupportQuantifierError(org.antlr.v4.runtime.ParserRuleContext ctx) -
transformWithSerdeUnsupportedError
public static Throwable transformWithSerdeUnsupportedError(org.antlr.v4.runtime.ParserRuleContext ctx) -
unpivotWithPivotInFromClauseNotAllowedError
public static Throwable unpivotWithPivotInFromClauseNotAllowedError(org.antlr.v4.runtime.ParserRuleContext ctx) -
lateralWithPivotInFromClauseNotAllowedError
public static Throwable lateralWithPivotInFromClauseNotAllowedError(org.antlr.v4.runtime.ParserRuleContext ctx) -
lateralWithUnpivotInFromClauseNotAllowedError
public static Throwable lateralWithUnpivotInFromClauseNotAllowedError(org.antlr.v4.runtime.ParserRuleContext ctx) -
lateralJoinWithUsingJoinUnsupportedError
public static Throwable lateralJoinWithUsingJoinUnsupportedError(org.antlr.v4.runtime.ParserRuleContext ctx) -
unsupportedLateralJoinTypeError
-
invalidLateralJoinRelationError
public static Throwable invalidLateralJoinRelationError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.RelationPrimaryContext ctx) -
repetitiveWindowDefinitionError
-
invalidWindowReferenceError
-
cannotResolveWindowReferenceError
-
incompatibleJoinTypesError
-
emptyInputForTableSampleError
-
tableSampleByBytesUnsupportedError
-
invalidByteLengthLiteralError
-
invalidEscapeStringError
-
trimOptionUnsupportedError
public static Throwable trimOptionUnsupportedError(int trimOption, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TrimContext ctx) -
functionNameUnsupportedError
-
cannotParseValueTypeError
-
literalValueTypeUnsupportedError
-
invalidNumericLiteralRangeError
-
moreThanOneFromToUnitInIntervalLiteralError
public static Throwable moreThanOneFromToUnitInIntervalLiteralError(org.antlr.v4.runtime.ParserRuleContext ctx) -
invalidIntervalFormError
-
invalidFromToUnitValueError
public static Throwable invalidFromToUnitValueError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IntervalValueContext ctx) -
fromToIntervalUnsupportedError
-
mixedIntervalUnitsError
-
dataTypeUnsupportedError
-
charTypeMissingLengthError
-
nestedTypeMissingElementTypeError
-
partitionTransformNotExpectedError
-
wrongNumberArgumentsForTransformError
-
invalidBucketsNumberError
-
cannotCleanReservedNamespacePropertyError
-
propertiesAndDbPropertiesBothSpecifiedError
public static Throwable propertiesAndDbPropertiesBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateNamespaceContext ctx) -
cannotCleanReservedTablePropertyError
-
duplicatedTablePathsFoundError
-
storedAsAndStoredByBothSpecifiedError
public static Throwable storedAsAndStoredByBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFileFormatContext ctx) -
operationInHiveStyleCommandUnsupportedError
-
operationNotAllowedError
-
invalidStatementError
-
descColumnForPartitionUnsupportedError
public static Throwable descColumnForPartitionUnsupportedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.DescribeRelationContext ctx) -
computeStatisticsNotExpectedError
public static Throwable computeStatisticsNotExpectedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentifierContext ctx) -
addCatalogInCacheTableAsSelectNotAllowedError
-
showFunctionsUnsupportedError
-
showFunctionsInvalidPatternError
-
duplicateCteDefinitionNamesError
-
sqlStatementUnsupportedError
-
invalidIdentifierError
-
duplicateClausesError
-
duplicateKeysError
-
unexpectedFormatForSetConfigurationError
public static Throwable unexpectedFormatForSetConfigurationError(org.antlr.v4.runtime.ParserRuleContext ctx) -
invalidPropertyKeyForSetQuotedConfigurationError
-
invalidPropertyValueForSetQuotedConfigurationError
-
unexpectedFormatForResetConfigurationError
public static Throwable unexpectedFormatForResetConfigurationError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.ResetConfigurationContext ctx) -
intervalValueOutOfRangeError
public static Throwable intervalValueOutOfRangeError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IntervalContext ctx) -
invalidTimeZoneDisplacementValueError
public static Throwable invalidTimeZoneDisplacementValueError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.SetTimeZoneContext ctx) -
createTempTableNotSpecifyProviderError
public static Throwable createTempTableNotSpecifyProviderError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateTableContext ctx) -
rowFormatNotUsedWithStoredAsError
public static Throwable rowFormatNotUsedWithStoredAsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateTableLikeContext ctx) -
useDefinedRecordReaderOrWriterClassesError
public static Throwable useDefinedRecordReaderOrWriterClassesError(org.antlr.v4.runtime.ParserRuleContext ctx) -
directoryPathAndOptionsPathBothSpecifiedError
public static Throwable directoryPathAndOptionsPathBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertOverwriteDirContext ctx) -
unsupportedLocalFileSchemeError
-
invalidGroupingSetError
-
identityColumnUnsupportedDataType
-
identityColumnIllegalStep
public static Throwable identityColumnIllegalStep(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentityColSpecContext ctx) -
identityColumnDuplicatedSequenceGeneratorOption
-
createViewWithBothIfNotExistsAndReplaceError
public static Throwable createViewWithBothIfNotExistsAndReplaceError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx) -
temporaryViewWithSchemaBindingMode
public static Throwable temporaryViewWithSchemaBindingMode(org.apache.spark.sql.catalyst.parser.SqlBaseParser.StatementContext ctx) -
parameterMarkerNotAllowed
-
defineTempViewWithIfNotExistsError
public static Throwable defineTempViewWithIfNotExistsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx) -
notAllowedToAddDBPrefixForTempViewError
-
createFuncWithBothIfNotExistsAndReplaceError
public static Throwable createFuncWithBothIfNotExistsAndReplaceError(org.antlr.v4.runtime.ParserRuleContext ctx) -
defineTempFuncWithIfNotExistsError
public static Throwable defineTempFuncWithIfNotExistsError(org.antlr.v4.runtime.ParserRuleContext ctx) -
unsupportedFunctionNameError
-
specifyingDBInCreateTempFuncError
-
invalidTableValuedFunctionNameError
-
unclosedBracketedCommentError
-
invalidTimeTravelSpec
-
invalidNameForDropTempFunc
-
defaultColumnNotImplementedYetError
public static Throwable defaultColumnNotImplementedYetError(org.antlr.v4.runtime.ParserRuleContext ctx) -
defaultColumnNotEnabledError
-
defaultColumnReferencesNotAllowedInPartitionSpec
public static Throwable defaultColumnReferencesNotAllowedInPartitionSpec(org.antlr.v4.runtime.ParserRuleContext ctx) -
duplicateArgumentNamesError
-
duplicateTableColumnDescriptor
-
invalidDatetimeUnitError
-
invalidTableFunctionIdentifierArgumentMissingParentheses
-
clusterByWithPartitionedBy
-
clusterByWithBucketing
-
toSQLId
-
toSQLId
-
toSQLStmt
-
toSQLConf
-
toSQLType
-
toSQLType
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
getSummary
-
getQueryContext
-
toDSOption
-