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

QueryExecutionErrors

object QueryExecutionErrors

Object for grouping error messages from (most) exceptions thrown during query execution. This does not include exceptions thrown during the eager execution of commands, which are grouped into QueryCompilationErrors.

Source
QueryExecutionErrors.scala
Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. QueryExecutionErrors
  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 addFilesWithAbsolutePathUnsupportedError(commitProtocol: String): Throwable
  5. def addNewFunctionMismatchedWithFunctionError(funcName: String): Throwable
  6. def alterTableWithDropPartitionAndPurgeUnsupportedError(): Throwable
  7. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  8. def attributesForTypeUnsupportedError(schema: Schema): Throwable
  9. def batchMetadataFileNotFoundError(batchMetadataFile: Path): Throwable
  10. def binaryArithmeticCauseOverflowError(eval1: Short, symbol: String, eval2: Short): ArithmeticException
  11. def buildReaderUnsupportedForFileFormatError(format: String): Throwable
  12. def cannotAcquireMemoryToBuildLongHashedRelationError(size: Long, got: Long): Throwable
  13. def cannotAcquireMemoryToBuildUnsafeHashedRelationError(): Throwable
  14. def cannotAddMultiPartitionsOnNonatomicPartitionTableError(tableName: String): Throwable
  15. def cannotAllocateMemoryToGrowBytesToBytesMapError(): Throwable
  16. def cannotBroadcastTableOverMaxTableBytesError(maxBroadcastTableBytes: Long, dataSize: Long): Throwable
  17. def cannotBroadcastTableOverMaxTableRowsError(maxBroadcastTableRows: Long, numRows: Long): Throwable
  18. def cannotBuildHashedRelationLargerThan8GError(): Throwable
  19. def cannotBuildHashedRelationWithUniqueKeysExceededError(): Throwable
  20. def cannotCastError(from: DataType, to: DataType): Throwable
  21. def cannotCastFromNullTypeError(to: DataType): Throwable
  22. def cannotCastUTF8StringToDataTypeError(s: UTF8String, to: DataType): Throwable
  23. def cannotChangeDecimalPrecisionError(value: Decimal, decimalPrecision: Int, decimalScale: Int): ArithmeticException
  24. def cannotClearOutputDirectoryError(staticPrefixPath: Path): Throwable
  25. def cannotClearPartitionDirectoryError(path: Path): Throwable
  26. def cannotCloneOrCopyReadOnlySQLConfError(): Throwable
  27. def cannotCompareCostWithTargetCostError(cost: String): Throwable
  28. def cannotConvertColumnToJSONError(name: String, dataType: DataType): Throwable
  29. def cannotCreateArrayWithElementsExceedLimitError(numElements: Long, additionalErrorMessage: String): Throwable
  30. def cannotCreateColumnarReaderError(): Throwable
  31. def cannotCreateJDBCTableWithPartitionsError(): Throwable
  32. def cannotCreateParquetConverterForDataTypeError(t: DataType, parquetType: String): Throwable
  33. def cannotCreateParquetConverterForDecimalTypeError(t: DecimalType, parquetType: String): Throwable
  34. def cannotCreateParquetConverterForTypeError(t: DecimalType, parquetType: String): Throwable
  35. def cannotCreateStagingDirError(message: String, e: IOException): Throwable
  36. def cannotDropMultiPartitionsOnNonatomicPartitionTableError(tableName: String): Throwable
  37. def cannotDropNonemptyNamespaceError(namespace: Seq[String]): Throwable
  38. def cannotEvaluateExpressionError(expression: Expression): Throwable
  39. def cannotExecuteStreamingRelationExecError(): Throwable
  40. def cannotFetchTablesOfDatabaseError(dbName: String, e: Exception): Throwable
  41. def cannotFindConstructorForTypeError(tpe: String): Throwable
  42. def cannotFindEncoderForTypeError(tpe: String, walkedTypePath: WalkedTypePath): Throwable
  43. def cannotGenerateCodeForExpressionError(expression: Expression): Throwable
  44. def cannotGenerateCodeForUncomparableTypeError(codeType: String, dataType: DataType): Throwable
  45. def cannotGenerateCodeForUnsupportedTypeError(dataType: DataType): Throwable
  46. def cannotGetEventTimeWatermarkError(): Throwable
  47. def cannotGetJdbcTypeError(dt: DataType): Throwable
  48. def cannotGetOuterPointerForInnerClassError(innerCls: Class[_]): Throwable
  49. def cannotGetSQLConfInSchedulerEventLoopThreadError(): Throwable
  50. def cannotHaveCircularReferencesInBeanClassError(clazz: Class[_]): Throwable
  51. def cannotHaveCircularReferencesInClassError(t: String): Throwable
  52. def cannotInstantiateAbstractCatalogPluginClassError(name: String, pluginClassName: String, e: Exception): Throwable
  53. def cannotInterpolateClassIntoCodeBlockError(arg: Any): Throwable
  54. def cannotLoadUserDefinedTypeError(name: String, userClass: String): Throwable
  55. def cannotMergeClassWithOtherClassError(className: String, otherClass: String): Throwable
  56. def cannotMergeDecimalTypesWithIncompatiblePrecisionAndScaleError(leftPrecision: Int, rightPrecision: Int, leftScale: Int, rightScale: Int): Throwable
  57. def cannotMergeDecimalTypesWithIncompatiblePrecisionError(leftPrecision: Int, rightPrecision: Int): Throwable
  58. def cannotMergeDecimalTypesWithIncompatibleScaleError(leftScale: Int, rightScale: Int): Throwable
  59. def cannotMergeIncompatibleDataTypesError(left: DataType, right: DataType): Throwable
  60. def cannotMutateReadOnlySQLConfError(): Throwable
  61. def cannotParseDecimalError(): Throwable
  62. def cannotParseJsonArraysAsStructsError(): Throwable
  63. def cannotParseStatisticAsPercentileError(stats: String, e: NumberFormatException): Throwable
  64. def cannotParseStringAsDataTypeError(str: String, dataType: DataType): Throwable
  65. def cannotPurgeAsBreakInternalStateError(): Throwable
  66. def cannotReadFooterForFileError(file: FileStatus, e: RuntimeException): Throwable
  67. def cannotReadFooterForFileError(file: Path, e: IOException): Throwable
  68. def cannotReadParquetFilesError(e: Exception): Throwable
  69. def cannotRecognizeHiveTypeError(e: ParseException, fieldType: String, fieldName: String): Throwable
  70. def cannotRemovePartitionDirError(partitionPath: Path): Throwable
  71. def cannotRemoveReservedPropertyError(property: String): Throwable
  72. def cannotRewriteDomainJoinWithConditionsError(conditions: Seq[Expression], d: DomainJoin): Throwable
  73. def cannotSafelyMergeSerdePropertiesError(props1: Map[String, String], props2: Map[String, String], conflictKeys: Set[String]): Throwable
  74. def cannotSetTimeoutDurationError(): Throwable
  75. def cannotSetTimeoutTimestampError(): Throwable
  76. def cannotSpecifyBothJdbcTableNameAndQueryError(jdbcTableName: String, jdbcQueryString: String): Throwable
  77. def cannotTerminateGeneratorError(generator: UnresolvedGenerator): Throwable
  78. def cannotTranslateNonNullValueForFieldError(pos: Int): Throwable
  79. def cannotUseInvalidJavaIdentifierAsFieldNameError(fieldName: String, walkedTypePath: WalkedTypePath): Throwable
  80. def castingCauseOverflowError(t: Any, targetType: String): ArithmeticException
  81. def catalogFailToCallPublicNoArgConstructorError(name: String, pluginClassName: String, e: Exception): Throwable
  82. def catalogFailToFindPublicNoArgConstructorError(name: String, pluginClassName: String, e: Exception): Throwable
  83. def catalogPluginClassNotFoundError(name: String): Throwable
  84. def catalogPluginClassNotFoundForCatalogError(name: String, pluginClassName: String): Throwable
  85. def catalogPluginClassNotImplementedError(name: String, pluginClassName: String): Throwable
  86. def classHasUnexpectedSerializerError(clsName: String, objSerializer: Expression): Throwable
  87. def classUnsupportedByMapObjectsError(cls: Class[_]): RuntimeException
  88. def cleanUpSourceFilesUnsupportedError(): Throwable
  89. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  90. def columnChangeUnsupportedError(): Throwable
  91. def commentOnTableUnsupportedError(): Throwable
  92. def commitDeniedError(partId: Int, taskId: Long, attemptId: Int, stageId: Int, stageAttempt: Int): Throwable
  93. def compilerError(e: CompileException): Throwable
  94. def concatArraysWithElementsExceedLimitError(numberOfElements: Long): Throwable
  95. def concurrentModificationOnExternalAppendOnlyUnsafeRowArrayError(className: String): Throwable
  96. def concurrentQueryInstanceError(): Throwable
  97. def constructorNotFoundError(cls: String): Throwable
  98. def continuousProcessingUnsupportedByDataSourceError(sourceName: String): Throwable
  99. def convertHiveTableToCatalogTableError(e: SparkException, dbName: String, tableName: String): Throwable
  100. def copyNullFieldNotAllowedError(): Throwable
  101. def createArrayWithElementsExceedLimitError(count: Any): RuntimeException
  102. def createStreamingSourceNotSpecifySchemaError(): Throwable
  103. def customCollectionClsNotResolvedError(): Throwable
  104. def dataPathNotSpecifiedError(): Throwable
  105. def dataTypeOperationUnsupportedError(): Throwable
  106. def dataTypeUnexpectedError(dataType: DataType): Throwable
  107. def dataTypeUnsupportedError(dataType: String, failure: String): Throwable
  108. def dataTypeUnsupportedError(dt: DataType): Throwable
  109. def dataTypeUnsupportedYetError(dataType: DataType): Throwable
  110. def databaseNameConflictWithSystemPreservedDatabaseError(globalTempDB: String): Throwable
  111. def ddlUnsupportedTemporarilyError(ddl: String): Throwable
  112. def decimalPrecisionExceedsMaxPrecisionError(precision: Int, maxPrecision: Int): Throwable
  113. def decorrelateInnerQueryThroughPlanUnsupportedError(plan: LogicalPlan): Throwable
  114. def divideByZeroError(): ArithmeticException
  115. def doExecuteBroadcastNotImplementedError(nodeName: String): Throwable
  116. def doGenCodeOfAliasShouldNotBeCalledError(): Throwable
  117. def dropTableWithPurgeUnsupportedError(): Throwable
  118. def duplicateMapKeyFoundError(key: Any): Throwable
  119. def dynamicPartitionKeyNotAmongWrittenPartitionPathsError(key: String): Throwable
  120. def dynamicPartitionOverwriteUnsupportedByTableError(table: Table): Throwable
  121. def elementsOfTupleExceedLimitError(): Throwable
  122. def emptyOptionError(optionName: String): Throwable
  123. def endOfIteratorError(): Throwable
  124. def endOfStreamError(): Throwable
  125. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  126. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  127. def evaluateUnevaluableAggregateUnsupportedError(methodName: String, unEvaluable: UnevaluableAggregate): Throwable
  128. def exceedMapSizeLimitError(size: Int): Throwable
  129. def executeBroadcastTimeoutError(timeout: Long, ex: Option[TimeoutException]): Throwable
  130. def executeCodePathUnsupportedError(execName: String): Throwable
  131. def expressionDecodingError(e: Exception, expressions: Seq[Expression]): Throwable
  132. def expressionEncodingError(e: Exception, expressions: Seq[Expression]): Throwable
  133. def failToConvertValueToJsonError(value: AnyRef, cls: Class[_], dataType: DataType): Throwable
  134. def failToFormatDateTimeInNewFormatterError(resultCandidate: String, e: Throwable): Throwable
  135. def failToParseDateTimeInNewParserError(s: String, e: Throwable): Throwable
  136. def failToParseEmptyStringForDataTypeError(dataType: DataType): Throwable
  137. def failToParseValueForDataTypeError(dataType: DataType, token: JsonToken): Throwable
  138. def failToRecognizePatternAfterUpgradeError(pattern: String, e: Throwable): Throwable
  139. def failToRecognizePatternError(pattern: String, e: Throwable): Throwable
  140. def failToSetOriginalACLBackError(aclEntries: String, path: Path, e: Throwable): Throwable
  141. def failToSetOriginalPermissionBackError(permission: FsPermission, path: Path, e: Throwable): Throwable
  142. def failedExecuteUserDefinedFunctionError(funcCls: String, inputTypes: String, outputType: String, e: Throwable): Throwable
  143. def failedMergingFieldsError(leftName: String, rightName: String, e: Throwable): Throwable
  144. def failedMergingSchemaError(schema: StructType, e: SparkException): Throwable
  145. def failedParsingStructTypeError(raw: String): Throwable
  146. def failedRenameTempFileError(srcPath: Path, dstPath: Path): Throwable
  147. def failedSplitSubExpressionError(length: Int): Throwable
  148. def failedSplitSubExpressionMsg(length: Int): String
  149. def failedToCastValueToDataTypeForPartitionColumnError(value: String, dataType: DataType, columnName: String): Throwable
  150. def failedToCompileMsg(e: Exception): String
  151. def failedToExecuteQueryError(e: Throwable): QueryExecutionException
  152. def failedToFindDataSourceError(provider: String, error: Throwable): Throwable
  153. def failedToGenerateEpochMarkerError(failureReason: Throwable): Throwable
  154. def failedToInstantiateConstructorForCatalogError(name: String, pluginClassName: String, e: Exception): Throwable
  155. def failedToMergeIncompatibleSchemasError(left: StructType, right: StructType, e: Throwable): Throwable
  156. def failedToPushRowIntoRowQueueError(rowQueue: String): Throwable
  157. def failedToReadDataError(failureReason: Throwable): Throwable
  158. def failedToReadDeltaFileError(fileToRead: Path, clazz: String, keySize: Int): Throwable
  159. def failedToReadSnapshotFileError(fileToRead: Path, clazz: String, message: String): Throwable
  160. def fallbackV1RelationReportsInconsistentSchemaError(v2Schema: StructType, v1Schema: StructType): Throwable
  161. def fieldCannotBeNullError(index: Int, fieldName: String): RuntimeException
  162. def fieldCannotBeNullMsg(index: Int, fieldName: String): String
  163. def fieldDiffersFromDerivedLocalDateError(field: ChronoField, actual: Int, expected: Int, candidate: LocalDate): Throwable
  164. def fieldIndexOnRowWithoutSchemaError(): Throwable
  165. def fileLengthExceedsMaxLengthError(status: FileStatus, maxLength: Int): Throwable
  166. def fileNotFoundError(e: FileNotFoundException): Throwable
  167. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  168. def flattenArraysWithElementsExceedLimitError(numberOfElements: Long): Throwable
  169. def foreachWriterAbortedDueToTaskFailureError(): Throwable
  170. def foundDuplicateFieldInCaseInsensitiveModeError(requiredFieldName: String, matchedOrcFields: String): Throwable
  171. def foundNullValueForNotNullableFieldError(name: String): Throwable
  172. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  173. def getParentLoggerNotImplementedError(className: String): Throwable
  174. def getPartitionMetadataByFilterError(e: InvocationTargetException): Throwable
  175. def getTablesByTypeUnsupportedByHiveVersionError(): Throwable
  176. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  177. def illegalLocationClauseForViewPartitionError(): Throwable
  178. def incompatibleDataSourceRegisterError(e: Throwable): Throwable
  179. def indexOutOfBoundsOfArrayDataError(idx: Int): Throwable
  180. def inferSchemaUnsupportedForHiveError(): Throwable
  181. def initialTypeNotTargetDataTypeError(dataType: DataType, target: String): Throwable
  182. def initialTypeNotTargetDataTypesError(dataType: DataType): Throwable
  183. def inputExternalRowCannotBeNullError(): RuntimeException
  184. def inputFilterNotFullyConvertibleError(owner: String): Throwable
  185. def inputTypeUnsupportedError(dataType: DataType): Throwable
  186. def integerOverflowError(message: String): Throwable
  187. def internalCompilerError(e: InternalCompilerException): Throwable
  188. def invalidArrayIndexError(index: Int, numElements: Int): ArrayIndexOutOfBoundsException
  189. def invalidFractionOfSecondError(): DateTimeException
  190. def invalidInputSyntaxForBooleanError(s: UTF8String): UnsupportedOperationException
  191. def invalidInputSyntaxForNumericError(s: UTF8String): NumberFormatException
  192. def invalidJdbcNumPartitionsError(n: Int, jdbcNumPartitions: String): Throwable
  193. def invalidJdbcTxnIsolationLevelError(jdbcTxnIsolationLevel: String, value: String): Throwable
  194. def invalidKerberosConfigForHiveServer2Error(): Throwable
  195. def invalidNamespaceNameError(namespace: Array[String]): Throwable
  196. def invalidPartitionFilterError(): Throwable
  197. def invalidStartIndexError(numRows: Int, startIndex: Int): Throwable
  198. def invalidStreamingOutputModeError(outputMode: Option[OutputMode]): Throwable
  199. def invalidUrlError(url: UTF8String, e: URISyntaxException): Throwable
  200. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  201. def jobAbortedError(cause: Throwable): Throwable
  202. def latestOffsetNotCalledError(): Throwable
  203. def legacyCheckpointDirectoryExistsError(checkpointPath: Path, legacyCheckpointDir: String): Throwable
  204. def legacyMetadataPathExistsError(metadataPath: Path, legacyMetadataPath: Path): Throwable
  205. def literalTypeUnsupportedError(v: Any): RuntimeException
  206. def loadHiveClientCausesNoClassDefFoundError(cnf: NoClassDefFoundError, execJars: Seq[URL], key: String, e: InvocationTargetException): Throwable
  207. def logicalHintOperatorNotRemovedDuringAnalysisError(): Throwable
  208. def malformedCSVRecordError(): Throwable
  209. def malformedJSONError(): Throwable
  210. def malformedRecordsDetectedInRecordParsingError(e: BadRecordException): Throwable
  211. def malformedRecordsDetectedInSchemaInferenceError(dataType: DataType): Throwable
  212. def malformedRecordsDetectedInSchemaInferenceError(e: Throwable): Throwable
  213. def mapDataKeyArrayLengthDiffersFromValueArrayLengthError(): Throwable
  214. def mapKeyNotExistError(key: Any): NoSuchElementException
  215. def mapSizeExceedArraySizeWhenZipMapError(size: Int): RuntimeException
  216. def mergeUnsupportedByWindowFunctionError(): Throwable
  217. def methodCalledInAnalyzerNotAllowedError(): Throwable
  218. def methodNotDeclaredError(name: String): Throwable
  219. def methodNotImplementedError(methodName: String): Throwable
  220. def microBatchUnsupportedByDataSourceError(srcName: String): Throwable
  221. def missingDatabaseLocationError(): Throwable
  222. def missingJdbcTableNameAndQueryError(jdbcTableName: String, jdbcQueryString: String): Throwable
  223. def multiFailuresInStageMaterializationError(error: Throwable): Throwable
  224. def multiStreamingQueriesUsingPathConcurrentlyError(path: String, e: FileAlreadyExistsException): Throwable
  225. def multiplePathsSpecifiedError(allPaths: Seq[String]): Throwable
  226. def namespaceNotEmptyError(namespace: Array[String]): Throwable
  227. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  228. def negativeValueUnexpectedError(frequencyExpression: Expression): Throwable
  229. def nestedArraysUnsupportedError(): Throwable
  230. def nestedFieldUnsupportedError(colName: String): Throwable
  231. def noDefaultForDataTypeError(dataType: DataType): RuntimeException
  232. def noRecordsFromEmptyDataReaderError(): Throwable
  233. def noSuchElementExceptionError(key: String): Throwable
  234. def noSuchElementExceptionError(): Throwable
  235. def notADatasourceRDDPartitionError(split: Partition): Throwable
  236. def notEnoughMemoryToBuildAndBroadcastTableError(oe: OutOfMemoryError): Throwable
  237. def notExpectedUnresolvedEncoderError(attr: AttributeReference): Throwable
  238. def notOverrideExpectedMethodsError(className: String, m1: String, m2: String): Throwable
  239. def notPublicClassError(name: String): Throwable
  240. def notSupportNonPrimitiveTypeError(): Throwable
  241. def notSupportTypeError(dataType: DataType): Throwable
  242. def notUserDefinedTypeError(name: String, userClass: String): Throwable
  243. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  244. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  245. def nullAsMapKeyNotAllowedError(): RuntimeException
  246. def nullLiteralsCannotBeCastedError(name: String): Throwable
  247. def onceStrategyIdempotenceIsBrokenForBatchError[TreeType <: TreeNode[_]](batchName: String, plan: TreeType, reOptimized: TreeType): Throwable
  248. def onlySupportDataSourcesProvidingFileFormatError(providingClass: String): Throwable
  249. def operatingOnCanonicalizationPlanError(): Throwable
  250. def orderedOperationUnsupportedByDataTypeError(dataType: DataType): Throwable
  251. def outOfDecimalTypeRangeError(str: UTF8String): Throwable
  252. def outputDataTypeUnsupportedByNodeWithoutSerdeError(nodeName: String, dt: DataType): Throwable
  253. def overflowInIntegralDivideError(): ArithmeticException
  254. def overflowInSumOfDecimalError(): ArithmeticException
  255. def overwriteTableByUnsupportedExpressionError(table: Table): Throwable
  256. def pairUnsupportedAtFunctionError(r1: ValueInterval, r2: ValueInterval, function: String): Throwable
  257. def paramExceedOneCharError(paramName: String): Throwable
  258. def paramIsNotBooleanValueError(paramName: String): Throwable
  259. def paramIsNotIntegerError(paramName: String, value: String): Throwable
  260. def parentSparkUIToAttachTabNotFoundError(): Throwable
  261. def partitionColumnNotFoundInSchemaError(col: String, schema: StructType): Throwable
  262. def pivotNotAfterGroupByUnsupportedError(): Throwable
  263. def primaryConstructorNotFoundError(cls: Class[_]): Throwable
  264. def primitiveTypesNotSupportedError(): Throwable
  265. def readCurrentFileNotFoundError(e: FileNotFoundException): Throwable
  266. def regexGroupIndexExceedGroupCountError(groupCount: Int, groupIndex: Int): Throwable
  267. def regexGroupIndexLessThanZeroError(): Throwable
  268. def registeringStreamingQueryListenerError(e: Exception): Throwable
  269. def remoteOperationsUnsupportedError(): Throwable
  270. def removedClassInSpark2Error(className: String, e: Throwable): Throwable
  271. def renameAsExistsPathError(dstPath: Path): Throwable
  272. def renameColumnUnsupportedForOlderMySQLError(): Throwable
  273. def renamePathAsExistsPathError(srcPath: Path, dstPath: Path): Throwable
  274. def renameSrcPathNotFoundError(srcPath: Path): Throwable
  275. def repeatedPivotsUnsupportedError(): Throwable
  276. def requestedPartitionsMismatchTablePartitionsError(table: CatalogTable, partition: Map[String, Option[String]]): Throwable
  277. def resolveCannotHandleNestedSchema(plan: LogicalPlan): Throwable
  278. def rootConverterReturnNullError(): Throwable
  279. def rowFromCSVParserNotExpectedError(): Throwable
  280. def rowLargerThan256MUnsupportedError(): Throwable
  281. def ruleIdNotFoundForRuleError(ruleName: String): Throwable
  282. def schemaForTypeUnsupportedError(tpe: String): Throwable
  283. def serDeInterfaceNotFoundError(e: NoClassDefFoundError): Throwable
  284. def simpleStringWithNodeIdUnsupportedError(nodeName: String): Throwable
  285. def sparkUpgradeInReadingDatesError(format: String, config: String, option: String): SparkUpgradeException
  286. def sparkUpgradeInWritingDatesError(format: String, config: String): SparkUpgradeException
  287. def sqlArrayIndexNotStartAtOneError(): ArrayIndexOutOfBoundsException
  288. def stateNotDefinedOrAlreadyRemovedError(): Throwable
  289. def statisticNotRecognizedError(stats: String): Throwable
  290. def streamedOperatorUnsupportedByDataSourceError(className: String, operator: String): Throwable
  291. def structuralIntegrityIsBrokenAfterApplyingRuleError(ruleName: String, batchName: String): Throwable
  292. def structuralIntegrityOfInputPlanIsBrokenInClassError(className: String): Throwable
  293. def subprocessExitedError(exitCode: Int, stderrBuffer: CircularBuffer, cause: Throwable): Throwable
  294. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  295. def tableStatsNotSpecifiedError(): Throwable
  296. def taskFailedWhileWritingRowsError(cause: Throwable): Throwable
  297. def timeZoneIdNotSpecifiedForTimestampTypeError(): Throwable
  298. def toString(): String
    Definition Classes
    AnyRef → Any
  299. def transactionUnsupportedByJdbcServerError(): Throwable
  300. def transformationsAndActionsNotInvokedByDriverError(): Throwable
  301. def truncateMultiPartitionUnsupportedError(tableName: String): Throwable
  302. def typeUnsupportedError(dataType: DataType): Throwable
  303. def unableToCreateDatabaseAsFailedToCreateDirectoryError(dbDefinition: CatalogDatabase, e: IOException): Throwable
  304. def unableToCreatePartitionPathError(partitionPath: Path, e: IOException): Throwable
  305. def unableToCreateTableAsFailedToCreateDirectoryError(table: String, defaultTableLocation: Path, e: IOException): Throwable
  306. def unableToDeletePartitionPathError(partitionPath: Path, e: IOException): Throwable
  307. def unableToDropDatabaseAsFailedToDeleteDirectoryError(dbDefinition: CatalogDatabase, e: IOException): Throwable
  308. def unableToDropTableAsFailedToDeleteDirectoryError(table: String, dir: Path, e: IOException): Throwable
  309. def unableToRenamePartitionPathError(oldPartPath: Path, e: IOException): Throwable
  310. def unableToRenameTableAsFailedToRenameDirectoryError(oldName: String, newName: String, oldDir: Path, e: IOException): Throwable
  311. def unaryMinusCauseOverflowError(originValue: AnyVal): ArithmeticException
  312. def unexpectedAccumulableUpdateValueError(o: Any): Throwable
  313. def unexpectedOperatorInCorrelatedSubquery(op: LogicalPlan, pos: String = ""): Throwable
  314. def unexpectedValueForLengthInFunctionError(prettyName: String): RuntimeException
  315. def unexpectedValueForStartInFunctionError(prettyName: String): RuntimeException
  316. def unexpectedWindowFunctionFrameError(frame: String): Throwable
  317. def unionArrayWithElementsExceedLimitError(length: Int): Throwable
  318. def unknownColumnError(unknownColumn: String): Throwable
  319. def unreachableError(err: String = ""): Throwable
  320. def unrecognizedCompressionSchemaTypeIDError(typeId: Int): Throwable
  321. def unrecognizedFileFormatError(format: String): Throwable
  322. def unrecognizedSqlTypeError(sqlType: Int): Throwable
  323. def unscaledValueTooLargeForPrecisionError(): Throwable
  324. def unsupportedArrayElementTypeBasedOnBinaryError(dt: DataType): Throwable
  325. def unsupportedArrayTypeError(clazz: Class[_]): Throwable
  326. def unsupportedDataTypeError(dt: String): Throwable
  327. def unsupportedEncoderError(): Throwable
  328. def unsupportedFieldNameError(fieldName: String): Throwable
  329. def unsupportedHiveMetastoreVersionError(version: String, key: String): Throwable
  330. def unsupportedJavaTypeError(clazz: Class[_]): Throwable
  331. def unsupportedJdbcTypeError(content: String): Throwable
  332. def unsupportedNaturalJoinTypeError(joinType: JoinType): Throwable
  333. def unsupportedOperandTypeForSizeFunctionError(dataType: DataType): Throwable
  334. def unsupportedOperationExceptionError(): Throwable
  335. def unsupportedOperationForDataTypeError(dataType: DataType): Throwable
  336. def unsupportedPartitionTransformError(transform: Transform): Throwable
  337. def unsupportedRoundingMode(roundMode: scala.math.BigDecimal.RoundingMode.Value): Throwable
  338. def unsupportedSaveModeError(saveMode: String, pathExists: Boolean): Throwable
  339. def unsupportedSchemaColumnConvertError(filePath: String, column: String, logicalType: String, physicalType: String, e: Exception): Throwable
  340. def unsupportedTableChangeError(e: IllegalArgumentException): Throwable
  341. def unsupportedTableWritesError(ident: Identifier): Throwable
  342. def unsupportedTypeError(dataType: DataType): Throwable
  343. def unsupportedUpdateColumnNullabilityError(): Throwable
  344. def unsupportedUserSpecifiedSchemaError(): Throwable
  345. def useDictionaryEncodingWhenDictionaryOverflowError(): Throwable
  346. def userDefinedTypeNotAnnotatedAndRegisteredError(udt: UserDefinedType[_]): Throwable
  347. def userSpecifiedSchemaUnsupportedByDataSourceError(provider: TableProvider): Throwable
  348. def valueIsNullError(index: Int): Throwable
  349. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  350. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  351. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  352. def writeUnsupportedForBinaryFileDataSourceError(): Throwable
  353. def writingJobAbortedError(e: Throwable): Throwable
  354. def writingJobFailedError(cause: Throwable): Throwable

Inherited from AnyRef

Inherited from Any

Ungrouped