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
Constructors -
Method Summary
Modifier and TypeMethodDescriptionstatic ThrowableaddCatalogInCacheTableAsSelectNotAllowedError(String quoted, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CacheTableContext ctx) static ThrowablecannotCleanReservedNamespacePropertyError(String property, org.antlr.v4.runtime.ParserRuleContext ctx, String msg) static ThrowablecannotCleanReservedTablePropertyError(String property, org.antlr.v4.runtime.ParserRuleContext ctx, String msg) static ThrowablecannotParseValueTypeError(String valueType, String value, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TypeConstructorContext ctx) static ThrowablecannotResolveWindowReferenceError(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx) static ThrowablecharTypeMissingLengthError(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx) static ThrowablecolumnAliasInOperationNotAllowedError(String op, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TableAliasContext ctx) static ThrowablecombinationQueryResultClausesUnsupportedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.QueryOrganizationContext ctx) static ThrowablecomputeStatisticsNotExpectedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentifierContext ctx) static ThrowablecreateFuncWithBothIfNotExistsAndReplaceError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx) static ThrowablecreateTempTableNotSpecifyProviderError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateTableContext ctx) static ThrowablecreateViewWithBothIfNotExistsAndReplaceError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx) static ThrowabledataTypeUnsupportedError(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx) static ThrowabledefaultColumnNotEnabledError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowabledefaultColumnNotImplementedYetError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowabledefaultColumnReferencesNotAllowedInPartitionSpec(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowabledefineTempFuncWithIfNotExistsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx) static ThrowabledefineTempViewWithIfNotExistsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx) static ThrowabledescColumnForPartitionUnsupportedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.DescribeRelationContext ctx) static ThrowabledirectoryPathAndOptionsPathBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertOverwriteDirContext ctx) static ThrowabledistributeByUnsupportedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.QueryOrganizationContext ctx) static ThrowableduplicateClausesError(String clauseName, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableduplicateCteDefinitionNamesError(String duplicateNames, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CtesContext ctx) static ThrowableduplicatedTablePathsFoundError(String pathOne, String pathTwo, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableduplicateKeysError(String key, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableduplicateTableColumnDescriptor(org.antlr.v4.runtime.ParserRuleContext ctx, String columnName, String optionName, boolean isCreate, String alterType) static ThrowableemptyInputForTableSampleError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableemptyPartitionKeyError(String key, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PartitionSpecContext ctx) static ThrowableemptySourceForMergeError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) static ThrowablefromToIntervalUnsupportedError(String from, String to, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowablefunctionNameUnsupportedError(String functionName, org.antlr.v4.runtime.ParserRuleContext ctx) static QueryContext[]getQueryContext(org.apache.spark.sql.catalyst.trees.SQLQueryContext sqlContext) static StringgetSummary(org.apache.spark.sql.catalyst.trees.SQLQueryContext sqlContext) static ThrowableincompatibleJoinTypesError(String joinType1, String joinType2, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableinsertedValueNumberNotMatchFieldNumberError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.NotMatchedClauseContext ctx) static Throwablestatic ThrowableintervalValueOutOfRangeError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IntervalContext ctx) static ThrowableinvalidBucketsNumberError(String describe, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx) static ThrowableinvalidByteLengthLiteralError(String bytesStr, org.apache.spark.sql.catalyst.parser.SqlBaseParser.SampleByBytesContext ctx) static ThrowableinvalidDatetimeUnitError(org.antlr.v4.runtime.ParserRuleContext ctx, String functionName, String invalidValue) static ThrowableinvalidEscapeStringError(String invalidEscape, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PredicateContext ctx) static ThrowableinvalidFromToUnitValueError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IntervalValueContext ctx) static ThrowableinvalidGroupingSetError(String element, org.apache.spark.sql.catalyst.parser.SqlBaseParser.GroupingAnalyticsContext ctx) static ThrowableinvalidIdentifierError(String ident, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ErrorIdentContext ctx) static ThrowableinvalidInsertIntoError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertIntoContext ctx) static ThrowableinvalidIntervalFormError(String value, org.apache.spark.sql.catalyst.parser.SqlBaseParser.MultiUnitsIntervalContext ctx) static ThrowableinvalidLateralJoinRelationError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.RelationPrimaryContext ctx) static ThrowableinvalidNameForDropTempFunc(scala.collection.Seq<String> name, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableinvalidNumericLiteralRangeError(String rawStrippedQualifier, scala.math.BigDecimal minValue, scala.math.BigDecimal maxValue, String typeName, org.apache.spark.sql.catalyst.parser.SqlBaseParser.NumberContext ctx) static ThrowableinvalidPropertyKeyForSetQuotedConfigurationError(String keyCandidate, String valueStr, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableinvalidPropertyValueForSetQuotedConfigurationError(String valueCandidate, String keyStr, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableinvalidTableFunctionIdentifierArgumentMissingParentheses(org.antlr.v4.runtime.ParserRuleContext ctx, String argumentName) static ThrowableinvalidTableValuedFunctionNameError(scala.collection.Seq<String> name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TableValuedFunctionContext ctx) static ThrowableinvalidTimeTravelSpec(String reason, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableinvalidTimeZoneDisplacementValueError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.SetTimeZoneContext ctx) static ThrowableinvalidWindowReferenceError(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx) static ThrowablelateralJoinWithUsingJoinUnsupportedError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowablelateralWithPivotInFromClauseNotAllowedError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowablelateralWithUnpivotInFromClauseNotAllowedError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableliteralValueTypeUnsupportedError(String unsupportedType, scala.collection.Seq<String> supportedTypes, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TypeConstructorContext ctx) static ThrowablemergeStatementWithoutWhenClauseError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) static ThrowablemixedIntervalUnitsError(String literal, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowablemoreThanOneFromToUnitInIntervalLiteralError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowablenestedTypeMissingElementTypeError(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx) static ThrowablenonLastMatchedClauseOmitConditionError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) static ThrowablenonLastNotMatchedBySourceClauseOmitConditionError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) static ThrowablenonLastNotMatchedClauseOmitConditionError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx) static ThrowablenotAllowedToAddDBPrefixForTempViewError(scala.collection.Seq<String> nameParts, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx) static ThrowableoperationInHiveStyleCommandUnsupportedError(String operation, String command, org.apache.spark.sql.catalyst.parser.SqlBaseParser.StatementContext ctx, scala.Option<String> msgOpt) static ThrowableoperationNotAllowedError(String message, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableparameterMarkerNotAllowed(String statement, org.apache.spark.sql.catalyst.trees.Origin origin) static ThrowablepartitionTransformNotExpectedError(String name, String expr, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx) static ThrowablepropertiesAndDbPropertiesBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateNamespaceContext ctx) static ThrowablerepetitiveWindowDefinitionError(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx) static ThrowablerowFormatNotUsedWithStoredAsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateTableLikeContext ctx) static ThrowableshowFunctionsInvalidPatternError(String pattern, org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableshowFunctionsUnsupportedError(String identifier, org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentifierContext ctx) static ThrowablespecifyingDBInCreateTempFuncError(String databaseName, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx) static ThrowablesqlStatementUnsupportedError(String sqlText, org.apache.spark.sql.catalyst.trees.Origin position) static ThrowablestoredAsAndStoredByBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFileFormatContext ctx) static ThrowabletableSampleByBytesUnsupportedError(String msg, org.apache.spark.sql.catalyst.parser.SqlBaseParser.SampleMethodContext ctx) static Stringstatic Stringstatic Stringstatic Stringstatic Stringstatic StringtoSQLType(org.apache.spark.sql.types.AbstractDataType t) static StringtoSQLValue(double value) static StringtoSQLValue(float value) static StringtoSQLValue(int value) static StringtoSQLValue(long value) static StringtoSQLValue(short value) static StringtoSQLValue(String value) static StringtoSQLValue(org.apache.spark.unsafe.types.UTF8String value) static ThrowabletransformNotSupportQuantifierError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowabletransformWithSerdeUnsupportedError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowabletrimOptionUnsupportedError(int trimOption, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TrimContext ctx) static ThrowableunclosedBracketedCommentError(String command, org.apache.spark.sql.catalyst.trees.Origin start, org.apache.spark.sql.catalyst.trees.Origin stop) static ThrowableunexpectedFormatForResetConfigurationError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.ResetConfigurationContext ctx) static ThrowableunexpectedFormatForSetConfigurationError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableunpivotWithPivotInFromClauseNotAllowedError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowableunsupportedFunctionNameError(scala.collection.Seq<String> funcName, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx) static ThrowableunsupportedLateralJoinTypeError(org.antlr.v4.runtime.ParserRuleContext ctx, String joinType) static ThrowableunsupportedLocalFileSchemeError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertOverwriteDirContext ctx, String actualSchema) static ThrowableuseDefinedRecordReaderOrWriterClassesError(org.antlr.v4.runtime.ParserRuleContext ctx) static ThrowablewrongNumberArgumentsForTransformError(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) -
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
-
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
-
createViewWithBothIfNotExistsAndReplaceError
public static Throwable createViewWithBothIfNotExistsAndReplaceError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx) -
parameterMarkerNotAllowed
-
defineTempViewWithIfNotExistsError
public static Throwable defineTempViewWithIfNotExistsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx) -
notAllowedToAddDBPrefixForTempViewError
-
createFuncWithBothIfNotExistsAndReplaceError
public static Throwable createFuncWithBothIfNotExistsAndReplaceError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx) -
defineTempFuncWithIfNotExistsError
public static Throwable defineTempFuncWithIfNotExistsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext 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) -
duplicateTableColumnDescriptor
-
invalidDatetimeUnitError
-
invalidTableFunctionIdentifierArgumentMissingParentheses
-
toSQLId
-
toSQLId
-
toSQLStmt
-
toSQLConf
-
toSQLType
-
toSQLType
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
getSummary
-
getQueryContext
public static QueryContext[] getQueryContext(org.apache.spark.sql.catalyst.trees.SQLQueryContext sqlContext)
-