Class QueryParsingErrors

Object
org.apache.spark.sql.errors.QueryParsingErrors

public class QueryParsingErrors extends Object
Object for grouping all error messages of the query parsing. Currently it includes all ParseException.
  • Constructor Details

    • QueryParsingErrors

      public QueryParsingErrors()
  • Method Details

    • invalidInsertIntoError

      public static Throwable invalidInsertIntoError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertIntoContext ctx)
    • insertOverwriteDirectoryUnsupportedError

      public static Throwable insertOverwriteDirectoryUnsupportedError()
    • columnAliasInOperationNotAllowedError

      public static Throwable columnAliasInOperationNotAllowedError(String op, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TableAliasContext ctx)
    • 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

      public static Throwable emptyPartitionKeyError(String key, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PartitionSpecContext ctx)
    • 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

      public static Throwable unsupportedLateralJoinTypeError(org.antlr.v4.runtime.ParserRuleContext ctx, String joinType)
    • invalidLateralJoinRelationError

      public static Throwable invalidLateralJoinRelationError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.RelationPrimaryContext ctx)
    • repetitiveWindowDefinitionError

      public static Throwable repetitiveWindowDefinitionError(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx)
    • invalidWindowReferenceError

      public static Throwable invalidWindowReferenceError(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx)
    • cannotResolveWindowReferenceError

      public static Throwable cannotResolveWindowReferenceError(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx)
    • incompatibleJoinTypesError

      public static Throwable incompatibleJoinTypesError(String joinType1, String joinType2, org.antlr.v4.runtime.ParserRuleContext ctx)
    • emptyInputForTableSampleError

      public static Throwable emptyInputForTableSampleError(org.antlr.v4.runtime.ParserRuleContext ctx)
    • tableSampleByBytesUnsupportedError

      public static Throwable tableSampleByBytesUnsupportedError(String msg, org.apache.spark.sql.catalyst.parser.SqlBaseParser.SampleMethodContext ctx)
    • invalidByteLengthLiteralError

      public static Throwable invalidByteLengthLiteralError(String bytesStr, org.apache.spark.sql.catalyst.parser.SqlBaseParser.SampleByBytesContext ctx)
    • invalidEscapeStringError

      public static Throwable invalidEscapeStringError(String invalidEscape, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PredicateContext ctx)
    • trimOptionUnsupportedError

      public static Throwable trimOptionUnsupportedError(int trimOption, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TrimContext ctx)
    • functionNameUnsupportedError

      public static Throwable functionNameUnsupportedError(String functionName, org.antlr.v4.runtime.ParserRuleContext ctx)
    • cannotParseValueTypeError

      public static Throwable cannotParseValueTypeError(String valueType, String value, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TypeConstructorContext ctx)
    • literalValueTypeUnsupportedError

      public static Throwable literalValueTypeUnsupportedError(String unsupportedType, scala.collection.Seq<String> supportedTypes, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TypeConstructorContext ctx)
    • invalidNumericLiteralRangeError

      public static Throwable invalidNumericLiteralRangeError(String rawStrippedQualifier, scala.math.BigDecimal minValue, scala.math.BigDecimal maxValue, String typeName, org.apache.spark.sql.catalyst.parser.SqlBaseParser.NumberContext ctx)
    • moreThanOneFromToUnitInIntervalLiteralError

      public static Throwable moreThanOneFromToUnitInIntervalLiteralError(org.antlr.v4.runtime.ParserRuleContext ctx)
    • invalidIntervalFormError

      public static Throwable invalidIntervalFormError(String value, org.apache.spark.sql.catalyst.parser.SqlBaseParser.MultiUnitsIntervalContext ctx)
    • invalidFromToUnitValueError

      public static Throwable invalidFromToUnitValueError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IntervalValueContext ctx)
    • fromToIntervalUnsupportedError

      public static Throwable fromToIntervalUnsupportedError(String from, String to, org.antlr.v4.runtime.ParserRuleContext ctx)
    • mixedIntervalUnitsError

      public static Throwable mixedIntervalUnitsError(String literal, org.antlr.v4.runtime.ParserRuleContext ctx)
    • dataTypeUnsupportedError

      public static Throwable dataTypeUnsupportedError(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx)
    • charTypeMissingLengthError

      public static Throwable charTypeMissingLengthError(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx)
    • nestedTypeMissingElementTypeError

      public static Throwable nestedTypeMissingElementTypeError(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx)
    • partitionTransformNotExpectedError

      public static Throwable partitionTransformNotExpectedError(String name, String expr, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx)
    • wrongNumberArgumentsForTransformError

      public static Throwable wrongNumberArgumentsForTransformError(String name, int actualNum, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx)
    • invalidBucketsNumberError

      public static Throwable invalidBucketsNumberError(String describe, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx)
    • cannotCleanReservedNamespacePropertyError

      public static Throwable cannotCleanReservedNamespacePropertyError(String property, org.antlr.v4.runtime.ParserRuleContext ctx, String msg)
    • propertiesAndDbPropertiesBothSpecifiedError

      public static Throwable propertiesAndDbPropertiesBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateNamespaceContext ctx)
    • cannotCleanReservedTablePropertyError

      public static Throwable cannotCleanReservedTablePropertyError(String property, org.antlr.v4.runtime.ParserRuleContext ctx, String msg)
    • duplicatedTablePathsFoundError

      public static Throwable duplicatedTablePathsFoundError(String pathOne, String pathTwo, org.antlr.v4.runtime.ParserRuleContext ctx)
    • storedAsAndStoredByBothSpecifiedError

      public static Throwable storedAsAndStoredByBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFileFormatContext ctx)
    • operationInHiveStyleCommandUnsupportedError

      public static Throwable operationInHiveStyleCommandUnsupportedError(String operation, String command, org.apache.spark.sql.catalyst.parser.SqlBaseParser.StatementContext ctx, scala.Option<String> msgOpt)
    • operationNotAllowedError

      public static Throwable operationNotAllowedError(String message, org.antlr.v4.runtime.ParserRuleContext ctx)
    • 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

      public static Throwable addCatalogInCacheTableAsSelectNotAllowedError(String quoted, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CacheTableContext ctx)
    • showFunctionsUnsupportedError

      public static Throwable showFunctionsUnsupportedError(String identifier, org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentifierContext ctx)
    • showFunctionsInvalidPatternError

      public static Throwable showFunctionsInvalidPatternError(String pattern, org.antlr.v4.runtime.ParserRuleContext ctx)
    • duplicateCteDefinitionNamesError

      public static Throwable duplicateCteDefinitionNamesError(String duplicateNames, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CtesContext ctx)
    • sqlStatementUnsupportedError

      public static Throwable sqlStatementUnsupportedError(String sqlText, org.apache.spark.sql.catalyst.trees.Origin position)
    • invalidIdentifierError

      public static Throwable invalidIdentifierError(String ident, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ErrorIdentContext ctx)
    • duplicateClausesError

      public static Throwable duplicateClausesError(String clauseName, org.antlr.v4.runtime.ParserRuleContext ctx)
    • duplicateKeysError

      public static Throwable duplicateKeysError(String key, org.antlr.v4.runtime.ParserRuleContext ctx)
    • unexpectedFormatForSetConfigurationError

      public static Throwable unexpectedFormatForSetConfigurationError(org.antlr.v4.runtime.ParserRuleContext ctx)
    • invalidPropertyKeyForSetQuotedConfigurationError

      public static Throwable invalidPropertyKeyForSetQuotedConfigurationError(String keyCandidate, String valueStr, org.antlr.v4.runtime.ParserRuleContext ctx)
    • invalidPropertyValueForSetQuotedConfigurationError

      public static Throwable invalidPropertyValueForSetQuotedConfigurationError(String valueCandidate, String keyStr, org.antlr.v4.runtime.ParserRuleContext ctx)
    • 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

      public static Throwable unsupportedLocalFileSchemeError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertOverwriteDirContext ctx, String actualSchema)
    • invalidGroupingSetError

      public static Throwable invalidGroupingSetError(String element, org.apache.spark.sql.catalyst.parser.SqlBaseParser.GroupingAnalyticsContext ctx)
    • createViewWithBothIfNotExistsAndReplaceError

      public static Throwable createViewWithBothIfNotExistsAndReplaceError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx)
    • parameterMarkerNotAllowed

      public static Throwable parameterMarkerNotAllowed(String statement, org.apache.spark.sql.catalyst.trees.Origin origin)
    • defineTempViewWithIfNotExistsError

      public static Throwable defineTempViewWithIfNotExistsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx)
    • notAllowedToAddDBPrefixForTempViewError

      public static Throwable notAllowedToAddDBPrefixForTempViewError(scala.collection.Seq<String> nameParts, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx)
    • 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

      public static Throwable unsupportedFunctionNameError(scala.collection.Seq<String> funcName, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx)
    • specifyingDBInCreateTempFuncError

      public static Throwable specifyingDBInCreateTempFuncError(String databaseName, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx)
    • invalidTableValuedFunctionNameError

      public static Throwable invalidTableValuedFunctionNameError(scala.collection.Seq<String> name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TableValuedFunctionContext ctx)
    • unclosedBracketedCommentError

      public static Throwable unclosedBracketedCommentError(String command, org.apache.spark.sql.catalyst.trees.Origin start, org.apache.spark.sql.catalyst.trees.Origin stop)
    • invalidTimeTravelSpec

      public static Throwable invalidTimeTravelSpec(String reason, org.antlr.v4.runtime.ParserRuleContext ctx)
    • invalidNameForDropTempFunc

      public static Throwable invalidNameForDropTempFunc(scala.collection.Seq<String> name, org.antlr.v4.runtime.ParserRuleContext ctx)
    • defaultColumnNotImplementedYetError

      public static Throwable defaultColumnNotImplementedYetError(org.antlr.v4.runtime.ParserRuleContext ctx)
    • defaultColumnNotEnabledError

      public static Throwable defaultColumnNotEnabledError(org.antlr.v4.runtime.ParserRuleContext ctx)
    • defaultColumnReferencesNotAllowedInPartitionSpec

      public static Throwable defaultColumnReferencesNotAllowedInPartitionSpec(org.antlr.v4.runtime.ParserRuleContext ctx)
    • duplicateTableColumnDescriptor

      public static Throwable duplicateTableColumnDescriptor(org.antlr.v4.runtime.ParserRuleContext ctx, String columnName, String optionName, boolean isCreate, String alterType)
    • invalidDatetimeUnitError

      public static Throwable invalidDatetimeUnitError(org.antlr.v4.runtime.ParserRuleContext ctx, String functionName, String invalidValue)
    • invalidTableFunctionIdentifierArgumentMissingParentheses

      public static Throwable invalidTableFunctionIdentifierArgumentMissingParentheses(org.antlr.v4.runtime.ParserRuleContext ctx, String argumentName)
    • toSQLId

      public static String toSQLId(String parts)
    • toSQLId

      public static String toSQLId(scala.collection.Seq<String> parts)
    • toSQLStmt

      public static String toSQLStmt(String text)
    • toSQLConf

      public static String toSQLConf(String conf)
    • toSQLType

      public static String toSQLType(String text)
    • toSQLType

      public static String toSQLType(org.apache.spark.sql.types.AbstractDataType t)
    • toSQLValue

      public static String toSQLValue(String value)
    • toSQLValue

      public static String toSQLValue(org.apache.spark.unsafe.types.UTF8String value)
    • toSQLValue

      public static String toSQLValue(short value)
    • toSQLValue

      public static String toSQLValue(int value)
    • toSQLValue

      public static String toSQLValue(long value)
    • toSQLValue

      public static String toSQLValue(float value)
    • toSQLValue

      public static String toSQLValue(double value)
    • getSummary

      public static String getSummary(org.apache.spark.sql.catalyst.trees.SQLQueryContext sqlContext)
    • getQueryContext

      public static QueryContext[] getQueryContext(org.apache.spark.sql.catalyst.trees.SQLQueryContext sqlContext)