public class QueryParsingErrors
extends Object
Constructor and Description |
---|
QueryParsingErrors() |
Modifier and Type | Method and Description |
---|---|
static 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 |
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.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext 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.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext 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 |
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(org.apache.spark.sql.catalyst.trees.SQLQueryContext sqlContext) |
static String |
getSummary(org.apache.spark.sql.catalyst.trees.SQLQueryContext sqlContext) |
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 |
insertOverwriteDirectoryUnsupportedError() |
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.apache.spark.sql.catalyst.parser.SqlBaseParser.ErrorIdentContext 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.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 |
invalidTableFunctionIdentifierArgumentMissingParentheses(org.antlr.v4.runtime.ParserRuleContext ctx,
String argumentName) |
static Throwable |
invalidTableValuedFunctionNameError(scala.collection.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.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.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 |
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.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext 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 String |
toSQLConf(String conf) |
static String |
toSQLId(scala.collection.Seq<String> parts) |
static String |
toSQLId(String parts) |
static String |
toSQLStmt(String text) |
static String |
toSQLType(org.apache.spark.sql.types.AbstractDataType t) |
static String |
toSQLType(String text) |
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.Seq<String> funcName,
org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext 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) |
public static Throwable invalidInsertIntoError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertIntoContext ctx)
public static Throwable insertOverwriteDirectoryUnsupportedError()
public static Throwable columnAliasInOperationNotAllowedError(String op, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TableAliasContext ctx)
public static Throwable emptySourceForMergeError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx)
public static Throwable insertedValueNumberNotMatchFieldNumberError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.NotMatchedClauseContext ctx)
public static Throwable mergeStatementWithoutWhenClauseError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx)
public static Throwable nonLastMatchedClauseOmitConditionError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx)
public static Throwable nonLastNotMatchedClauseOmitConditionError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx)
public static Throwable nonLastNotMatchedBySourceClauseOmitConditionError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.MergeIntoTableContext ctx)
public static Throwable emptyPartitionKeyError(String key, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PartitionSpecContext ctx)
public static Throwable combinationQueryResultClausesUnsupportedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.QueryOrganizationContext ctx)
public static Throwable distributeByUnsupportedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.QueryOrganizationContext ctx)
public static Throwable transformNotSupportQuantifierError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable transformWithSerdeUnsupportedError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable unpivotWithPivotInFromClauseNotAllowedError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable lateralWithPivotInFromClauseNotAllowedError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable lateralWithUnpivotInFromClauseNotAllowedError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable lateralJoinWithUsingJoinUnsupportedError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable unsupportedLateralJoinTypeError(org.antlr.v4.runtime.ParserRuleContext ctx, String joinType)
public static Throwable invalidLateralJoinRelationError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.RelationPrimaryContext ctx)
public static Throwable repetitiveWindowDefinitionError(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx)
public static Throwable invalidWindowReferenceError(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx)
public static Throwable cannotResolveWindowReferenceError(String name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.WindowClauseContext ctx)
public static Throwable incompatibleJoinTypesError(String joinType1, String joinType2, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable emptyInputForTableSampleError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable tableSampleByBytesUnsupportedError(String msg, org.apache.spark.sql.catalyst.parser.SqlBaseParser.SampleMethodContext ctx)
public static Throwable invalidByteLengthLiteralError(String bytesStr, org.apache.spark.sql.catalyst.parser.SqlBaseParser.SampleByBytesContext ctx)
public static Throwable invalidEscapeStringError(String invalidEscape, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PredicateContext ctx)
public static Throwable trimOptionUnsupportedError(int trimOption, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TrimContext ctx)
public static Throwable functionNameUnsupportedError(String functionName, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable cannotParseValueTypeError(String valueType, String value, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TypeConstructorContext ctx)
public static Throwable literalValueTypeUnsupportedError(String unsupportedType, scala.collection.Seq<String> supportedTypes, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TypeConstructorContext ctx)
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)
public static Throwable moreThanOneFromToUnitInIntervalLiteralError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable invalidIntervalFormError(String value, org.apache.spark.sql.catalyst.parser.SqlBaseParser.MultiUnitsIntervalContext ctx)
public static Throwable invalidFromToUnitValueError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IntervalValueContext ctx)
public static Throwable fromToIntervalUnsupportedError(String from, String to, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable mixedIntervalUnitsError(String literal, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable dataTypeUnsupportedError(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx)
public static Throwable charTypeMissingLengthError(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx)
public static Throwable nestedTypeMissingElementTypeError(String dataType, org.apache.spark.sql.catalyst.parser.SqlBaseParser.PrimitiveDataTypeContext ctx)
public static Throwable partitionTransformNotExpectedError(String name, String expr, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx)
public static Throwable wrongNumberArgumentsForTransformError(String name, int actualNum, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx)
public static Throwable invalidBucketsNumberError(String describe, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ApplyTransformContext ctx)
public static Throwable cannotCleanReservedNamespacePropertyError(String property, org.antlr.v4.runtime.ParserRuleContext ctx, String msg)
public static Throwable propertiesAndDbPropertiesBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateNamespaceContext ctx)
public static Throwable cannotCleanReservedTablePropertyError(String property, org.antlr.v4.runtime.ParserRuleContext ctx, String msg)
public static Throwable duplicatedTablePathsFoundError(String pathOne, String pathTwo, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable storedAsAndStoredByBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFileFormatContext ctx)
public static Throwable operationInHiveStyleCommandUnsupportedError(String operation, String command, org.apache.spark.sql.catalyst.parser.SqlBaseParser.StatementContext ctx, scala.Option<String> msgOpt)
public static Throwable operationNotAllowedError(String message, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable descColumnForPartitionUnsupportedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.DescribeRelationContext ctx)
public static Throwable computeStatisticsNotExpectedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentifierContext ctx)
public static Throwable addCatalogInCacheTableAsSelectNotAllowedError(String quoted, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CacheTableContext ctx)
public static Throwable showFunctionsUnsupportedError(String identifier, org.apache.spark.sql.catalyst.parser.SqlBaseParser.IdentifierContext ctx)
public static Throwable showFunctionsInvalidPatternError(String pattern, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable duplicateCteDefinitionNamesError(String duplicateNames, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CtesContext ctx)
public static Throwable sqlStatementUnsupportedError(String sqlText, org.apache.spark.sql.catalyst.trees.Origin position)
public static Throwable invalidIdentifierError(String ident, org.apache.spark.sql.catalyst.parser.SqlBaseParser.ErrorIdentContext ctx)
public static Throwable duplicateClausesError(String clauseName, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable duplicateKeysError(String key, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable unexpectedFormatForSetConfigurationError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable invalidPropertyKeyForSetQuotedConfigurationError(String keyCandidate, String valueStr, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable invalidPropertyValueForSetQuotedConfigurationError(String valueCandidate, String keyStr, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable unexpectedFormatForResetConfigurationError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.ResetConfigurationContext ctx)
public static Throwable intervalValueOutOfRangeError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.IntervalContext ctx)
public static Throwable invalidTimeZoneDisplacementValueError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.SetTimeZoneContext ctx)
public static Throwable createTempTableNotSpecifyProviderError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateTableContext ctx)
public static Throwable rowFormatNotUsedWithStoredAsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateTableLikeContext ctx)
public static Throwable useDefinedRecordReaderOrWriterClassesError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable directoryPathAndOptionsPathBothSpecifiedError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertOverwriteDirContext ctx)
public static Throwable unsupportedLocalFileSchemeError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.InsertOverwriteDirContext ctx, String actualSchema)
public static Throwable invalidGroupingSetError(String element, org.apache.spark.sql.catalyst.parser.SqlBaseParser.GroupingAnalyticsContext ctx)
public static Throwable createViewWithBothIfNotExistsAndReplaceError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx)
public static Throwable parameterMarkerNotAllowed(String statement, org.apache.spark.sql.catalyst.trees.Origin origin)
public static Throwable defineTempViewWithIfNotExistsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx)
public static Throwable notAllowedToAddDBPrefixForTempViewError(scala.collection.Seq<String> nameParts, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateViewContext ctx)
public static Throwable createFuncWithBothIfNotExistsAndReplaceError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx)
public static Throwable defineTempFuncWithIfNotExistsError(org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx)
public static Throwable unsupportedFunctionNameError(scala.collection.Seq<String> funcName, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx)
public static Throwable specifyingDBInCreateTempFuncError(String databaseName, org.apache.spark.sql.catalyst.parser.SqlBaseParser.CreateFunctionContext ctx)
public static Throwable invalidTableValuedFunctionNameError(scala.collection.Seq<String> name, org.apache.spark.sql.catalyst.parser.SqlBaseParser.TableValuedFunctionContext ctx)
public static Throwable unclosedBracketedCommentError(String command, org.apache.spark.sql.catalyst.trees.Origin start, org.apache.spark.sql.catalyst.trees.Origin stop)
public static Throwable invalidTimeTravelSpec(String reason, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable invalidNameForDropTempFunc(scala.collection.Seq<String> name, org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable defaultColumnNotImplementedYetError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable defaultColumnNotEnabledError(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable defaultColumnReferencesNotAllowedInPartitionSpec(org.antlr.v4.runtime.ParserRuleContext ctx)
public static Throwable duplicateTableColumnDescriptor(org.antlr.v4.runtime.ParserRuleContext ctx, String columnName, String optionName, boolean isCreate, String alterType)
public static Throwable invalidDatetimeUnitError(org.antlr.v4.runtime.ParserRuleContext ctx, String functionName, String invalidValue)
public static Throwable invalidTableFunctionIdentifierArgumentMissingParentheses(org.antlr.v4.runtime.ParserRuleContext ctx, String argumentName)
public static String toSQLId(String parts)
public static String toSQLId(scala.collection.Seq<String> parts)
public static String toSQLStmt(String text)
public static String toSQLConf(String conf)
public static String toSQLType(String text)
public static String toSQLType(org.apache.spark.sql.types.AbstractDataType t)
public static String toSQLValue(String value)
public static String toSQLValue(org.apache.spark.unsafe.types.UTF8String value)
public static String toSQLValue(short value)
public static String toSQLValue(int value)
public static String toSQLValue(long value)
public static String toSQLValue(float value)
public static String toSQLValue(double value)
public static String getSummary(org.apache.spark.sql.catalyst.trees.SQLQueryContext sqlContext)
public static QueryContext[] getQueryContext(org.apache.spark.sql.catalyst.trees.SQLQueryContext sqlContext)