Package org.apache.spark.sql.errors
Class QueryCompilationErrors
Object
org.apache.spark.sql.errors.QueryCompilationErrors
Object for grouping error messages from exceptions thrown during query compilation.
As commands are executed eagerly, this also includes errors thrown during the execution of
commands, which users can see immediately.
-
Constructor Summary
-
Method Summary
Modifier and TypeMethodDescriptionstatic Throwable
actionNotAllowedOnTableSincePartitionMetadataNotStoredError
(String action, String tableName) static Throwable
actionNotAllowedOnTableWithFilesourcePartitionManagementDisabledError
(String action, String tableName) static Throwable
static Throwable
addNewDefaultColumnToExistingTableNotAllowed
(String statementType, String dataSource) static Throwable
static Throwable
aggregateInAggregateFilterError
(org.apache.spark.sql.catalyst.expressions.Expression filterExpr, org.apache.spark.sql.catalyst.expressions.Expression aggExpr) static Throwable
static Throwable
aggregationFunctionAppliedOnNonNumericColumnError
(String pivotColumn, int maxValues) static Throwable
aggregationNotAllowedInMergeCondition
(String condName, org.apache.spark.sql.catalyst.expressions.Expression cond) static Throwable
aliasesNumberNotMatchUDTFOutputError
(int aliasesSize, String aliasesNames) static Throwable
aliasNumberNotMatchColumnNumberError
(int columnSize, int outputSize, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static Throwable
alterAddColNotSupportDatasourceTableError
(Object tableType, org.apache.spark.sql.catalyst.TableIdentifier table) static Throwable
alterAddColNotSupportViewError
(org.apache.spark.sql.catalyst.TableIdentifier table) static Throwable
alterColumnCannotFindColumnInV1TableError
(String colName, org.apache.spark.sql.connector.catalog.V1Table v1Table) static Throwable
static Throwable
static Throwable
alterTableChangeColumnNotSupportedForColumnTypeError
(String tableName, StructField originColumn, StructField newColumn, org.apache.spark.sql.catalyst.trees.Origin origin) static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
ambiguousAttributesInSelfJoinError
(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.AttributeReference> ambiguousAttrs) static Throwable
ambiguousColumnOrFieldError
(scala.collection.immutable.Seq<String> name, int numMatches, org.apache.spark.sql.catalyst.trees.Origin context) static Throwable
ambiguousColumnReferences
(org.apache.spark.sql.catalyst.expressions.Expression e) static Throwable
ambiguousLateralColumnAliasError
(String name, int numOfMatches) static Throwable
ambiguousLateralColumnAliasError
(scala.collection.immutable.Seq<String> nameParts, int numOfMatches) static Throwable
ambiguousReferenceError
(String name, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> ambiguousReferences) static Throwable
ambiguousReferenceToFieldsError
(String field, int numberOfAppearance) static Throwable
static Throwable
static Throwable
static Throwable
analyzingColumnStatisticsNotSupportedForColumnTypeError
(String name, DataType dataType) static Throwable
static Throwable
avroIncompatibleReadError
(String avroPath, String sqlPath, String avroType, String sqlType) static Throwable
batchWriteCapabilityError
(Table table, String v2WriteClassName, String v1WriteClassName) static Throwable
binaryFormatError
(String funcName, String invalidFormat) static Throwable
static Throwable
bucketByUnsupportedByOperationError
(String operation) static Throwable
bucketingColumnCannotBePartOfPartitionColumnsError
(String bucketCol, scala.collection.immutable.Seq<String> normalizedPartCols) static Throwable
bucketSortingColumnCannotBePartOfPartitionColumnsError
(String sortCol, scala.collection.immutable.Seq<String> normalizedPartCols) static Throwable
cannotAlterPartitionColumn
(String tableName, String columnName) static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
cannotConvertCatalystTypeToProtobufTypeError
(scala.collection.immutable.Seq<String> sqlColumn, String protobufColumn, DataType sqlType, String protobufType) static Throwable
static Throwable
cannotConvertProtobufTypeToCatalystTypeError
(String protobufType, DataType sqlType, Throwable cause) static Throwable
cannotConvertProtobufTypeToSqlTypeError
(String protobufColumn, scala.collection.immutable.Seq<String> sqlColumn, String protobufType, DataType sqlType) static Throwable
cannotConvertSqlTypeToProtobufError
(String protobufType, DataType sqlType, Throwable cause) static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
cannotCreateTableWithBothProviderAndSerdeError
(scala.Option<String> provider, scala.Option<org.apache.spark.sql.catalyst.plans.logical.SerdeInfo> maybeSerdeInfo) static Throwable
static Throwable
cannotCreateViewNotEnoughColumnsError
(org.apache.spark.sql.catalyst.TableIdentifier viewIdent, scala.collection.immutable.Seq<String> expected, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan query) static Throwable
cannotCreateViewTooManyColumnsError
(org.apache.spark.sql.catalyst.TableIdentifier viewIdent, scala.collection.immutable.Seq<String> expected, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan query) static Throwable
cannotDeleteTableWhereFiltersError
(Table table, Predicate[] filters) static Throwable
cannotDropBuiltinFuncError
(String functionName) static Throwable
cannotDropDefaultDatabaseError
(String database) static Throwable
static Throwable
cannotDropNonemptyNamespaceError
(scala.collection.immutable.Seq<String> namespace) static Throwable
static Throwable
cannotFindCatalystTypeInProtobufSchemaError
(String catalystFieldPath) static Throwable
cannotFindColumnError
(String name, String[] fieldNames) static Throwable
cannotFindColumnInRelationOutputError
(String colName, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan relation) static AnalysisException
cannotFindDescriptorFileError
(String filePath, Throwable cause) static Throwable
cannotFindPartitionColumnInPartitionSchemaError
(StructField readField, StructType partitionSchema) static Throwable
static Throwable
cannotLoadClassNotOnClassPathError
(String className) static Throwable
cannotLoadClassWhenRegisteringFunctionError
(String className, org.apache.spark.sql.catalyst.FunctionIdentifier func) static Throwable
cannotModifyValueOfSparkConfigError
(String key, String docroot) static Throwable
static Throwable
cannotOperateOnHiveDataSourceFilesError
(String operation) static Throwable
static Throwable
cannotOverwriteTableThatIsBeingReadFromError
(org.apache.spark.sql.catalyst.TableIdentifier tableIdent) static Throwable
cannotParseIntervalError
(String delayThreshold, Throwable e) static Throwable
static Throwable
cannotRefreshBuiltInFuncError
(String functionName) static Throwable
cannotRefreshTempFuncError
(String functionName) static Throwable
static Throwable
static Throwable
cannotRenameTempViewToExistingTableError
(org.apache.spark.sql.catalyst.TableIdentifier newName) static Throwable
cannotRenameTempViewWithDatabaseSpecifiedError
(org.apache.spark.sql.catalyst.TableIdentifier oldName, org.apache.spark.sql.catalyst.TableIdentifier newName) static Throwable
cannotReplaceMissingTableError
(Identifier tableIdentifier) static Throwable
cannotReplaceMissingTableError
(Identifier tableIdentifier, scala.Option<Throwable> cause) static Throwable
cannotResolveAttributeError
(String name, String outputStr) static Throwable
cannotResolveColumnGivenInputColumnsError
(String col, String inputColumns) static Throwable
cannotResolveColumnNameAmongAttributesError
(String colName, String fieldNames) static Throwable
cannotResolveDataFrameColumn
(org.apache.spark.sql.catalyst.expressions.Expression e) static Throwable
cannotResolveStarExpandGivenInputColumnsError
(String targetString, String columns) static Throwable
cannotRetrieveTableOrViewNotInSameDatabaseError
(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.QualifiedTableName> qualifiedTableNames) static Throwable
static Throwable
static Throwable
static Throwable
cannotSpecifyDatabaseForTempViewError
(org.apache.spark.sql.catalyst.TableIdentifier tableIdent) static Throwable
cannotSpecifyWindowFrameError
(String prettyName) static Throwable
cannotTranslateExpressionToSourceFilterError
(org.apache.spark.sql.catalyst.expressions.Expression f) static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
cannotWriteDataToRelationsWithMultiplePathsError
(scala.collection.immutable.Seq<org.apache.hadoop.fs.Path> paths) static Throwable
cannotWriteNotEnoughColumnsToTableError
(String tableName, scala.collection.immutable.Seq<String> expected, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> queryOutput) static Throwable
cannotWriteTooManyColumnsToTableError
(String tableName, scala.collection.immutable.Seq<String> expected, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> queryOutput) static Throwable
catalogOperationNotSupported
(CatalogPlugin catalog, String operation) static Throwable
static Throwable
static Throwable
static Throwable
cmdOnlyWorksOnPartitionedTablesError
(String operation, String tableIdentWithDB) static Throwable
cmdOnlyWorksOnTableWithLocationError
(String cmd, String tableIdentWithDB) static Throwable
static Throwable
columnAlreadyExistsError
(String columnName) static Throwable
columnNotDefinedInTableError
(String colType, String colName, String tableName, scala.collection.immutable.Seq<String> tableCols) static AnalysisException
columnNotFoundError
(String colName) static Throwable
columnNotFoundInExistingColumnsError
(String columnType, String columnName, scala.collection.immutable.Seq<String> validColumnNames) static Throwable
columnNotFoundInSchemaError
(StructField col, scala.Option<StructType> tableSchema) static Throwable
columnNotInGroupByClauseError
(org.apache.spark.sql.catalyst.expressions.Expression expression) static Throwable
columnStatisticsDeserializationNotSupportedError
(String name, DataType dataType) static Throwable
columnStatisticsSerializationNotSupportedError
(String colName, DataType dataType) static Throwable
columnTypeNotSupportStatisticsCollectionError
(String name, org.apache.spark.sql.catalyst.TableIdentifier tableIdent, DataType dataType) static Throwable
static Throwable
commandNotSupportNestedColumnError
(String command, String quoted) static Throwable
configRemovedInVersionError
(String configName, String version, String comment) static Throwable
conflictingAttributesInJoinConditionError
(org.apache.spark.sql.catalyst.expressions.AttributeSet conflictingAttrs, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan outerPlan, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan subplan) static Throwable
corruptedTableNameContextInCatalogError
(int numParts, int index) static Throwable
corruptedViewQueryOutputColumnsInCatalogError
(String numCols, int index) static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
dataPathNotExistError
(String path) static Throwable
dataSchemaNotSpecifiedError
(String format) static Throwable
dataSchemaNotSpecifiedError
(String format, String fileCatalog) static Throwable
static Throwable
dataSourceDoesNotExist
(String name) static Throwable
dataSourceOutputModeUnsupportedError
(String className, OutputMode outputMode) static Throwable
dataSourceTableSchemaMismatchError
(StructType dsSchema, StructType expectedSchema) static Throwable
dataTypeMismatchForDeserializerError
(DataType dataType, String desiredType) static Throwable
static Throwable
dataTypeUnsupportedByClassError
(DataType x, String className) static Throwable
dataTypeUnsupportedByDataSourceError
(String format, StructField column) static Throwable
dataTypeUnsupportedByExtractValueError
(DataType dataType, org.apache.spark.sql.catalyst.expressions.Expression extraction, org.apache.spark.sql.catalyst.expressions.Expression child) static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
defaultReferencesNotAllowedInDataSource
(String statementType, String dataSource) static Throwable
defaultValueNotConstantError
(String statement, String colName, String defaultValue) static Throwable
defaultValuesDataTypeError
(String statement, String colName, String defaultValue, DataType expectedType, DataType actualType) static Throwable
defaultValuesMayNotContainSubQueryExpressions
(String statement, String colName, String defaultValue) static Throwable
defaultValuesUnresolvedExprError
(String statement, String colName, String defaultValue, Throwable cause) static Throwable
static Throwable
static Throwable
static AnalysisException
descriptorParseError
(Throwable cause) static Throwable
static Throwable
doubleNamedArgumentReference
(String functionName, String parameterName) static Throwable
dropNonExistentColumnsNotSupportedError
(scala.collection.immutable.Seq<String> nonExistentColumnNames) static Throwable
static Throwable
emptyWindowExpressionError
(org.apache.spark.sql.catalyst.plans.logical.Window expr) static Throwable
escapeCharacterAtTheEndError
(String pattern) static Throwable
escapeCharacterInTheMiddleError
(String pattern, String char_) static Throwable
expectPermanentViewNotTempViewError
(scala.collection.immutable.Seq<String> nameParts, String cmd, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static Throwable
expectPersistentFuncError
(String name, String cmd, scala.Option<String> mismatchHint, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static Throwable
expectTableNotViewError
(scala.collection.immutable.Seq<String> nameParts, String cmd, boolean suggestAlternative, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static Throwable
expectViewNotTableError
(scala.collection.immutable.Seq<String> nameParts, String cmd, boolean suggestAlternative, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static Throwable
explicitCollationMismatchError
(scala.collection.immutable.Seq<String> explicitTypes) static Throwable
expressionWithMultiWindowExpressionsError
(org.apache.spark.sql.catalyst.expressions.NamedExpression expr, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.WindowSpecDefinition> distinctWindowSpec) static Throwable
expressionWithoutWindowExpressionError
(org.apache.spark.sql.catalyst.expressions.NamedExpression expr) static Throwable
failedToFindAvroDataSourceError
(String provider) static Throwable
failedToFindKafkaDataSourceError
(String provider) static Throwable
failedToParseExistenceDefaultAsLiteral
(String fieldName, String defaultValue) static Throwable
failedToRebuildExpressionError
(Filter filter) static Throwable
failToResolveDataSourceForTableError
(org.apache.spark.sql.catalyst.catalog.CatalogTable table, String key) static Throwable
failToTruncateTableWhenRemovingDataError
(String tableIdentWithDB, org.apache.hadoop.fs.Path path, Throwable e) static Throwable
fieldNumberMismatchForDeserializerError
(StructType schema, int maxOrdinal) static Throwable
findMultipleDataSourceError
(String provider, scala.collection.immutable.Seq<String> sourceNames) static Throwable
foundDifferentWindowFunctionTypeError
(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.NamedExpression> windowExpressions) static Throwable
foundMultipleDataSources
(String provider) static Throwable
foundMultipleXMLDataSourceError
(String provider, scala.collection.immutable.Seq<String> sourceNames, String externalSource) static Throwable
foundRecursionInProtobufSchema
(String fieldDescriptor) static Throwable
funcBuildError
(String funcName, Exception cause) static Throwable
functionAlreadyExistsError
(org.apache.spark.sql.catalyst.FunctionIdentifier func) static Throwable
functionCannotProcessInputError
(UnboundFunction unbound, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> arguments, UnsupportedOperationException unsupported) static Throwable
functionWithUnsupportedSyntaxError
(String prettyName, String syntax) static Throwable
generatorNotExpectedError
(org.apache.spark.sql.catalyst.FunctionIdentifier name, String classCanonicalName) static Throwable
generatorOutsideSelectError
(org.apache.spark.sql.catalyst.plans.logical.LogicalPlan plan) static QueryContext[]
getQueryContext
(QueryContext context) static String
getSummary
(QueryContext sqlContext) static Throwable
groupByPositionRangeError
(int index, int size) static Throwable
groupByPositionRefersToAggregateFunctionError
(int index, org.apache.spark.sql.catalyst.expressions.Expression expr) static Throwable
groupingColInvalidError
(org.apache.spark.sql.catalyst.expressions.Expression groupingCol, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> groupByExprs) static Throwable
groupingIDMismatchError
(org.apache.spark.sql.catalyst.expressions.GroupingID groupingID, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> groupByExprs) static Throwable
static Throwable
groupingSizeTooLargeError
(int sizeLimit) static Throwable
hiveTableTypeUnsupportedError
(String tableName, String tableType) static Throwable
static Throwable
identifierTooManyNamePartsError
(String originalIdentifier) static Throwable
illegalParquetTypeError
(String parquetType) static Throwable
static Throwable
incompatibleDataToTableAmbiguousColumnNameError
(String tableName, String colName) static Throwable
incompatibleDataToTableCannotFindDataError
(String tableName, String colName) static Throwable
incompatibleDataToTableCannotSafelyCastError
(String tableName, String colName, String srcType, String targetType) static Throwable
incompatibleDataToTableExtraColumnsError
(String tableName, String extraColumns) static Throwable
incompatibleDataToTableExtraStructFieldsError
(String tableName, String colName, String extraFields) static Throwable
incompatibleDataToTableNullableArrayElementsError
(String tableName, String colName) static Throwable
incompatibleDataToTableNullableColumnError
(String tableName, String colName) static Throwable
incompatibleDataToTableNullableMapValuesError
(String tableName, String colName) static Throwable
incompatibleDataToTableStructMissingFieldsError
(String tableName, String colName, String missingFields) static Throwable
incompatibleDataToTableUnexpectedColumnNameError
(String tableName, String colName, int order, String expected, String found) static Throwable
incompatibleViewSchemaChangeError
(String viewName, String colName, int expectedNum, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> actualCols, scala.Option<String> viewDDL) static Throwable
static Throwable
inputSourceDiffersFromDataSourceProviderError
(String source, String tableName, org.apache.spark.sql.catalyst.catalog.CatalogTable table) static Throwable
insertIntoViewNotAllowedError
(org.apache.spark.sql.catalyst.TableIdentifier identifier, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static Throwable
insertMismatchedColumnNumberError
(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> targetAttributes, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> sourceAttributes, int staticPartitionsSize) static Throwable
insertMismatchedPartitionNumberError
(StructType targetPartitionSchema, int providedPartitionsSize) static Throwable
static Throwable
insufficientTablePropertyPartError
(String key, String totalAmountOfParts) static Throwable
invalidBoundaryEndError
(long end) static Throwable
invalidBoundaryStartError
(long start) static Throwable
invalidBucketColumnDataTypeError
(DataType dataType) static Throwable
invalidBucketNumberError
(int bucketingMaxBuckets, int numBuckets) static Throwable
invalidBucketsNumberError
(String numBuckets, String e) static Throwable
invalidByteStringFormatError
(Object unsupported) static Throwable
invalidCoalesceHintParameterError
(String hintName) static Throwable
invalidColumnNameAsPathError
(String datasource, String columnName) static Throwable
invalidColumnOrFieldDataTypeError
(scala.collection.immutable.Seq<String> name, DataType dt, DataType expected) static Throwable
invalidDataSourceError
(String className) static Throwable
invalidEscapeChar
(org.apache.spark.sql.catalyst.expressions.Expression sqlExpr) static Throwable
invalidExecuteImmediateVariableType
(DataType dataType) static Throwable
invalidFieldName
(scala.collection.immutable.Seq<String> fieldName, scala.collection.immutable.Seq<String> path, org.apache.spark.sql.catalyst.trees.Origin context) static Throwable
static Throwable
invalidFileFormatForStoredAsError
(org.apache.spark.sql.catalyst.plans.logical.SerdeInfo serdeInfo) static Throwable
invalidHintParameterError
(String hintName, scala.collection.immutable.Seq<Object> invalidParams) static Throwable
static Throwable
invalidJoinTypeInJoinWithError
(org.apache.spark.sql.catalyst.plans.JoinType joinType) static Throwable
invalidJsonSchema
(DataType schema) static Throwable
static Throwable
static Throwable
invalidOrderingForConstantValuePartitionColumnError
(StructType targetPartitionSchema) static Throwable
invalidPandasUDFPlacementError
(scala.collection.immutable.Seq<String> groupAggPandasUDFNames) static Throwable
static Throwable
invalidPartitionColumnError
(String partKey, StructType targetPartitionSchema) static Throwable
invalidPartitionColumnKeyInTableError
(String key, String tblName) static Throwable
static Throwable
invalidPartitionSpecError
(String details) static Throwable
invalidPartitionSpecError
(String specKeys, scala.collection.immutable.Seq<String> partitionColumnNames, String tableName) static Throwable
invalidPartitionTransformationError
(org.apache.spark.sql.catalyst.expressions.Expression expr) static Throwable
invalidQueryAllParametersMustBeNamed
(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> expr) static Throwable
static Throwable
invalidRepartitionExpressionsError
(scala.collection.immutable.Seq<Object> sortOrders) static Throwable
invalidRowLevelOperationAssignments
(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.plans.logical.Assignment> assignments, scala.collection.immutable.Seq<String> errors) static Throwable
invalidSaveModeError
(String saveMode) static Throwable
static Throwable
static Throwable
invalidStarUsageError
(String prettyName, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.analysis.Star> stars) static Throwable
invalidStatementForExecuteInto
(String queryString) static Throwable
invalidTimestampExprForTimeTravel
(String errorClass, org.apache.spark.sql.catalyst.expressions.Expression expr) static Throwable
invalidTimestampProvidedForStrategyError
(String strategy, String timeString) static Throwable
static Throwable
invalidUDFClassError
(String invalidClass) static Throwable
static Throwable
invalidViewNameError
(String viewName) static Throwable
invalidViewText
(String viewText, String viewName) static Throwable
invalidXmlSchema
(DataType schema) static Throwable
static Throwable
joinConditionMissingOrTrivialError
(org.apache.spark.sql.catalyst.plans.logical.Join join, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan left, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan right) static Throwable
joinStrategyHintParameterNotSupportedError
(Object unsupported) static Throwable
keyValueInMapNotStringError
(org.apache.spark.sql.catalyst.expressions.CreateMap m) static Throwable
lateralColumnAliasInAggFuncUnsupportedError
(scala.collection.immutable.Seq<String> lcaNameParts, org.apache.spark.sql.catalyst.expressions.Expression aggExpr) static Throwable
lateralColumnAliasInAggWithWindowAndHavingUnsupportedError
(scala.collection.immutable.Seq<String> lcaNameParts) static Throwable
lateralColumnAliasInWindowUnsupportedError
(scala.collection.immutable.Seq<String> lcaNameParts, org.apache.spark.sql.catalyst.expressions.Expression windowExpr) static Throwable
static Throwable
literalTypeUnsupportedForSourceTypeError
(String field, org.apache.spark.sql.catalyst.expressions.Expression source) static Throwable
static Throwable
loadDataNotSupportedForDatasourceTablesError
(String tableIdentWithDB) static Throwable
static Throwable
loadDataPartitionSizeNotMatchNumPartitionColumnsError
(String tableIdentWithDB, int partitionSize, int targetTableSize) static Throwable
loadDataTargetTableNotPartitionedButPartitionSpecWasProvidedError
(String tableIdentWithDB) static Throwable
loadDataWithoutPartitionSpecProvidedError
(String tableIdentWithDB) static Throwable
static Throwable
mismatchedTableBucketingError
(String tableName, String specifiedBucketString, String existingBucketString) static Throwable
mismatchedTableColumnNumberError
(String tableName, org.apache.spark.sql.catalyst.catalog.CatalogTable existingTable, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan query) static Throwable
mismatchedTableFormatError
(String tableName, Class<?> existingProvider, Class<?> specifiedProvider) static Throwable
mismatchedTableLocationError
(org.apache.spark.sql.catalyst.TableIdentifier identifier, org.apache.spark.sql.catalyst.catalog.CatalogTable existingTable, org.apache.spark.sql.catalyst.catalog.CatalogTable tableDesc) static Throwable
mismatchedTablePartitionColumnError
(String tableName, scala.collection.immutable.Seq<String> specifiedPartCols, String existingPartCols) static Throwable
missingCatalogAbilityError
(CatalogPlugin plugin, String ability) static Throwable
missingFieldError
(scala.collection.immutable.Seq<String> fieldName, org.apache.spark.sql.catalyst.analysis.ResolvedTable table, org.apache.spark.sql.catalyst.trees.Origin context) static Throwable
missingStaticPartitionColumn
(String staticName) static Throwable
mixedRefsInAggFunc
(String funcStr, org.apache.spark.sql.catalyst.trees.Origin origin) static Throwable
moreThanOneGeneratorError
(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> generators) static Throwable
multiplePartitionColumnValuesSpecifiedError
(StructField field, scala.collection.immutable.Map<String, String> potentialSpecs) static Throwable
multiTimeWindowExpressionsNotSupportedError
(org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static Throwable
namedArgumentsNotEnabledError
(String functionName, String argumentName) static Throwable
namedArgumentsNotSupported
(String functionName) static Throwable
namespaceAlreadyExistsError
(String[] namespace) static Throwable
static Throwable
nestedExecuteImmediate
(String queryString) static Throwable
nestedGeneratorError
(org.apache.spark.sql.catalyst.expressions.Expression trimmedNestedGenerator) static Throwable
noHandlerForUDAFError
(String name) static Throwable
nonBooleanFilterInAggregateError
(org.apache.spark.sql.catalyst.expressions.Expression filterExpr) static Throwable
nonDeterministicFilterInAggregateError
(org.apache.spark.sql.catalyst.expressions.Expression filterExpr) static Throwable
nonDeterministicMergeCondition
(String condName, org.apache.spark.sql.catalyst.expressions.Expression cond) static Throwable
nonFoldableArgumentError
(String funcName, String paramName, DataType paramType) static Throwable
nonLiteralPivotValError
(org.apache.spark.sql.catalyst.expressions.Expression pivotVal) static Throwable
static Throwable
nonPartitionColError
(String partitionName) static Throwable
nonPartitionPruningPredicatesNotExpectedError
(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> nonPartitionPruningPredicates) static Throwable
noSuchFunctionError
(org.apache.spark.sql.catalyst.FunctionIdentifier identifier) static Throwable
noSuchNamespaceError
(String[] namespace) static Throwable
noSuchPartitionError
(String db, String table, scala.collection.immutable.Map<String, String> partition) static Throwable
noSuchStructFieldInGivenFieldsError
(String fieldName, StructField[] fields) static Throwable
noSuchTableError
(String db, String table) static org.apache.spark.sql.catalyst.analysis.NoSuchTableException
noSuchTableError
(Identifier ident) static Throwable
noSuchTableError
(scala.collection.immutable.Seq<String> nameParts) static Throwable
notAllowedToCreatePermanentViewByReferencingTempFuncError
(org.apache.spark.sql.catalyst.TableIdentifier name, String funcName) static Throwable
notAllowedToCreatePermanentViewByReferencingTempVarError
(org.apache.spark.sql.catalyst.TableIdentifier name, String varName) static Throwable
notAllowedToCreatePermanentViewByReferencingTempViewError
(org.apache.spark.sql.catalyst.TableIdentifier name, String nameParts) static Throwable
notAllowedToCreatePermanentViewWithoutAssigningAliasForExpressionError
(org.apache.spark.sql.catalyst.TableIdentifier name, org.apache.spark.sql.catalyst.expressions.Attribute attr) static Throwable
notExistPartitionError
(Identifier table, org.apache.spark.sql.catalyst.InternalRow partitionIdent, StructType partitionSchema) static Throwable
notNullConstraintViolationArrayElementError
(scala.collection.immutable.Seq<String> path) static Throwable
notNullConstraintViolationMapValueError
(scala.collection.immutable.Seq<String> path) static Throwable
nullableColumnOrFieldError
(scala.collection.immutable.Seq<String> name) static Throwable
nullableRowIdError
(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.AttributeReference> nullableRowIdAttrs) static Throwable
nullArgumentError
(String funcName, String parameter) static Throwable
nullSQLStringExecuteImmediate
(String varName) static Throwable
static Throwable
static Throwable
operationNotSupportPartitioningError
(String operation) static Throwable
optionMustBeConstant
(String key, scala.Option<Throwable> cause) static Throwable
static Throwable
static Throwable
orderByPositionRangeError
(int index, int size, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static String
ordinalNumber
(int i) static Throwable
outerScopeFailureForNewInstanceError
(String className) static Throwable
outputPathAlreadyExistsError
(org.apache.hadoop.fs.Path outputPath) static Throwable
static Throwable
parquetTypeUnsupportedYetError
(String parquetType) static Throwable
parseModeUnsupportedError
(String funcName, org.apache.spark.sql.catalyst.util.ParseMode mode) static Throwable
static Throwable
partitionColumnNotFoundInSchemaError
(String col, String schemaCatalog) static Throwable
partitionColumnNotSpecifiedError
(String format, String partitionColumn) static Throwable
partitionNotSpecifyLocationUriError
(String specString) static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
pivotValDataTypeMismatchError
(org.apache.spark.sql.catalyst.expressions.Expression pivotVal, org.apache.spark.sql.catalyst.expressions.Expression pivotCol) static Throwable
static Throwable
positionalAndNamedArgumentDoubleReference
(String functionName, String parameterName) static Throwable
protobufClassLoadError
(String protobufClassName, String explanation, Throwable cause) static Throwable
protobufDescriptorDependencyError
(String dependencyName) static Throwable
protobufFieldMatchError
(String field, String protobufSchema, String matchSize, String matches) static Throwable
static Throwable
protobufTypeUnsupportedYetError
(String protobufType) static Throwable
pythonDataSourceError
(String action, String tpe, String msg) static Throwable
static Throwable
static Throwable
readNonStreamingTempViewError
(String quoted) static Throwable
recoverQueryFromCheckpointUnsupportedError
(org.apache.hadoop.fs.Path checkpointPath) static Throwable
recursiveViewDetectedError
(org.apache.spark.sql.catalyst.TableIdentifier viewIdent, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.TableIdentifier> newPath) static Throwable
referenceColNotFoundForAlterTableChangesError
(String fieldName, String[] fields) static Throwable
static Throwable
renameTempViewToExistingViewError
(String newName) static Throwable
static Throwable
requestedPartitionsMismatchTablePartitionsError
(String tableName, scala.collection.immutable.Map<String, scala.Option<String>> normalizedPartSpec, StructType partColNames) static Throwable
requiredParameterNotFound
(String functionName, String parameterName, int index) static Throwable
requiresSinglePartNamespaceError
(scala.collection.immutable.Seq<String> namespace) static Throwable
resourceTypeNotSupportedError
(String resourceType) static Throwable
static Throwable
schemaIsNotStructTypeError
(String inputSchema, DataType dataType) static Throwable
schemaIsNotStructTypeError
(org.apache.spark.sql.catalyst.expressions.Expression exp, DataType dataType) static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
selectExprNotInGroupByError
(org.apache.spark.sql.catalyst.expressions.Expression expr, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Alias> groupByAliases) static Throwable
static Throwable
static Throwable
static Throwable
showColumnsWithConflictDatabasesError
(scala.collection.immutable.Seq<String> db, org.apache.spark.sql.catalyst.TableIdentifier v1TableName) static Throwable
showCreateTableAsSerdeNotAllowedOnSparkDataSourceTableError
(org.apache.spark.sql.catalyst.TableIdentifier table) static Throwable
static Throwable
showCreateTableFailToExecuteUnsupportedConfError
(org.apache.spark.sql.catalyst.TableIdentifier table, scala.collection.mutable.StringBuilder builder) static Throwable
showCreateTableFailToExecuteUnsupportedFeatureError
(org.apache.spark.sql.catalyst.catalog.CatalogTable table) static Throwable
static Throwable
showCreateTableNotSupportTransactionalHiveTableError
(org.apache.spark.sql.catalyst.catalog.CatalogTable table) static Throwable
showCreateTableOrViewFailToExecuteUnsupportedFeatureError
(org.apache.spark.sql.catalyst.catalog.CatalogTable table, scala.collection.immutable.Seq<String> features) static Throwable
showPartitionNotAllowedOnTableNotPartitionedError
(String tableIdentWithDB) static Throwable
singleTableStarInCountNotAllowedError
(String targetString) static Throwable
static Throwable
static Throwable
static Throwable
starExpandDataTypeNotSupportedError
(scala.collection.immutable.Seq<String> attributes) static Throwable
static Throwable
staticPartitionInUserSpecifiedColumnsError
(String staticName) static Throwable
streamingIntoViewNotSupportedError
(String viewName) static Throwable
streamingSourcesDoNotSupportCommonExecutionModeError
(scala.collection.immutable.Seq<String> microBatchSources, scala.collection.immutable.Seq<String> continuousSources) static Throwable
streamJoinStreamWithoutEqualityPredicateUnsupportedError
(org.apache.spark.sql.catalyst.plans.logical.LogicalPlan plan) static Throwable
static Throwable
subqueryNotAllowedInMergeCondition
(String condName, org.apache.spark.sql.catalyst.expressions.Expression cond) static Throwable
subqueryReturnMoreThanOneColumn
(int number, org.apache.spark.sql.catalyst.trees.Origin origin) static Throwable
tableAlreadyExistsError
(String table) static Throwable
tableAlreadyExistsError
(org.apache.spark.sql.catalyst.TableIdentifier tableIdent) static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
static Throwable
tableIdentifierExistsError
(org.apache.spark.sql.catalyst.TableIdentifier tableIdentifier) static Throwable
tableIdentifierNotConvertedToHadoopFsRelationError
(org.apache.spark.sql.catalyst.TableIdentifier tableIdentifier) static Throwable
tableIndexNotSupportedError
(String errorMessage) static Throwable
static Throwable
tableNotSpecifyDatabaseError
(org.apache.spark.sql.catalyst.TableIdentifier identifier) static Throwable
tableNotSpecifyLocationUriError
(org.apache.spark.sql.catalyst.TableIdentifier identifier) static Throwable
tableNotSupportStreamingWriteError
(String tableName, Table t) static Throwable
static Throwable
tableOrViewNotFound
(scala.collection.immutable.Seq<String> ident) static Throwable
static Throwable
tableValuedFunctionRequiredMetadataIncompatibleWithCall
(String functionName, String requestedMetadata, String invalidFunctionCallProperty) static Throwable
tableValuedFunctionRequiredMetadataInvalid
(String functionName, String reason) static Throwable
static Throwable
tempViewNotCachedForAnalyzingColumnsError
(org.apache.spark.sql.catalyst.TableIdentifier tableIdent) static Throwable
tempViewNotSupportStreamingWriteError
(String viewName) static Throwable
static Throwable
timeTravelUnsupportedError
(String relationId) static String
toDSOption
(String option) static String
static String
toSQLConfVal
(String conf) static String
toSQLExpr
(org.apache.spark.sql.catalyst.expressions.Expression e) 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
(Object v, DataType t) static String
toSQLValue
(String value) static String
toSQLValue
(org.apache.spark.unsafe.types.UTF8String value) static Throwable
truncateTableOnExternalTablesError
(String tableIdentWithDB) static Throwable
truncateTablePartitionNotSupportedForNotPartitionedTablesError
(String tableIdentWithDB) static Throwable
static Throwable
udfClassImplementMultiUDFInterfacesError
(String className) static Throwable
static Throwable
unableToLocateProtobufMessageError
(String messageName) static Throwable
unexpectedInputDataTypeError
(String functionName, int paramIndex, DataType dataType, org.apache.spark.sql.catalyst.expressions.Expression expression) static Throwable
unexpectedNullError
(String exprName, org.apache.spark.sql.catalyst.expressions.Expression expression) static Throwable
unexpectedPartitionColumnPrefixError
(String table, String database, String schemaColumns, String specColumns) static Throwable
unexpectedPositionalArgument
(String functionName, String precedingNamedArgument) static Throwable
unexpectedRequiredParameterInFunctionSignature
(String functionName, org.apache.spark.sql.catalyst.plans.logical.FunctionSignature functionSignature) static Throwable
unexpectedSchemaTypeError
(org.apache.spark.sql.catalyst.expressions.Expression exp) static Throwable
unknownHiveResourceTypeError
(String resourceType) static Throwable
unknownProtobufMessageTypeError
(String descriptorName, String containingType) static Throwable
unorderablePivotColError
(org.apache.spark.sql.catalyst.expressions.Expression pivotCol) static Throwable
unpivotRequiresAttributes
(String given, String empty, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.NamedExpression> expressions) static Throwable
static Throwable
unpivotValueDataTypeMismatchError
(scala.collection.immutable.Seq<scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.NamedExpression>> values) static Throwable
unpivotValueSizeMismatchError
(int names) static Throwable
unrecognizedParameterName
(String functionName, String argumentName, scala.collection.immutable.Seq<String> candidates) static Throwable
static Throwable
unresolvedAttributeError
(String errorClass, String colName, scala.collection.immutable.Seq<String> candidates, org.apache.spark.sql.catalyst.trees.Origin origin) static AnalysisException
unresolvedColumnError
(String colName, String[] fields) static Throwable
unresolvedColumnError
(String columnName, scala.collection.immutable.Seq<String> proposal) static Throwable
unresolvedFieldError
(String fieldName, scala.collection.immutable.Seq<String> columnPath, scala.collection.immutable.Seq<String> proposal) static Throwable
unresolvedRoutineError
(org.apache.spark.sql.catalyst.FunctionIdentifier name, scala.collection.immutable.Seq<String> searchPath) static Throwable
unresolvedRoutineError
(scala.collection.immutable.Seq<String> nameParts, scala.collection.immutable.Seq<String> searchPath, org.apache.spark.sql.catalyst.trees.Origin context) static Throwable
unresolvedUsingColForJoinError
(String colName, String suggestion, String side) static Throwable
unresolvedVariableError
(scala.collection.immutable.Seq<String> name, scala.collection.immutable.Seq<String> searchPath) static Throwable
unresolvedVariableError
(scala.collection.immutable.Seq<String> name, scala.collection.immutable.Seq<String> searchPath, org.apache.spark.sql.catalyst.trees.Origin origin) static Throwable
unsetNonExistentPropertiesError
(scala.collection.immutable.Seq<String> properties, org.apache.spark.sql.catalyst.TableIdentifier table) static Throwable
static Throwable
unsupportedBatchReadError
(Table table) static Throwable
unsupportedCorrelatedReferenceDataTypeError
(org.apache.spark.sql.catalyst.expressions.Expression expr, DataType dataType, org.apache.spark.sql.catalyst.trees.Origin origin) static Throwable
unsupportedCorrelatedSubqueryInJoinConditionError
(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> unsupportedSubqueryExpressions) static Throwable
unsupportedCreateOrReplaceViewOnTableError
(org.apache.spark.sql.catalyst.TableIdentifier name, boolean replace) static Throwable
unsupportedDeleteByConditionWithSubqueryError
(org.apache.spark.sql.catalyst.expressions.Expression condition) static Throwable
static Throwable
unsupportedIfNotExistsError
(String tableName) static Throwable
unsupportedJDBCNamespaceChangeInCatalogError
(scala.collection.immutable.Seq<NamespaceChange> changes) static Throwable
static Throwable
unsupportedParameterExpression
(org.apache.spark.sql.catalyst.expressions.Expression expr) static Throwable
static Throwable
static Throwable
unsupportedTableOperationError
(org.apache.spark.sql.catalyst.TableIdentifier ident, String operation) static Throwable
unsupportedTableOperationError
(CatalogPlugin catalog, Identifier ident, String operation) static Throwable
static Throwable
upCastFailureError
(String fromStr, org.apache.spark.sql.catalyst.expressions.Expression from, DataType to, scala.collection.immutable.Seq<String> walkedTypePath) static Throwable
usePythonUDFInJoinConditionUnsupportedError
(org.apache.spark.sql.catalyst.plans.JoinType joinType) static Throwable
userDefinedPartitionNotFoundInJDBCRelationError
(String columnName, String schema) static Throwable
userSpecifiedSchemaMismatchActualSchemaError
(StructType schema, StructType actualSchema) static Throwable
userSpecifiedSchemaUnsupportedError
(String operation) static Throwable
static Throwable
v2FunctionInvalidInputTypeLengthError
(BoundFunction bound, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> args) static Throwable
viewAlreadyExistsError
(org.apache.spark.sql.catalyst.TableIdentifier name) static Throwable
viewDepthExceedsMaxResolutionDepthError
(org.apache.spark.sql.catalyst.TableIdentifier identifier, int maxNestedDepth, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static Throwable
static Throwable
windowFrameNotMatchRequiredFrameError
(org.apache.spark.sql.catalyst.expressions.SpecifiedWindowFrame f, org.apache.spark.sql.catalyst.expressions.WindowFrame required) static Throwable
windowFunctionInAggregateFilterError
(org.apache.spark.sql.catalyst.expressions.Expression filterExpr, org.apache.spark.sql.catalyst.expressions.Expression windowExpr) static Throwable
static Throwable
windowFunctionNotAllowedError
(String clauseName) static Throwable
windowFunctionWithWindowFrameNotOrderedError
(org.apache.spark.sql.catalyst.expressions.WindowFunction wf) static Throwable
windowSpecificationNotDefinedError
(String windowName) static Throwable
static Throwable
static Throwable
static Throwable
writeIntoV1TableNotAllowedError
(org.apache.spark.sql.catalyst.TableIdentifier identifier, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static Throwable
writeIntoViewNotAllowedError
(org.apache.spark.sql.catalyst.TableIdentifier identifier, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) static Throwable
writeWithSaveModeUnsupportedBySourceError
(String source, String createMode) static Throwable
wrongCommandForObjectTypeError
(String operation, String requiredType, String objectName, String foundType, String alternative) static Throwable
wrongNumArgsError
(String name, scala.collection.immutable.Seq<Object> validParametersCount, int actualNumber, String legacyNum, String legacyConfKey, String legacyConfValue) static Throwable
wrongNumOrderingsForInverseDistributionFunctionError
(String funcName, int validOrderingsNumber, int actualOrderingsNumber) static Throwable
xmlRowTagRequiredError
(String optionName) static Throwable
-
Constructor Details
-
QueryCompilationErrors
public QueryCompilationErrors()
-
-
Method Details
-
unexpectedRequiredParameterInFunctionSignature
-
namedArgumentsNotSupported
-
positionalAndNamedArgumentDoubleReference
-
doubleNamedArgumentReference
-
requiredParameterNotFound
-
unrecognizedParameterName
-
unexpectedPositionalArgument
-
groupingIDMismatchError
public static Throwable groupingIDMismatchError(org.apache.spark.sql.catalyst.expressions.GroupingID groupingID, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> groupByExprs) -
groupingColInvalidError
public static Throwable groupingColInvalidError(org.apache.spark.sql.catalyst.expressions.Expression groupingCol, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> groupByExprs) -
groupingSizeTooLargeError
-
zeroArgumentIndexError
-
binaryFormatError
-
nullArgumentError
-
unorderablePivotColError
public static Throwable unorderablePivotColError(org.apache.spark.sql.catalyst.expressions.Expression pivotCol) -
nonLiteralPivotValError
public static Throwable nonLiteralPivotValError(org.apache.spark.sql.catalyst.expressions.Expression pivotVal) -
pivotValDataTypeMismatchError
public static Throwable pivotValDataTypeMismatchError(org.apache.spark.sql.catalyst.expressions.Expression pivotVal, org.apache.spark.sql.catalyst.expressions.Expression pivotCol) -
unpivotRequiresAttributes
-
unpivotRequiresValueColumns
-
unpivotValueSizeMismatchError
-
unpivotValueDataTypeMismatchError
public static Throwable unpivotValueDataTypeMismatchError(scala.collection.immutable.Seq<scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.NamedExpression>> values) -
unsupportedIfNotExistsError
-
nonPartitionColError
-
missingStaticPartitionColumn
-
staticPartitionInUserSpecifiedColumnsError
-
nestedGeneratorError
public static Throwable nestedGeneratorError(org.apache.spark.sql.catalyst.expressions.Expression trimmedNestedGenerator) -
moreThanOneGeneratorError
public static Throwable moreThanOneGeneratorError(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> generators) -
generatorOutsideSelectError
public static Throwable generatorOutsideSelectError(org.apache.spark.sql.catalyst.plans.logical.LogicalPlan plan) -
legacyStoreAssignmentPolicyError
-
namedArgumentsNotEnabledError
-
collationNotEnabledError
-
unresolvedUsingColForJoinError
-
unresolvedAttributeError
-
unresolvedColumnError
-
unresolvedFieldError
-
dataTypeMismatchForDeserializerError
-
fieldNumberMismatchForDeserializerError
-
upCastFailureError
-
outerScopeFailureForNewInstanceError
-
referenceColNotFoundForAlterTableChangesError
-
windowSpecificationNotDefinedError
-
selectExprNotInGroupByError
public static Throwable selectExprNotInGroupByError(org.apache.spark.sql.catalyst.expressions.Expression expr, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Alias> groupByAliases) -
groupingMustWithGroupingSetsOrCubeOrRollupError
-
pandasUDFAggregateNotSupportedInPivotError
-
aggregateExpressionRequiredForPivotError
-
writeIntoTempViewNotAllowedError
-
readNonStreamingTempViewError
-
viewDepthExceedsMaxResolutionDepthError
public static Throwable viewDepthExceedsMaxResolutionDepthError(org.apache.spark.sql.catalyst.TableIdentifier identifier, int maxNestedDepth, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) -
insertIntoViewNotAllowedError
public static Throwable insertIntoViewNotAllowedError(org.apache.spark.sql.catalyst.TableIdentifier identifier, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) -
writeIntoViewNotAllowedError
public static Throwable writeIntoViewNotAllowedError(org.apache.spark.sql.catalyst.TableIdentifier identifier, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) -
writeIntoV1TableNotAllowedError
public static Throwable writeIntoV1TableNotAllowedError(org.apache.spark.sql.catalyst.TableIdentifier identifier, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) -
expectTableNotViewError
-
expectViewNotTableError
-
expectPermanentViewNotTempViewError
-
expectPersistentFuncError
-
permanentViewNotSupportedByStreamingReadingAPIError
-
starNotAllowedWhenGroupByOrdinalPositionUsedError
-
invalidStarUsageError
-
singleTableStarInCountNotAllowedError
-
orderByPositionRangeError
public static Throwable orderByPositionRangeError(int index, int size, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) -
groupByPositionRefersToAggregateFunctionError
public static Throwable groupByPositionRefersToAggregateFunctionError(int index, org.apache.spark.sql.catalyst.expressions.Expression expr) -
groupByPositionRangeError
-
generatorNotExpectedError
-
functionWithUnsupportedSyntaxError
-
subqueryExpressionInLambdaOrHigherOrderFunctionNotAllowedError
-
nonDeterministicFilterInAggregateError
public static Throwable nonDeterministicFilterInAggregateError(org.apache.spark.sql.catalyst.expressions.Expression filterExpr) -
nonBooleanFilterInAggregateError
public static Throwable nonBooleanFilterInAggregateError(org.apache.spark.sql.catalyst.expressions.Expression filterExpr) -
aggregateInAggregateFilterError
public static Throwable aggregateInAggregateFilterError(org.apache.spark.sql.catalyst.expressions.Expression filterExpr, org.apache.spark.sql.catalyst.expressions.Expression aggExpr) -
windowFunctionInAggregateFilterError
public static Throwable windowFunctionInAggregateFilterError(org.apache.spark.sql.catalyst.expressions.Expression filterExpr, org.apache.spark.sql.catalyst.expressions.Expression windowExpr) -
distinctInverseDistributionFunctionUnsupportedError
-
inverseDistributionFunctionMissingWithinGroupError
-
wrongNumOrderingsForInverseDistributionFunctionError
-
aliasNumberNotMatchColumnNumberError
public static Throwable aliasNumberNotMatchColumnNumberError(int columnSize, int outputSize, org.apache.spark.sql.catalyst.trees.TreeNode<?> t) -
aliasesNumberNotMatchUDTFOutputError
-
invalidSortOrderInUDTFOrderingColumnFromAnalyzeMethodHasAlias
-
invalidUDTFSelectExpressionFromAnalyzeMethodNeedsAlias
-
windowAggregateFunctionWithFilterNotSupportedError
-
windowFunctionInsideAggregateFunctionNotAllowedError
-
expressionWithoutWindowExpressionError
public static Throwable expressionWithoutWindowExpressionError(org.apache.spark.sql.catalyst.expressions.NamedExpression expr) -
expressionWithMultiWindowExpressionsError
public static Throwable expressionWithMultiWindowExpressionsError(org.apache.spark.sql.catalyst.expressions.NamedExpression expr, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.WindowSpecDefinition> distinctWindowSpec) -
windowFunctionNotAllowedError
-
cannotSpecifyWindowFrameError
-
windowFrameNotMatchRequiredFrameError
public static Throwable windowFrameNotMatchRequiredFrameError(org.apache.spark.sql.catalyst.expressions.SpecifiedWindowFrame f, org.apache.spark.sql.catalyst.expressions.WindowFrame required) -
windowFunctionWithWindowFrameNotOrderedError
public static Throwable windowFunctionWithWindowFrameNotOrderedError(org.apache.spark.sql.catalyst.expressions.WindowFunction wf) -
multiTimeWindowExpressionsNotSupportedError
public static Throwable multiTimeWindowExpressionsNotSupportedError(org.apache.spark.sql.catalyst.trees.TreeNode<?> t) -
sessionWindowGapDurationDataTypeError
-
unresolvedVariableError
-
unresolvedVariableError
-
unresolvedRoutineError
-
unresolvedRoutineError
-
wrongNumArgsError
-
alterV2TableSetLocationWithPartitionNotSupportedError
-
joinStrategyHintParameterNotSupportedError
-
invalidHintParameterError
-
invalidCoalesceHintParameterError
-
starExpandDataTypeNotSupportedError
-
cannotResolveStarExpandGivenInputColumnsError
-
addColumnWithV1TableCannotSpecifyNotNullError
-
unsupportedTableOperationError
public static Throwable unsupportedTableOperationError(CatalogPlugin catalog, Identifier ident, String operation) -
unsupportedTableOperationError
-
unsupportedBatchReadError
-
unsupportedStreamingScanError
-
unsupportedAppendInBatchModeError
-
unsupportedDynamicOverwriteInBatchModeError
-
unsupportedTruncateInBatchModeError
-
unsupportedOverwriteByFilterInBatchModeError
-
catalogOperationNotSupported
-
alterColumnWithV1TableCannotSpecifyNotNullError
-
alterColumnCannotFindColumnInV1TableError
-
wrongCommandForObjectTypeError
-
showColumnsWithConflictDatabasesError
-
cannotCreateTableWithBothProviderAndSerdeError
-
invalidFileFormatForStoredAsError
public static Throwable invalidFileFormatForStoredAsError(org.apache.spark.sql.catalyst.plans.logical.SerdeInfo serdeInfo) -
commandNotSupportNestedColumnError
-
renameTempViewToExistingViewError
-
cannotDropNonemptyDatabaseError
-
cannotDropNonemptyNamespaceError
-
invalidNameForTableOrDatabaseError
-
cannotCreateDatabaseWithSameNameAsPreservedDatabaseError
-
cannotDropDefaultDatabaseError
-
cannotUsePreservedDatabaseAsCurrentDatabaseError
-
createExternalTableWithoutLocationError
-
dropNonExistentColumnsNotSupportedError
-
cannotRetrieveTableOrViewNotInSameDatabaseError
public static Throwable cannotRetrieveTableOrViewNotInSameDatabaseError(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.QualifiedTableName> qualifiedTableNames) -
renameTableSourceAndDestinationMismatchError
-
cannotRenameTempViewWithDatabaseSpecifiedError
public static Throwable cannotRenameTempViewWithDatabaseSpecifiedError(org.apache.spark.sql.catalyst.TableIdentifier oldName, org.apache.spark.sql.catalyst.TableIdentifier newName) -
cannotRenameTempViewToExistingTableError
public static Throwable cannotRenameTempViewToExistingTableError(org.apache.spark.sql.catalyst.TableIdentifier newName) -
invalidPartitionSpecError
-
functionAlreadyExistsError
public static Throwable functionAlreadyExistsError(org.apache.spark.sql.catalyst.FunctionIdentifier func) -
cannotLoadClassWhenRegisteringFunctionError
-
resourceTypeNotSupportedError
-
tableNotSpecifyDatabaseError
public static Throwable tableNotSpecifyDatabaseError(org.apache.spark.sql.catalyst.TableIdentifier identifier) -
tableNotSpecifyLocationUriError
public static Throwable tableNotSpecifyLocationUriError(org.apache.spark.sql.catalyst.TableIdentifier identifier) -
partitionNotSpecifyLocationUriError
-
invalidBucketNumberError
-
corruptedTableNameContextInCatalogError
-
corruptedViewSQLConfigsInCatalogError
-
corruptedViewQueryOutputColumnsInCatalogError
-
corruptedViewReferredTempViewInCatalogError
-
corruptedViewReferredTempFunctionsInCatalogError
-
columnStatisticsDeserializationNotSupportedError
-
columnStatisticsSerializationNotSupportedError
-
insufficientTablePropertyError
-
insufficientTablePropertyPartError
-
unexpectedSchemaTypeError
public static Throwable unexpectedSchemaTypeError(org.apache.spark.sql.catalyst.expressions.Expression exp) -
schemaIsNotStructTypeError
-
schemaIsNotStructTypeError
-
keyValueInMapNotStringError
public static Throwable keyValueInMapNotStringError(org.apache.spark.sql.catalyst.expressions.CreateMap m) -
nonMapFunctionNotAllowedError
-
invalidFieldTypeForCorruptRecordError
-
dataTypeUnsupportedByClassError
-
parseModeUnsupportedError
-
nonFoldableArgumentError
-
literalTypeUnsupportedForSourceTypeError
-
arrayComponentTypeUnsupportedError
-
secondArgumentNotDoubleLiteralError
-
dataTypeUnsupportedByExtractValueError
-
noHandlerForUDAFError
-
batchWriteCapabilityError
-
unsupportedDeleteByConditionWithSubqueryError
public static Throwable unsupportedDeleteByConditionWithSubqueryError(org.apache.spark.sql.catalyst.expressions.Expression condition) -
cannotTranslateExpressionToSourceFilterError
public static Throwable cannotTranslateExpressionToSourceFilterError(org.apache.spark.sql.catalyst.expressions.Expression f) -
cannotDeleteTableWhereFiltersError
-
describeDoesNotSupportPartitionForV2TablesError
-
cannotReplaceMissingTableError
-
cannotReplaceMissingTableError
public static Throwable cannotReplaceMissingTableError(Identifier tableIdentifier, scala.Option<Throwable> cause) -
streamingSourcesDoNotSupportCommonExecutionModeError
-
noSuchTableError
public static org.apache.spark.sql.catalyst.analysis.NoSuchTableException noSuchTableError(Identifier ident) -
noSuchTableError
-
noSuchNamespaceError
-
tableAlreadyExistsError
-
requiresSinglePartNamespaceError
-
namespaceAlreadyExistsError
-
cannotCreateJDBCTableUsingProviderError
-
cannotCreateJDBCTableUsingLocationError
-
cannotCreateJDBCNamespaceUsingProviderError
-
cannotCreateJDBCNamespaceWithPropertyError
-
cannotSetJDBCNamespaceWithPropertyError
-
cannotUnsetJDBCNamespaceWithPropertyError
-
unsupportedJDBCNamespaceChangeInCatalogError
public static Throwable unsupportedJDBCNamespaceChangeInCatalogError(scala.collection.immutable.Seq<NamespaceChange> changes) -
tableDoesNotSupportReadsError
-
tableDoesNotSupportWritesError
-
tableDoesNotSupportDeletesError
-
tableDoesNotSupportTruncatesError
-
tableDoesNotSupportPartitionManagementError
-
tableDoesNotSupportAtomicPartitionManagementError
-
tableIsNotRowLevelOperationTableError
-
cannotRenameTableWithAlterViewError
-
analyzeTableNotSupportedForV2TablesError
-
alterTableRecoverPartitionsNotSupportedForV2TablesError
-
alterTableSerDePropertiesNotSupportedForV2TablesError
-
loadDataNotSupportedForV2TablesError
-
showCreateTableAsSerdeNotSupportedForV2TablesError
-
showColumnsNotSupportedForV2TablesError
-
repairTableNotSupportedForV2TablesError
-
databaseFromV1SessionCatalogNotSpecifiedError
-
nestedDatabaseUnsupportedByV1SessionCatalogError
-
invalidRepartitionExpressionsError
-
partitionColumnNotSpecifiedError
-
dataSchemaNotSpecifiedError
-
dataPathNotExistError
-
dataSourceOutputModeUnsupportedError
public static Throwable dataSourceOutputModeUnsupportedError(String className, OutputMode outputMode) -
schemaNotSpecifiedForSchemaRelationProviderError
-
userSpecifiedSchemaMismatchActualSchemaError
public static Throwable userSpecifiedSchemaMismatchActualSchemaError(StructType schema, StructType actualSchema) -
dataSchemaNotSpecifiedError
-
invalidDataSourceError
-
cannotSaveIntervalIntoExternalStorageError
-
cannotSaveVariantIntoExternalStorageError
-
cannotResolveAttributeError
-
orcNotUsedWithHiveEnabledError
-
failedToFindAvroDataSourceError
-
failedToFindKafkaDataSourceError
-
findMultipleDataSourceError
-
writeEmptySchemasUnsupportedByDataSourceError
-
insertMismatchedColumnNumberError
public static Throwable insertMismatchedColumnNumberError(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> targetAttributes, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Attribute> sourceAttributes, int staticPartitionsSize) -
insertMismatchedPartitionNumberError
public static Throwable insertMismatchedPartitionNumberError(StructType targetPartitionSchema, int providedPartitionsSize) -
invalidPartitionColumnError
public static Throwable invalidPartitionColumnError(String partKey, StructType targetPartitionSchema) -
multiplePartitionColumnValuesSpecifiedError
public static Throwable multiplePartitionColumnValuesSpecifiedError(StructField field, scala.collection.immutable.Map<String, String> potentialSpecs) -
invalidOrderingForConstantValuePartitionColumnError
public static Throwable invalidOrderingForConstantValuePartitionColumnError(StructType targetPartitionSchema) -
cannotWriteDataToRelationsWithMultiplePathsError
public static Throwable cannotWriteDataToRelationsWithMultiplePathsError(scala.collection.immutable.Seq<org.apache.hadoop.fs.Path> paths) -
failedToRebuildExpressionError
-
dataTypeUnsupportedByDataSourceError
-
failToResolveDataSourceForTableError
-
outputPathAlreadyExistsError
-
invalidPartitionColumnDataTypeError
-
cannotUseAllColumnsForPartitionColumnsError
-
partitionColumnNotFoundInSchemaError
-
columnNotFoundInSchemaError
public static Throwable columnNotFoundInSchemaError(StructField col, scala.Option<StructType> tableSchema) -
saveDataIntoViewNotAllowedError
-
mismatchedTableFormatError
-
mismatchedTableLocationError
public static Throwable mismatchedTableLocationError(org.apache.spark.sql.catalyst.TableIdentifier identifier, org.apache.spark.sql.catalyst.catalog.CatalogTable existingTable, org.apache.spark.sql.catalyst.catalog.CatalogTable tableDesc) -
mismatchedTableColumnNumberError
-
cannotResolveColumnGivenInputColumnsError
-
mismatchedTablePartitionColumnError
-
mismatchedTableBucketingError
-
specifyPartitionNotAllowedWhenTableSchemaNotDefinedError
-
bucketingColumnCannotBePartOfPartitionColumnsError
-
bucketSortingColumnCannotBePartOfPartitionColumnsError
-
invalidBucketColumnDataTypeError
-
requestedPartitionsMismatchTablePartitionsError
public static Throwable requestedPartitionsMismatchTablePartitionsError(String tableName, scala.collection.immutable.Map<String, scala.Option<String>> normalizedPartSpec, StructType partColNames) -
ddlWithoutHiveSupportEnabledError
-
createTableColumnTypesOptionColumnNotFoundInSchemaError
public static Throwable createTableColumnTypesOptionColumnNotFoundInSchemaError(String col, StructType schema) -
parquetTypeUnsupportedYetError
-
illegalParquetTypeError
-
unrecognizedParquetTypeError
-
cannotConvertDataTypeToParquetTypeError
-
incompatibleViewSchemaChangeError
-
numberOfPartitionsNotAllowedWithUnspecifiedDistributionError
-
partitionSizeNotAllowedWithUnspecifiedDistributionError
-
numberAndSizeOfPartitionsNotAllowedTogether
-
unexpectedInputDataTypeError
-
unexpectedNullError
-
streamJoinStreamWithoutEqualityPredicateUnsupportedError
public static Throwable streamJoinStreamWithoutEqualityPredicateUnsupportedError(org.apache.spark.sql.catalyst.plans.logical.LogicalPlan plan) -
invalidPandasUDFPlacementError
-
ambiguousAttributesInSelfJoinError
public static Throwable ambiguousAttributesInSelfJoinError(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.AttributeReference> ambiguousAttrs) -
ambiguousColumnOrFieldError
-
ambiguousReferenceError
-
cannotUseIntervalTypeInTableSchemaError
-
missingCatalogAbilityError
-
tableValuedFunctionTooManyTableArgumentsError
-
tableValuedFunctionFailedToAnalyseInPythonError
-
pythonDataSourceError
-
identifierTooManyNamePartsError
-
emptyMultipartIdentifierError
-
cannotOperateOnHiveDataSourceFilesError
-
setPathOptionAndCallWithPathParameterError
-
userSpecifiedSchemaUnsupportedError
-
tempViewNotSupportStreamingWriteError
-
streamingIntoViewNotSupportedError
-
inputSourceDiffersFromDataSourceProviderError
-
tableNotSupportStreamingWriteError
-
queryNameNotSpecifiedForMemorySinkError
-
sourceNotSupportedWithContinuousTriggerError
-
columnNotFoundInExistingColumnsError
-
operationNotSupportPartitioningError
-
mixedRefsInAggFunc
-
subqueryReturnMoreThanOneColumn
public static Throwable subqueryReturnMoreThanOneColumn(int number, org.apache.spark.sql.catalyst.trees.Origin origin) -
functionCannotProcessInputError
public static Throwable functionCannotProcessInputError(UnboundFunction unbound, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> arguments, UnsupportedOperationException unsupported) -
v2FunctionInvalidInputTypeLengthError
public static Throwable v2FunctionInvalidInputTypeLengthError(BoundFunction bound, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> args) -
cannotResolveColumnNameAmongAttributesError
-
cannotWriteTooManyColumnsToTableError
-
cannotWriteNotEnoughColumnsToTableError
-
incompatibleDataToTableCannotFindDataError
-
incompatibleDataToTableAmbiguousColumnNameError
-
incompatibleDataToTableExtraColumnsError
-
incompatibleDataToTableExtraStructFieldsError
-
incompatibleDataToTableNullableColumnError
-
incompatibleDataToTableNullableArrayElementsError
-
incompatibleDataToTableNullableMapValuesError
-
incompatibleDataToTableCannotSafelyCastError
-
incompatibleDataToTableStructMissingFieldsError
-
incompatibleDataToTableUnexpectedColumnNameError
-
invalidRowLevelOperationAssignments
-
invalidEscapeChar
public static Throwable invalidEscapeChar(org.apache.spark.sql.catalyst.expressions.Expression sqlExpr) -
secondArgumentOfFunctionIsNotIntegerError
public static Throwable secondArgumentOfFunctionIsNotIntegerError(String function, NumberFormatException e) -
nonPartitionPruningPredicatesNotExpectedError
public static Throwable nonPartitionPruningPredicatesNotExpectedError(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> nonPartitionPruningPredicates) -
columnNotDefinedInTableError
-
invalidLiteralForWindowDurationError
-
noSuchStructFieldInGivenFieldsError
-
ambiguousReferenceToFieldsError
-
secondArgumentInFunctionIsNotBooleanLiteralError
-
joinConditionMissingOrTrivialError
public static Throwable joinConditionMissingOrTrivialError(org.apache.spark.sql.catalyst.plans.logical.Join join, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan left, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan right) -
usePythonUDFInJoinConditionUnsupportedError
public static Throwable usePythonUDFInJoinConditionUnsupportedError(org.apache.spark.sql.catalyst.plans.JoinType joinType) -
conflictingAttributesInJoinConditionError
public static Throwable conflictingAttributesInJoinConditionError(org.apache.spark.sql.catalyst.expressions.AttributeSet conflictingAttrs, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan outerPlan, org.apache.spark.sql.catalyst.plans.logical.LogicalPlan subplan) -
emptyWindowExpressionError
public static Throwable emptyWindowExpressionError(org.apache.spark.sql.catalyst.plans.logical.Window expr) -
foundDifferentWindowFunctionTypeError
public static Throwable foundDifferentWindowFunctionTypeError(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.NamedExpression> windowExpressions) -
escapeCharacterInTheMiddleError
-
escapeCharacterAtTheEndError
-
tableIdentifierExistsError
public static Throwable tableIdentifierExistsError(org.apache.spark.sql.catalyst.TableIdentifier tableIdentifier) -
tableIdentifierNotConvertedToHadoopFsRelationError
public static Throwable tableIdentifierNotConvertedToHadoopFsRelationError(org.apache.spark.sql.catalyst.TableIdentifier tableIdentifier) -
alterDatabaseLocationUnsupportedError
-
hiveTableTypeUnsupportedError
-
unknownHiveResourceTypeError
-
configRemovedInVersionError
-
invalidPartitionColumnKeyInTableError
-
invalidPartitionSpecError
-
columnAlreadyExistsError
-
noSuchTableError
-
tempViewNotCachedForAnalyzingColumnsError
public static Throwable tempViewNotCachedForAnalyzingColumnsError(org.apache.spark.sql.catalyst.TableIdentifier tableIdent) -
columnTypeNotSupportStatisticsCollectionError
-
analyzeTableNotSupportedOnViewsError
-
unexpectedPartitionColumnPrefixError
-
noSuchPartitionError
-
notExistPartitionError
public static Throwable notExistPartitionError(Identifier table, org.apache.spark.sql.catalyst.InternalRow partitionIdent, StructType partitionSchema) -
analyzingColumnStatisticsNotSupportedForColumnTypeError
-
tableAlreadyExistsError
-
createTableAsSelectWithNonEmptyDirectoryError
-
unsetNonExistentPropertiesError
-
alterTableChangeColumnNotSupportedForColumnTypeError
public static Throwable alterTableChangeColumnNotSupportedForColumnTypeError(String tableName, StructField originColumn, StructField newColumn, org.apache.spark.sql.catalyst.trees.Origin origin) -
cannotAlterPartitionColumn
-
cannotFindColumnError
-
alterTableSetSerdeForSpecificPartitionNotSupportedError
-
alterTableSetSerdeNotSupportedError
-
cmdOnlyWorksOnPartitionedTablesError
-
cmdOnlyWorksOnTableWithLocationError
-
actionNotAllowedOnTableWithFilesourcePartitionManagementDisabledError
-
actionNotAllowedOnTableSincePartitionMetadataNotStoredError
-
cannotAlterViewWithAlterTableError
-
cannotAlterTableWithAlterViewError
-
cannotOverwritePathBeingReadFromError
-
cannotOverwriteTableThatIsBeingReadFromError
public static Throwable cannotOverwriteTableThatIsBeingReadFromError(org.apache.spark.sql.catalyst.TableIdentifier tableIdent) -
cannotDropBuiltinFuncError
-
cannotRefreshBuiltInFuncError
-
cannotRefreshTempFuncError
-
noSuchFunctionError
public static Throwable noSuchFunctionError(org.apache.spark.sql.catalyst.FunctionIdentifier identifier) -
alterAddColNotSupportViewError
public static Throwable alterAddColNotSupportViewError(org.apache.spark.sql.catalyst.TableIdentifier table) -
alterAddColNotSupportDatasourceTableError
-
loadDataNotSupportedForDatasourceTablesError
-
loadDataWithoutPartitionSpecProvidedError
-
loadDataPartitionSizeNotMatchNumPartitionColumnsError
-
loadDataTargetTableNotPartitionedButPartitionSpecWasProvidedError
-
loadDataInputPathNotExistError
-
truncateTableOnExternalTablesError
-
truncateTablePartitionNotSupportedForNotPartitionedTablesError
-
failToTruncateTableWhenRemovingDataError
-
descPartitionNotAllowedOnTempView
-
descPartitionNotAllowedOnView
-
showPartitionNotAllowedOnTableNotPartitionedError
-
showCreateTableNotSupportedOnTempView
-
showCreateTableFailToExecuteUnsupportedFeatureError
public static Throwable showCreateTableFailToExecuteUnsupportedFeatureError(org.apache.spark.sql.catalyst.catalog.CatalogTable table) -
showCreateTableNotSupportTransactionalHiveTableError
public static Throwable showCreateTableNotSupportTransactionalHiveTableError(org.apache.spark.sql.catalyst.catalog.CatalogTable table) -
showCreateTableFailToExecuteUnsupportedConfError
public static Throwable showCreateTableFailToExecuteUnsupportedConfError(org.apache.spark.sql.catalyst.TableIdentifier table, scala.collection.mutable.StringBuilder builder) -
showCreateTableAsSerdeNotAllowedOnSparkDataSourceTableError
public static Throwable showCreateTableAsSerdeNotAllowedOnSparkDataSourceTableError(org.apache.spark.sql.catalyst.TableIdentifier table) -
showCreateTableOrViewFailToExecuteUnsupportedFeatureError
-
logicalPlanForViewNotAnalyzedError
-
cannotCreateViewTooManyColumnsError
-
cannotCreateViewNotEnoughColumnsError
-
cannotAlterTempViewWithSchemaBindingError
-
unsupportedCreateOrReplaceViewOnTableError
public static Throwable unsupportedCreateOrReplaceViewOnTableError(org.apache.spark.sql.catalyst.TableIdentifier name, boolean replace) -
viewAlreadyExistsError
-
createPersistedViewFromDatasetAPINotAllowedError
-
recursiveViewDetectedError
public static Throwable recursiveViewDetectedError(org.apache.spark.sql.catalyst.TableIdentifier viewIdent, scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.TableIdentifier> newPath) -
notAllowedToCreatePermanentViewWithoutAssigningAliasForExpressionError
public static Throwable notAllowedToCreatePermanentViewWithoutAssigningAliasForExpressionError(org.apache.spark.sql.catalyst.TableIdentifier name, org.apache.spark.sql.catalyst.expressions.Attribute attr) -
notAllowedToCreatePermanentViewByReferencingTempViewError
-
notAllowedToCreatePermanentViewByReferencingTempFuncError
-
notAllowedToCreatePermanentViewByReferencingTempVarError
-
queryFromRawFilesIncludeCorruptRecordColumnError
-
userDefinedPartitionNotFoundInJDBCRelationError
-
invalidPartitionColumnTypeError
-
tableOrViewAlreadyExistsError
-
invalidColumnNameAsPathError
-
textDataSourceWithMultiColumnsError
-
cannotFindPartitionColumnInPartitionSchemaError
public static Throwable cannotFindPartitionColumnInPartitionSchemaError(StructField readField, StructType partitionSchema) -
cannotSpecifyDatabaseForTempViewError
public static Throwable cannotSpecifyDatabaseForTempViewError(org.apache.spark.sql.catalyst.TableIdentifier tableIdent) -
cannotCreateTempViewUsingHiveDataSourceError
-
invalidTimestampProvidedForStrategyError
-
hostOptionNotSetError
-
portOptionNotSetError
-
invalidIncludeTimestampValueError
-
checkpointLocationNotSpecifiedError
-
recoverQueryFromCheckpointUnsupportedError
public static Throwable recoverQueryFromCheckpointUnsupportedError(org.apache.hadoop.fs.Path checkpointPath) -
cannotFindColumnInRelationOutputError
-
invalidBoundaryStartError
-
invalidBoundaryEndError
-
tableOrViewNotFound
-
unsupportedTableChangeInJDBCCatalogError
-
pathOptionNotSetCorrectlyWhenReadingError
-
pathOptionNotSetCorrectlyWhenWritingError
-
invalidSaveModeError
-
invalidSingleVariantColumn
-
writeWithSaveModeUnsupportedBySourceError
-
partitionByDoesNotAllowedWhenUsingInsertIntoError
-
cannotFindCatalogToHandleIdentifierError
-
sortByWithoutBucketingError
-
bucketByUnsupportedByOperationError
-
bucketByAndSortByUnsupportedByOperationError
-
tableAlreadyExistsError
public static Throwable tableAlreadyExistsError(org.apache.spark.sql.catalyst.TableIdentifier tableIdent) -
invalidPartitionTransformationError
public static Throwable invalidPartitionTransformationError(org.apache.spark.sql.catalyst.expressions.Expression expr) -
unresolvedColumnError
-
cannotParseIntervalError
-
invalidJoinTypeInJoinWithError
public static Throwable invalidJoinTypeInJoinWithError(org.apache.spark.sql.catalyst.plans.JoinType joinType) -
cannotPassTypedColumnInUntypedSelectError
-
invalidViewNameError
-
invalidBucketsNumberError
-
usingUntypedScalaUDFError
-
aggregationFunctionAppliedOnNonNumericColumnError
-
aggregationFunctionAppliedOnNonNumericColumnError
-
cannotModifyValueOfStaticConfigError
-
cannotModifyValueOfSparkConfigError
-
commandExecutionInRunnerUnsupportedError
-
udfClassDoesNotImplementAnyUDFInterfaceError
-
udfClassImplementMultiUDFInterfacesError
-
udfClassWithTooManyTypeArgumentsError
-
classWithoutPublicNonArgumentConstructorError
-
cannotLoadClassNotOnClassPathError
-
classDoesNotImplementUserDefinedAggregateFunctionError
-
missingFieldError
-
invalidFieldName
-
invalidJsonSchema
-
invalidXmlSchema
-
tableIndexNotSupportedError
-
invalidViewText
-
invalidTimeTravelSpecError
-
invalidTimestampExprForTimeTravel
-
timeTravelUnsupportedError
-
writeDistributionAndOrderingNotSupportedInContinuousExecution
-
defaultReferencesNotAllowedInComplexExpressionsInInsertValuesList
-
defaultReferencesNotAllowedInComplexExpressionsInUpdateSetClause
-
defaultReferencesNotAllowedInComplexExpressionsInMergeInsertsOrUpdates
-
nonDeterministicMergeCondition
-
subqueryNotAllowedInMergeCondition
-
aggregationNotAllowedInMergeCondition
-
failedToParseExistenceDefaultAsLiteral
-
defaultReferencesNotAllowedInDataSource
-
addNewDefaultColumnToExistingTableNotAllowed
-
defaultValuesDataTypeError
-
defaultValuesUnresolvedExprError
-
defaultValuesMayNotContainSubQueryExpressions
-
defaultValueNotConstantError
-
nullableColumnOrFieldError
-
notNullConstraintViolationArrayElementError
-
notNullConstraintViolationMapValueError
-
invalidColumnOrFieldDataTypeError
-
columnNotInGroupByClauseError
public static Throwable columnNotInGroupByClauseError(org.apache.spark.sql.catalyst.expressions.Expression expression) -
implicitCollationMismatchError
-
explicitCollationMismatchError
-
indeterminateCollationError
-
cannotConvertProtobufTypeToSqlTypeError
-
cannotConvertCatalystTypeToProtobufTypeError
-
cannotConvertProtobufTypeToCatalystTypeError
-
cannotConvertSqlTypeToProtobufError
-
protobufTypeUnsupportedYetError
-
unknownProtobufMessageTypeError
-
cannotFindCatalystTypeInProtobufSchemaError
-
cannotFindProtobufFieldInCatalystError
-
protobufFieldMatchError
-
unableToLocateProtobufMessageError
-
foundRecursionInProtobufSchema
-
protobufFieldTypeMismatchError
-
protobufClassLoadError
-
protobufDescriptorDependencyError
-
invalidByteStringFormatError
-
funcBuildError
-
ambiguousRelationAliasNameInNestedCTEError
-
ambiguousLateralColumnAliasError
-
ambiguousLateralColumnAliasError
-
lateralColumnAliasInAggFuncUnsupportedError
-
lateralColumnAliasInWindowUnsupportedError
-
lateralColumnAliasInAggWithWindowAndHavingUnsupportedError
-
dataTypeOperationUnsupportedError
-
nullableRowIdError
public static Throwable nullableRowIdError(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.AttributeReference> nullableRowIdAttrs) -
cannotRenameTableAcrossSchemaError
-
avroIncompatibleReadError
-
optionMustBeLiteralString
-
optionMustBeConstant
-
tableValuedFunctionRequiredMetadataIncompatibleWithCall
-
tableValuedFunctionRequiredMetadataInvalid
-
dataSourceAlreadyExists
-
dataSourceDoesNotExist
-
foundMultipleDataSources
-
foundMultipleXMLDataSourceError
-
xmlRowTagRequiredError
-
invalidUDFClassError
-
unsupportedParameterExpression
public static Throwable unsupportedParameterExpression(org.apache.spark.sql.catalyst.expressions.Expression expr) -
invalidQueryAllParametersMustBeNamed
public static Throwable invalidQueryAllParametersMustBeNamed(scala.collection.immutable.Seq<org.apache.spark.sql.catalyst.expressions.Expression> expr) -
invalidQueryMixedQueryParameters
-
invalidExecuteImmediateVariableType
-
nullSQLStringExecuteImmediate
-
invalidStatementForExecuteInto
-
nestedExecuteImmediate
-
dataSourceTableSchemaMismatchError
public static Throwable dataSourceTableSchemaMismatchError(StructType dsSchema, StructType expectedSchema) -
cannotResolveDataFrameColumn
public static Throwable cannotResolveDataFrameColumn(org.apache.spark.sql.catalyst.expressions.Expression e) -
ambiguousColumnReferences
public static Throwable ambiguousColumnReferences(org.apache.spark.sql.catalyst.expressions.Expression e) -
createTableDeprecatedError
-
cannotAssignEventTimeColumn
-
toSQLId
-
toSQLId
-
toSQLStmt
-
toSQLConf
-
toSQLType
-
toSQLType
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
toSQLValue
-
getSummary
-
getQueryContext
-
toSQLConfVal
-
toDSOption
-
toSQLExpr
-
toSQLValue
-
ordinalNumber
-
columnNotFoundError
-
descriptorParseError
-
cannotFindDescriptorFileError
-