Packages

  • package root
    Definition Classes
    root
  • package org
    Definition Classes
    root
  • package apache
    Definition Classes
    org
  • package spark

    Core Spark functionality.

    Core Spark functionality. org.apache.spark.SparkContext serves as the main entry point to Spark, while org.apache.spark.rdd.RDD is the data type representing a distributed collection, and provides most parallel operations.

    In addition, org.apache.spark.rdd.PairRDDFunctions contains operations available only on RDDs of key-value pairs, such as groupByKey and join; org.apache.spark.rdd.DoubleRDDFunctions contains operations available only on RDDs of Doubles; and org.apache.spark.rdd.SequenceFileRDDFunctions contains operations available on RDDs that can be saved as SequenceFiles. These operations are automatically available on any RDD of the right type (e.g. RDD[(Int, Int)] through implicit conversions.

    Java programmers should reference the org.apache.spark.api.java package for Spark programming APIs in Java.

    Classes and methods marked with Experimental are user-facing features which have not been officially adopted by the Spark project. These are subject to change or removal in minor releases.

    Classes and methods marked with Developer API are intended for advanced users want to extend Spark through lower level interfaces. These are subject to changes or removal in minor releases.

    Definition Classes
    apache
  • package sql

    Allows the execution of relational queries, including those expressed in SQL using Spark.

    Allows the execution of relational queries, including those expressed in SQL using Spark.

    Definition Classes
    spark
  • package errors
    Definition Classes
    sql
  • QueryCompilationErrors
  • QueryExecutionErrors
  • QueryParsingErrors
o

org.apache.spark.sql.errors

QueryCompilationErrors

object 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.

Source
QueryCompilationErrors.scala
Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. QueryCompilationErrors
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. def actionNotAllowedOnTableSincePartitionMetadataNotStoredError(action: String, tableName: String): Throwable
  5. def actionNotAllowedOnTableWithFilesourcePartitionManagementDisabledError(action: String, tableName: String): Throwable
  6. def addColumnWithV1TableCannotSpecifyNotNullError(): Throwable
  7. def aggregateExpressionRequiredForPivotError(sql: String): Throwable
  8. def aggregationFunctionAppliedOnNonNumericColumnError(pivotColumn: String, maxValues: Int): Throwable
  9. def aggregationFunctionAppliedOnNonNumericColumnError(colName: String): Throwable
  10. def aliasNumberNotMatchColumnNumberError(columnSize: Int, outputSize: Int, t: TreeNode[_]): Throwable
  11. def aliasesNumberNotMatchUDTFOutputError(aliasesSize: Int, aliasesNames: String): Throwable
  12. def alterAddColNotSupportDatasourceTableError(tableType: Any, table: TableIdentifier): Throwable
  13. def alterAddColNotSupportViewError(table: TableIdentifier): Throwable
  14. def alterColumnCannotFindColumnInV1TableError(colName: String, v1Table: V1Table): Throwable
  15. def alterColumnWithV1TableCannotSpecifyNotNullError(): Throwable
  16. def alterDatabaseLocationUnsupportedError(version: String): Throwable
  17. def alterOnlySupportedWithV2TableError(): Throwable
  18. def alterQualifiedColumnOnlySupportedWithV2TableError(): Throwable
  19. def alterTableChangeColumnNotSupportedForColumnTypeError(originColumn: StructField, newColumn: StructField): Throwable
  20. def alterTableRecoverPartitionsNotSupportedForV2TablesError(): Throwable
  21. def alterTableSerDePropertiesNotSupportedForV2TablesError(): Throwable
  22. def alterTableSetSerdeForSpecificPartitionNotSupportedError(): Throwable
  23. def alterTableSetSerdeNotSupportedError(): Throwable
  24. def alterV2TableSetLocationWithPartitionNotSupportedError(): Throwable
  25. def ambiguousAttributesInSelfJoinError(ambiguousAttrs: Seq[AttributeReference]): Throwable
  26. def ambiguousFieldNameError(fieldName: Seq[String], numMatches: Int, context: Origin): Throwable
  27. def ambiguousReferenceToFieldsError(fields: String): Throwable
  28. def ambiguousRelationAliasNameInNestedCTEError(name: String): Throwable
  29. def analyzeTableNotSupportedForV2TablesError(): Throwable
  30. def analyzeTableNotSupportedOnViewsError(): Throwable
  31. def analyzingColumnStatisticsNotSupportedForColumnTypeError(name: String, dataType: DataType): Throwable
  32. def arrayComponentTypeUnsupportedError(clz: Class[_]): Throwable
  33. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  34. def attributeNameSyntaxError(name: String): Throwable
  35. def attributeNotFoundError(colName: String, child: LogicalPlan): Throwable
  36. def batchWriteCapabilityError(table: Table, v2WriteClassName: String, v1WriteClassName: String): Throwable
  37. def bucketByAndSortByUnsupportedByOperationError(operation: String): Throwable
  38. def bucketByUnsupportedByOperationError(operation: String): Throwable
  39. def bucketSortingColumnCannotBePartOfPartitionColumnsError(sortCol: String, normalizedPartCols: Seq[String]): Throwable
  40. def bucketingColumnCannotBePartOfPartitionColumnsError(bucketCol: String, normalizedPartCols: Seq[String]): Throwable
  41. def cannotAlterTableWithAlterViewError(): Throwable
  42. def cannotAlterViewWithAlterTableError(): Throwable
  43. def cannotApplyTableValuedFunctionError(name: String, arguments: String, usage: String, details: String = ""): Throwable
  44. def cannotConvertBucketWithSortColumnsToTransformError(spec: BucketSpec): Throwable
  45. def cannotConvertDataTypeToParquetTypeError(field: StructField): Throwable
  46. def cannotConvertTransformsToPartitionColumnsError(nonIdTransforms: Seq[Transform]): Throwable
  47. def cannotCreateDatabaseWithSameNameAsPreservedDatabaseError(database: String): Throwable
  48. def cannotCreateJDBCNamespaceUsingProviderError(): Throwable
  49. def cannotCreateJDBCNamespaceWithPropertyError(k: String): Throwable
  50. def cannotCreateJDBCTableUsingLocationError(): Throwable
  51. def cannotCreateJDBCTableUsingProviderError(): Throwable
  52. def cannotCreateTableWithBothProviderAndSerdeError(provider: Option[String], maybeSerdeInfo: Option[SerdeInfo]): Throwable
  53. def cannotCreateTempViewUsingHiveDataSourceError(): Throwable
  54. def cannotDeleteTableWhereFiltersError(table: Table, filters: Array[Filter]): Throwable
  55. def cannotDropDefaultDatabaseError(): Throwable
  56. def cannotDropNativeFuncError(functionName: String): Throwable
  57. def cannotDropViewWithDropTableError(): Throwable
  58. def cannotFindCatalogToHandleIdentifierError(quote: String): Throwable
  59. def cannotFindColumnError(name: String, fieldNames: Array[String]): Throwable
  60. def cannotFindColumnInRelationOutputError(colName: String, relation: LogicalPlan): Throwable
  61. def cannotFindPartitionColumnInPartitionSchemaError(readField: StructField, partitionSchema: StructType): Throwable
  62. def cannotLoadClassNotOnClassPathError(className: String): Throwable
  63. def cannotLoadClassWhenRegisteringFunctionError(className: String, func: FunctionIdentifier): Throwable
  64. def cannotModifyValueOfSparkConfigError(key: String): Throwable
  65. def cannotModifyValueOfStaticConfigError(key: String): Throwable
  66. def cannotOperateManagedTableWithExistingLocationError(methodName: String, tableIdentifier: TableIdentifier, tableLocation: Path): Throwable
  67. def cannotOperateOnHiveDataSourceFilesError(operation: String): Throwable
  68. def cannotOverwritePathBeingReadFromError(): Throwable
  69. def cannotOverwriteTableThatIsBeingReadFromError(tableName: String): Throwable
  70. def cannotParseIntervalError(delayThreshold: String, e: Throwable): Throwable
  71. def cannotPartitionByNestedColumnError(reference: NamedReference): Throwable
  72. def cannotPassTypedColumnInUntypedSelectError(typedCol: String): Throwable
  73. def cannotReadCorruptedTablePropertyError(key: String, details: String = ""): Throwable
  74. def cannotRefreshBuiltInFuncError(functionName: String): Throwable
  75. def cannotRefreshTempFuncError(functionName: String): Throwable
  76. def cannotRenameTableWithAlterViewError(): Throwable
  77. def cannotRenameTempViewToExistingTableError(oldName: TableIdentifier, newName: TableIdentifier): Throwable
  78. def cannotRenameTempViewWithDatabaseSpecifiedError(oldName: TableIdentifier, newName: TableIdentifier): Throwable
  79. def cannotReplaceMissingTableError(tableIdentifier: Identifier, cause: Option[Throwable]): Throwable
  80. def cannotReplaceMissingTableError(tableIdentifier: Identifier): Throwable
  81. def cannotResolveAttributeError(name: String, outputStr: String): Throwable
  82. def cannotResolveColumnGivenInputColumnsError(col: String, inputColumns: String): Throwable
  83. def cannotResolveColumnNameAmongAttributesError(colName: String, fieldNames: String): Throwable
  84. def cannotResolveColumnNameAmongFieldsError(colName: String, fieldsStr: String, extraMsg: String): AnalysisException
  85. def cannotResolveStarExpandGivenInputColumnsError(targetString: String, columns: String): Throwable
  86. def cannotResolveUserSpecifiedColumnsError(col: String, t: TreeNode[_]): Throwable
  87. def cannotRetrieveTableOrViewNotInSameDatabaseError(qualifiedTableNames: Seq[QualifiedTableName]): Throwable
  88. def cannotSaveIntervalIntoExternalStorageError(): Throwable
  89. def cannotSetJDBCNamespaceWithPropertyError(k: String): Throwable
  90. def cannotSpecifyDatabaseForTempViewError(tableIdent: TableIdentifier): Throwable
  91. def cannotSpecifyWindowFrameError(prettyName: String): Throwable
  92. def cannotTranslateExpressionToSourceFilterError(f: Expression): Throwable
  93. def cannotUnsetJDBCNamespaceWithPropertyError(k: String): Throwable
  94. def cannotUpCastAsAttributeError(fromAttr: Attribute, toAttr: Attribute): Throwable
  95. def cannotUseAllColumnsForPartitionColumnsError(): Throwable
  96. def cannotUseCatalogError(plugin: CatalogPlugin, msg: String): Throwable
  97. def cannotUseDataTypeForPartitionColumnError(field: StructField): Throwable
  98. def cannotUseIntervalTypeInTableSchemaError(): Throwable
  99. def cannotUseMixtureOfAggFunctionAndGroupAggPandasUDFError(): Throwable
  100. def cannotUsePreservedDatabaseAsCurrentDatabaseError(database: String): Throwable
  101. def cannotWriteDataToRelationsWithMultiplePathsError(): Throwable
  102. def cannotWriteIncompatibleDataToTableError(tableName: String, errors: Seq[String]): Throwable
  103. def cannotWriteNotEnoughColumnsToTableError(tableName: String, expected: Seq[Attribute], query: LogicalPlan): Throwable
  104. def cannotWriteTooManyColumnsToTableError(tableName: String, expected: Seq[Attribute], query: LogicalPlan): Throwable
  105. def charOrVarcharTypeAsStringUnsupportedError(): Throwable
  106. def checkpointLocationNotSpecifiedError(): Throwable
  107. def classDoesNotImplementUserDefinedAggregateFunctionError(className: String): Throwable
  108. def classWithoutPublicNonArgumentConstructorError(className: String): Throwable
  109. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  110. def cmdOnlyWorksOnPartitionedTablesError(cmd: String, tableIdentWithDB: String): Throwable
  111. def cmdOnlyWorksOnTableWithLocationError(cmd: String, tableIdentWithDB: String): Throwable
  112. def columnDoesNotExistError(colName: String): Throwable
  113. def columnNameContainsInvalidCharactersError(name: String): Throwable
  114. def columnNotDefinedInTableError(colType: String, colName: String, tableName: String, tableCols: Seq[String]): Throwable
  115. def columnNotFoundInExistingColumnsError(columnType: String, columnName: String, validColumnNames: Seq[String]): Throwable
  116. def columnNotFoundInSchemaError(col: StructField, tableSchema: Option[StructType]): Throwable
  117. def columnStatisticsDeserializationNotSupportedError(name: String, dataType: DataType): Throwable
  118. def columnStatisticsSerializationNotSupportedError(colName: String, dataType: DataType): Throwable
  119. def columnTypeNotSupportStatisticsCollectionError(name: String, tableIdent: TableIdentifier, dataType: DataType): Throwable
  120. def commandExecutionInRunnerUnsupportedError(runner: String): Throwable
  121. def commandNotSupportNestedColumnError(command: String, quoted: String): Throwable
  122. def commandUnsupportedInV2TableError(name: String): Throwable
  123. def configRemovedInVersionError(configName: String, version: String, comment: String): Throwable
  124. def conflictingAttributesInJoinConditionError(conflictingAttrs: AttributeSet, outerPlan: LogicalPlan, subplan: LogicalPlan): Throwable
  125. def corruptedTableNameContextInCatalogError(numParts: Int, index: Int): Throwable
  126. def corruptedViewQueryOutputColumnsInCatalogError(numCols: String, index: Int): Throwable
  127. def corruptedViewReferredTempFunctionsInCatalogError(e: Exception): Throwable
  128. def corruptedViewReferredTempViewInCatalogError(e: Exception): Throwable
  129. def corruptedViewSQLConfigsInCatalogError(e: Exception): Throwable
  130. def createExternalTableWithoutLocationError(): Throwable
  131. def createFuncWithBothIfNotExistsAndReplaceError(): Throwable
  132. def createPersistedViewFromDatasetAPINotAllowedError(): Throwable
  133. def createTableAsSelectWithNonEmptyDirectoryError(tablePath: String): Throwable
  134. def createTableColumnTypesOptionColumnNotFoundInSchemaError(col: String, schema: StructType): Throwable
  135. def createViewNumColumnsMismatchUserSpecifiedColumnLengthError(analyzedPlanLength: Int, userSpecifiedColumnsLength: Int): Throwable
  136. def createViewWithBothIfNotExistsAndReplaceError(): Throwable
  137. def dataPathNotExistError(path: String): Throwable
  138. def dataSchemaNotSpecifiedError(format: String, fileCatalog: String): Throwable
  139. def dataSchemaNotSpecifiedError(format: String): Throwable
  140. def dataSourceOutputModeUnsupportedError(className: String, outputMode: OutputMode): Throwable
  141. def dataTypeMismatchForDeserializerError(dataType: DataType, desiredType: String): Throwable
  142. def dataTypeUnsupportedByClassError(x: DataType, className: String): Throwable
  143. def dataTypeUnsupportedByDataSourceError(format: String, field: StructField): Throwable
  144. def dataTypeUnsupportedByExtractValueError(dataType: DataType, extraction: Expression, child: Expression): Throwable
  145. def databaseDoesNotExistError(dbName: String): Throwable
  146. def databaseFromV1SessionCatalogNotSpecifiedError(): Throwable
  147. def databaseNotEmptyError(db: String, details: String): Throwable
  148. def ddlWithoutHiveSupportEnabledError(detail: String): Throwable
  149. def decimalCannotGreaterThanPrecisionError(scale: Int, precision: Int): Throwable
  150. def decimalOnlySupportPrecisionUptoError(decimalType: String, precision: Int): Throwable
  151. def defineTempFuncWithIfNotExistsError(): Throwable
  152. def defineTempViewWithIfNotExistsError(): Throwable
  153. def deleteOnlySupportedWithV2TablesError(): Throwable
  154. def descPartitionNotAllowedOnTempView(table: String): Throwable
  155. def descPartitionNotAllowedOnView(table: String): Throwable
  156. def descPartitionNotAllowedOnViewError(table: String): Throwable
  157. def describeDoesNotSupportPartitionForV2TablesError(): Throwable
  158. def dropColumnOnlySupportedWithV2TableError(): Throwable
  159. def dropNonExistentColumnsNotSupportedError(nonExistentColumnNames: Seq[String]): Throwable
  160. def emptyMultipartIdentifierError(): Throwable
  161. def emptyWindowExpressionError(expr: Window): Throwable
  162. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  163. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  164. def expectTableNotViewError(v: ResolvedView, cmd: String, mismatchHint: Option[String], t: TreeNode[_]): Throwable
  165. def expectTableOrPermanentViewNotTempViewError(quoted: String, cmd: String, t: TreeNode[_]): Throwable
  166. def expectViewNotTableError(v: ResolvedTable, cmd: String, mismatchHint: Option[String], t: TreeNode[_]): Throwable
  167. def expressionWithMultiWindowExpressionsError(expr: NamedExpression, distinctWindowSpec: Seq[WindowSpecDefinition]): Throwable
  168. def expressionWithoutWindowExpressionError(expr: NamedExpression): Throwable
  169. def externalCatalogNotSupportShowViewsError(resolved: ResolvedNamespace): Throwable
  170. def failToResolveDataSourceForTableError(table: CatalogTable, key: String): Throwable
  171. def failToTruncateTableWhenRemovingDataError(tableIdentWithDB: String, path: Path, e: Throwable): Throwable
  172. def failedFallbackParsingError(msg: String, e1: Throwable, e2: Throwable): Throwable
  173. def failedToFindAvroDataSourceError(provider: String): Throwable
  174. def failedToFindKafkaDataSourceError(provider: String): Throwable
  175. def failedToRebuildExpressionError(filter: Filter): Throwable
  176. def fieldNumberMismatchForDeserializerError(schema: StructType, maxOrdinal: Int): Throwable
  177. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  178. def findMultipleDataSourceError(provider: String, sourceNames: Seq[String]): Throwable
  179. def foundDifferentWindowFunctionTypeError(windowExpressions: Seq[NamedExpression]): Throwable
  180. def foundDuplicateColumnError(colType: String, duplicateCol: Seq[String]): Throwable
  181. def functionAcceptsOnlyOneArgumentError(name: String): Throwable
  182. def functionAlreadyExistsError(func: FunctionIdentifier): Throwable
  183. def functionCannotProcessInputError(unbound: UnboundFunction, arguments: Seq[Expression], unsupported: UnsupportedOperationException): Throwable
  184. def functionUndefinedError(name: FunctionIdentifier): Throwable
  185. def functionUnsupportedInV2CatalogError(): Throwable
  186. def functionWithUnsupportedSyntaxError(prettyName: String, syntax: String): Throwable
  187. def generatorNotExpectedError(name: FunctionIdentifier, classCanonicalName: String): Throwable
  188. def generatorOutsideSelectError(plan: LogicalPlan): Throwable
  189. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  190. def groupAggPandasUDFUnsupportedByStreamingAggError(): Throwable
  191. def groupByPositionRangeError(index: Int, size: Int): Throwable
  192. def groupByPositionRefersToAggregateFunctionError(index: Int, expr: Expression): Throwable
  193. def groupingColInvalidError(groupingCol: Expression, groupByExprs: Seq[Expression]): Throwable
  194. def groupingIDMismatchError(groupingID: GroupingID, groupByExprs: Seq[Expression]): Throwable
  195. def groupingMustWithGroupingSetsOrCubeOrRollupError(): Throwable
  196. def groupingSizeTooLargeError(sizeLimit: Int): Throwable
  197. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  198. def hiveCreatePermanentFunctionsUnsupportedError(): Throwable
  199. def hiveTableTypeUnsupportedError(tableType: String): Throwable
  200. def hostOptionNotSetError(): Throwable
  201. def identifierHavingMoreThanTwoNamePartsError(quoted: String, identifier: String): Throwable
  202. def illegalParquetTypeError(parquetType: String): Throwable
  203. def incompatibleRangeInputDataTypeError(expression: Expression, dataType: DataType): Throwable
  204. def incompatibleViewSchemaChange(viewName: String, colName: String, expectedNum: Int, actualCols: Seq[Attribute], viewDDL: Option[String]): Throwable
  205. def inputSourceDiffersFromDataSourceProviderError(source: String, tableName: String, table: CatalogTable): Throwable
  206. def insertIntoViewNotAllowedError(identifier: TableIdentifier, t: TreeNode[_]): Throwable
  207. def insertMismatchedColumnNumberError(targetAttributes: Seq[Attribute], sourceAttributes: Seq[Attribute], staticPartitionsSize: Int): Throwable
  208. def insertMismatchedPartitionNumberError(targetPartitionSchema: StructType, providedPartitionsSize: Int): Throwable
  209. def invalidBoundaryEndError(end: Long): Throwable
  210. def invalidBoundaryStartError(start: Long): Throwable
  211. def invalidBucketNumberError(bucketingMaxBuckets: Int, numBuckets: Int): Throwable
  212. def invalidBucketsNumberError(numBuckets: String, e: String): Throwable
  213. def invalidCoalesceHintParameterError(hintName: String): Throwable
  214. def invalidDataSourceError(className: String): Throwable
  215. def invalidDatabaseNameError(quoted: String): Throwable
  216. def invalidDayTimeField(field: Byte): Throwable
  217. def invalidDayTimeIntervalType(startFieldName: String, endFieldName: String): Throwable
  218. def invalidFieldName(fieldName: Seq[String], path: Seq[String], context: Origin): Throwable
  219. def invalidFieldTypeForCorruptRecordError(): Throwable
  220. def invalidFileFormatForStoredAsError(serdeInfo: SerdeInfo): Throwable
  221. def invalidFunctionArgumentNumberError(validParametersCount: Seq[Int], name: String, params: Seq[Class[Expression]]): Throwable
  222. def invalidFunctionArgumentsError(name: String, expectedInfo: String, actualNumber: Int): Throwable
  223. def invalidHintParameterError(hintName: String, invalidParams: Seq[Any]): Throwable
  224. def invalidIncludeTimestampValueError(): Throwable
  225. def invalidJoinTypeInJoinWithError(joinType: JoinType): Throwable
  226. def invalidLiteralForWindowDurationError(): Throwable
  227. def invalidNameForTableOrDatabaseError(name: String): Throwable
  228. def invalidOrderingForConstantValuePartitionColumnError(targetPartitionSchema: StructType): Throwable
  229. def invalidPartitionColumnError(partKey: String, targetPartitionSchema: StructType): Throwable
  230. def invalidPartitionColumnKeyInTableError(key: String, tblName: String): Throwable
  231. def invalidPartitionColumnTypeError(column: StructField): Throwable
  232. def invalidPartitionSpecError(specKeys: String, partitionColumnNames: Seq[String], tableName: String): Throwable
  233. def invalidPartitionSpecError(details: String): Throwable
  234. def invalidPartitionTransformationError(expr: Expression): Throwable
  235. def invalidPatternError(pattern: String, message: String): Throwable
  236. def invalidRepartitionExpressionsError(sortOrders: Seq[Any]): Throwable
  237. def invalidSchemaStringError(exp: Expression): Throwable
  238. def invalidStarUsageError(prettyName: String): Throwable
  239. def invalidTimestampProvidedForStrategyError(strategy: String, timeString: String): Throwable
  240. def invalidViewNameError(viewName: String): Throwable
  241. def invalidYearMonthField(field: Byte): Throwable
  242. def invalidYearMonthIntervalType(startFieldName: String, endFieldName: String): Throwable
  243. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  244. def joinConditionMissingOrTrivialError(join: Join, left: LogicalPlan, right: LogicalPlan): Throwable
  245. def joinStrategyHintParameterNotSupportedError(unsupported: Any): Throwable
  246. def keyValueInMapNotStringError(m: CreateMap): Throwable
  247. def legacyStoreAssignmentPolicyError(): Throwable
  248. def literalTypeUnsupportedForSourceTypeError(field: String, source: Expression): Throwable
  249. def loadDataInputPathNotExistError(path: String): Throwable
  250. def loadDataNotSupportedForDatasourceTablesError(tableIdentWithDB: String): Throwable
  251. def loadDataNotSupportedForV2TablesError(): Throwable
  252. def loadDataPartitionSizeNotMatchNumPartitionColumnsError(tableIdentWithDB: String, partitionSize: Int, targetTableSize: Int): Throwable
  253. def loadDataTargetTableNotPartitionedButPartitionSpecWasProvidedError(tableIdentWithDB: String): Throwable
  254. def loadDataWithoutPartitionSpecProvidedError(tableIdentWithDB: String): Throwable
  255. def logicalPlanForViewNotAnalyzedError(): Throwable
  256. def lookupFunctionInNonFunctionCatalogError(ident: Identifier, catalog: CatalogPlugin): Throwable
  257. def mismatchedInsertedDataColumnNumberError(tableName: String, insert: InsertIntoStatement, staticPartCols: Set[String]): Throwable
  258. def mismatchedTableBucketingError(tableName: String, specifiedBucketString: String, existingBucketString: String): Throwable
  259. def mismatchedTableColumnNumberError(tableName: String, existingTable: CatalogTable, query: LogicalPlan): Throwable
  260. def mismatchedTableFormatError(tableName: String, existingProvider: Class[_], specifiedProvider: Class[_]): Throwable
  261. def mismatchedTableLocationError(identifier: TableIdentifier, existingTable: CatalogTable, tableDesc: CatalogTable): Throwable
  262. def mismatchedTablePartitionColumnError(tableName: String, specifiedPartCols: Seq[String], existingPartCols: String): Throwable
  263. def missingFieldError(fieldName: Seq[String], table: ResolvedTable, context: Origin): Throwable
  264. def missingStaticPartitionColumn(staticName: String): Throwable
  265. def mixedRefsInAggFunc(funcStr: String): Throwable
  266. def moreThanOneGeneratorError(generators: Seq[Expression], clause: String): Throwable
  267. def multiTimeWindowExpressionsNotSupportedError(t: TreeNode[_]): Throwable
  268. def multiplePartitionColumnValuesSpecifiedError(field: StructField, potentialSpecs: Map[String, String]): Throwable
  269. def namespaceAlreadyExistsError(namespace: Array[String]): Throwable
  270. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  271. def negativeScaleNotAllowedError(scale: Int): Throwable
  272. def nestedDatabaseUnsupportedByV1SessionCatalogError(catalog: String): Throwable
  273. def nestedGeneratorError(trimmedNestedGenerator: Expression): Throwable
  274. def noHandlerForUDAFError(name: String): Throwable
  275. def noSuchFunctionError(identifier: FunctionIdentifier): Throwable
  276. def noSuchNamespaceError(namespace: Array[String]): Throwable
  277. def noSuchPartitionError(db: String, table: String, partition: TablePartitionSpec): Throwable
  278. def noSuchStructFieldInGivenFieldsError(fieldName: String, fields: Array[StructField]): Throwable
  279. def noSuchTableError(db: String, table: String): Throwable
  280. def noSuchTableError(ident: Identifier): Throwable
  281. def nonDeterministicFilterInAggregateError(): Throwable
  282. def nonLiteralPivotValError(pivotVal: Expression): Throwable
  283. def nonMapFunctionNotAllowedError(): Throwable
  284. def nonPartitionColError(partitionName: String): Throwable
  285. def nonPartitionPruningPredicatesNotExpectedError(nonPartitionPruningPredicates: Seq[Expression]): Throwable
  286. def notAllowedToAddDBPrefixForTempViewError(database: String): Throwable
  287. def notAllowedToCreatePermanentViewByReferencingTempFuncError(name: TableIdentifier, funcName: String): Throwable
  288. def notAllowedToCreatePermanentViewByReferencingTempViewError(name: TableIdentifier, nameParts: String): Throwable
  289. def notAllowedToCreatePermanentViewWithoutAssigningAliasForExpressionError(name: TableIdentifier, attrName: String): Throwable
  290. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  291. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  292. def numberOfPartitionsNotAllowedWithUnspecifiedDistributionError(): Throwable
  293. def operationNotSupportPartitioningError(operation: String): Throwable
  294. def orcNotUsedWithHiveEnabledError(): Throwable
  295. def orderByPositionRangeError(index: Int, size: Int, t: TreeNode[_]): Throwable
  296. def outerScopeFailureForNewInstanceError(className: String): Throwable
  297. def outputPathAlreadyExistsError(outputPath: Path): Throwable
  298. def pandasUDFAggregateNotSupportedInPivotError(): Throwable
  299. def parquetTypeUnsupportedYetError(parquetType: String): Throwable
  300. def parseModeUnsupportedError(funcName: String, mode: ParseMode): Throwable
  301. def partitionByDoesNotAllowedWhenUsingInsertIntoError(): Throwable
  302. def partitionColumnNotFoundInSchemaError(col: String, schemaCatalog: String): Throwable
  303. def partitionColumnNotSpecifiedError(format: String, partitionColumn: String): Throwable
  304. def partitionNotSpecifyLocationUriError(specString: String): Throwable
  305. def pathOptionNotSetCorrectlyWhenReadingError(): Throwable
  306. def pathOptionNotSetCorrectlyWhenWritingError(): Throwable
  307. def permanentViewNotSupportedByStreamingReadingAPIError(quoted: String): Throwable
  308. def pivotValDataTypeMismatchError(pivotVal: Expression, pivotCol: Expression): Throwable
  309. def portOptionNotSetError(): Throwable
  310. def queryFromRawFilesIncludeCorruptRecordColumnError(): Throwable
  311. def queryNameNotSpecifiedForMemorySinkError(): Throwable
  312. def readNonStreamingTempViewError(quoted: String): Throwable
  313. def recoverQueryFromCheckpointUnsupportedError(checkpointPath: Path): Throwable
  314. def recursiveViewDetectedError(viewIdent: TableIdentifier, newPath: Seq[TableIdentifier]): Throwable
  315. def referenceColNotFoundForAlterTableChangesError(after: After, parentName: String): Throwable
  316. def renameColumnOnlySupportedWithV2TableError(): Throwable
  317. def renameTableSourceAndDestinationMismatchError(db: String, newDb: String): Throwable
  318. def renameTempViewToExistingViewError(oldName: String, newName: String): Throwable
  319. def repairTableNotSupportedForV2TablesError(): Throwable
  320. def replaceColumnsOnlySupportedWithV2TableError(): Throwable
  321. def replaceTableAsSelectOnlySupportedWithV2TableError(): Throwable
  322. def replaceTableOnlySupportedWithV2TableError(): Throwable
  323. def requestedPartitionsMismatchTablePartitionsError(tableName: String, normalizedPartSpec: Map[String, Option[String]], partColNames: StructType): Throwable
  324. def requiresSinglePartNamespaceError(ident: Identifier): Throwable
  325. def resourceTypeNotSupportedError(resourceType: String): Throwable
  326. def saveDataIntoViewNotAllowedError(): Throwable
  327. def schemaIsNotStructTypeError(dataType: DataType): Throwable
  328. def schemaNotFoldableError(exp: Expression): Throwable
  329. def schemaNotSpecifiedForSchemaRelationProviderError(className: String): Throwable
  330. def secondArgumentInFunctionIsNotBooleanLiteralError(funcName: String): Throwable
  331. def secondArgumentNotDoubleLiteralError(): Throwable
  332. def secondArgumentOfFunctionIsNotIntegerError(function: String, e: NumberFormatException): Throwable
  333. def selectExprNotInGroupByError(expr: Expression, groupByAliases: Seq[Alias]): Throwable
  334. def sessionWindowGapDurationDataTypeError(dt: DataType): Throwable
  335. def setPathOptionAndCallWithPathParameterError(method: String): Throwable
  336. def showColumnsNotSupportedForV2TablesError(): Throwable
  337. def showColumnsWithConflictDatabasesError(db: Seq[String], v1TableName: TableIdentifier): Throwable
  338. def showCreateTableAsSerdeNotAllowedOnSparkDataSourceTableError(table: TableIdentifier): Throwable
  339. def showCreateTableAsSerdeNotSupportedForV2TablesError(): Throwable
  340. def showCreateTableFailToExecuteUnsupportedConfError(table: TableIdentifier, builder: StringBuilder): Throwable
  341. def showCreateTableFailToExecuteUnsupportedFeatureError(table: CatalogTable): Throwable
  342. def showCreateTableNotSupportTransactionalHiveTableError(table: CatalogTable): Throwable
  343. def showCreateTableNotSupportedOnTempView(table: String): Throwable
  344. def showCreateTableOrViewFailToExecuteUnsupportedFeatureError(table: CatalogTable, features: Seq[String]): Throwable
  345. def showPartitionNotAllowedOnTableNotPartitionedError(tableIdentWithDB: String): Throwable
  346. def singleTableStarInCountNotAllowedError(targetString: String): Throwable
  347. def sortByNotUsedWithBucketByError(): Throwable
  348. def sourceNotSupportedWithContinuousTriggerError(source: String): Throwable
  349. def specifyPartitionNotAllowedWhenTableSchemaNotDefinedError(): Throwable
  350. def specifyingDBInCreateTempFuncError(databaseName: String): Throwable
  351. def specifyingDBInDropTempFuncError(databaseName: String): Throwable
  352. def sqlOnlySupportedWithV1TablesError(sql: String): Throwable
  353. def starExpandDataTypeNotSupportedError(attributes: Seq[String]): Throwable
  354. def starNotAllowedWhenGroupByOrdinalPositionUsedError(): Throwable
  355. def streamJoinStreamWithoutEqualityPredicateUnsupportedError(plan: LogicalPlan): Throwable
  356. def streamingIntoViewNotSupportedError(viewName: String): Throwable
  357. def streamingSourcesDoNotSupportCommonExecutionModeError(microBatchSources: Seq[String], continuousSources: Seq[String]): Throwable
  358. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  359. def tableAlreadyExistsError(tableIdent: TableIdentifier): Throwable
  360. def tableAlreadyExistsError(table: String, guide: String = ""): Throwable
  361. def tableAlreadyExistsError(ident: Identifier): Throwable
  362. def tableDoesNotExistInDatabaseError(tableName: String, dbName: String): Throwable
  363. def tableDoesNotSupportAtomicPartitionManagementError(table: Table): Throwable
  364. def tableDoesNotSupportDeletesError(table: Table): Throwable
  365. def tableDoesNotSupportPartitionManagementError(table: Table): Throwable
  366. def tableDoesNotSupportReadsError(table: Table): Throwable
  367. def tableDoesNotSupportTruncatesError(table: Table): Throwable
  368. def tableDoesNotSupportWritesError(table: Table): Throwable
  369. def tableIdentifierExistsError(tableIdentifier: TableIdentifier): Throwable
  370. def tableIdentifierNotConvertedToHadoopFsRelationError(tableIdentifier: TableIdentifier): Throwable
  371. def tableIsNotViewError(name: TableIdentifier): Throwable
  372. def tableNotSpecifyDatabaseError(identifier: TableIdentifier): Throwable
  373. def tableNotSpecifyLocationUriError(identifier: TableIdentifier): Throwable
  374. def tableNotSupportStreamingWriteError(tableName: String, t: Table): Throwable
  375. def tableOrViewAlreadyExistsError(name: String): Throwable
  376. def tableOrViewNotFoundError(table: String): Throwable
  377. def tableOrViewNotFoundInDatabaseError(tableName: String, dbName: String): Throwable
  378. def tempViewNotCachedForAnalyzingColumnsError(tableIdent: TableIdentifier): Throwable
  379. def tempViewNotSupportStreamingWriteError(viewName: String): Throwable
  380. def textDataSourceWithMultiColumnsError(schema: StructType): Throwable
  381. def toString(): String
    Definition Classes
    AnyRef → Any
  382. def truncateTableOnExternalTablesError(tableIdentWithDB: String): Throwable
  383. def truncateTablePartitionNotSupportedForNotPartitionedTablesError(tableIdentWithDB: String): Throwable
  384. def udfClassDoesNotImplementAnyUDFInterfaceError(className: String): Throwable
  385. def udfClassNotAllowedToImplementMultiUDFInterfacesError(className: String): Throwable
  386. def udfClassWithTooManyTypeArgumentsError(n: Int): Throwable
  387. def unexpectedEvalTypesForUDFsError(evalTypes: Set[Int]): Throwable
  388. def unexpectedPartitionColumnPrefixError(table: String, database: String, schemaColumns: String, specColumns: String): Throwable
  389. def unexpectedTypeOfRelationError(relation: LogicalPlan, tableName: String): Throwable
  390. def unfoldableFieldUnsupportedError(): Throwable
  391. def unknownHiveResourceTypeError(resourceType: String): Throwable
  392. def unorderablePivotColError(pivotCol: Expression): Throwable
  393. def unrecognizedParquetTypeError(field: String): Throwable
  394. def unresolvedUsingColForJoinError(colName: String, plan: LogicalPlan, side: String): Throwable
  395. def unsetNonExistentPropertyError(property: String, table: TableIdentifier): Throwable
  396. def unsupportedAbstractDataTypeForUpCastError(gotType: AbstractDataType): Throwable
  397. def unsupportedAppendInBatchModeError(table: Table): Throwable
  398. def unsupportedBatchReadError(table: Table): Throwable
  399. def unsupportedDataSourceTypeForDirectQueryOnFilesError(className: String): Throwable
  400. def unsupportedDeleteByConditionWithSubqueryError(condition: Option[Expression]): Throwable
  401. def unsupportedDynamicOverwriteInBatchModeError(table: Table): Throwable
  402. def unsupportedFunctionNameError(quoted: String): Throwable
  403. def unsupportedIfNotExistsError(tableName: String): Throwable
  404. def unsupportedJDBCNamespaceChangeInCatalogError(changes: Seq[NamespaceChange]): Throwable
  405. def unsupportedMicroBatchOrContinuousScanError(table: Table): Throwable
  406. def unsupportedOverwriteByFilterInBatchModeError(table: Table): Throwable
  407. def unsupportedTableChangeInJDBCCatalogError(change: TableChange): Throwable
  408. def unsupportedTableOperationError(table: Table, cmd: String): Throwable
  409. def unsupportedTruncateInBatchModeError(table: Table): Throwable
  410. def upCastFailureError(fromStr: String, from: Expression, to: DataType, walkedTypePath: Seq[String]): Throwable
  411. def usePythonUDFInJoinConditionUnsupportedError(joinType: JoinType): Throwable
  412. def userDefinedPartitionNotFoundInJDBCRelationError(columnName: String, schema: String): Throwable
  413. def userSpecifiedSchemaMismatchActualSchemaError(schema: StructType, actualSchema: StructType): Throwable
  414. def userSpecifiedSchemaUnsupportedError(operation: String): Throwable
  415. def usingUntypedScalaUDFError(): Throwable
  416. def v2FunctionInvalidInputTypeLengthError(bound: BoundFunction, args: Seq[Expression]): Throwable
  417. def viewAlreadyExistsError(name: TableIdentifier): Throwable
  418. def viewDepthExceedsMaxResolutionDepthError(identifier: TableIdentifier, maxNestedViewDepth: Int, t: TreeNode[_]): Throwable
  419. def viewOutputNumberMismatchQueryColumnNamesError(output: Seq[Attribute], queryColumnNames: Seq[String]): Throwable
  420. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  421. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  422. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  423. def windowAggregateFunctionWithFilterNotSupportedError(): Throwable
  424. def windowFrameNotMatchRequiredFrameError(f: SpecifiedWindowFrame, required: WindowFrame): Throwable
  425. def windowFunctionInsideAggregateFunctionNotAllowedError(): Throwable
  426. def windowFunctionNotAllowedError(clauseName: String): Throwable
  427. def windowFunctionWithWindowFrameNotOrderedError(wf: WindowFunction): Throwable
  428. def windowSpecificationNotDefinedError(windowName: String): Throwable
  429. def writeEmptySchemasUnsupportedByDataSourceError(): Throwable
  430. def writeIntoTempViewNotAllowedError(quoted: String): Throwable
  431. def writeIntoV1TableNotAllowedError(identifier: TableIdentifier, t: TreeNode[_]): Throwable
  432. def writeIntoViewNotAllowedError(identifier: TableIdentifier, t: TreeNode[_]): Throwable
  433. def writeTableWithMismatchedColumnsError(columnSize: Int, outputSize: Int, t: TreeNode[_]): Throwable
  434. def writeWithSaveModeUnsupportedBySourceError(source: String, createMode: String): Throwable

Inherited from AnyRef

Inherited from Any

Ungrouped