Interface ExecutionErrors

All Superinterfaces:
DataTypeErrorsBase

public interface ExecutionErrors extends DataTypeErrorsBase
  • Method Details

    • fieldDiffersFromDerivedLocalDateError

      org.apache.spark.SparkDateTimeException fieldDiffersFromDerivedLocalDateError(ChronoField field, int actual, int expected, LocalDate candidate)
    • failToParseDateTimeInNewParserError

      org.apache.spark.SparkUpgradeException failToParseDateTimeInNewParserError(String s, Throwable e)
    • failToRecognizePatternAfterUpgradeError

      org.apache.spark.SparkUpgradeException failToRecognizePatternAfterUpgradeError(String pattern, Throwable e)
    • failToRecognizePatternError

      org.apache.spark.SparkRuntimeException failToRecognizePatternError(String pattern, Throwable e)
    • unreachableError

      org.apache.spark.SparkRuntimeException unreachableError(String err)
    • invalidInputInCastToDatetimeError

      org.apache.spark.SparkDateTimeException invalidInputInCastToDatetimeError(org.apache.spark.unsafe.types.UTF8String value, DataType to, org.apache.spark.sql.catalyst.trees.SQLQueryContext context)
    • invalidInputInCastToDatetimeError

      org.apache.spark.SparkDateTimeException invalidInputInCastToDatetimeError(double value, DataType to, org.apache.spark.sql.catalyst.trees.SQLQueryContext context)
    • invalidInputInCastToDatetimeErrorInternal

      org.apache.spark.SparkDateTimeException invalidInputInCastToDatetimeErrorInternal(String sqlValue, DataType from, DataType to, org.apache.spark.sql.catalyst.trees.SQLQueryContext context)
    • arithmeticOverflowError

      ArithmeticException arithmeticOverflowError(String message, String hint, org.apache.spark.sql.catalyst.trees.SQLQueryContext context)
    • cannotParseStringAsDataTypeError

      org.apache.spark.SparkRuntimeException cannotParseStringAsDataTypeError(String pattern, String value, DataType dataType)
    • unsupportedArrowTypeError

      org.apache.spark.SparkUnsupportedOperationException unsupportedArrowTypeError(org.apache.arrow.vector.types.pojo.ArrowType typeName)
    • duplicatedFieldNameInArrowStructError

      org.apache.spark.SparkUnsupportedOperationException duplicatedFieldNameInArrowStructError(scala.collection.Seq<String> fieldNames)
    • unsupportedDataTypeError

      org.apache.spark.SparkUnsupportedOperationException unsupportedDataTypeError(DataType typeName)
    • userDefinedTypeNotAnnotatedAndRegisteredError

      Throwable userDefinedTypeNotAnnotatedAndRegisteredError(UserDefinedType<?> udt)
    • cannotFindEncoderForTypeError

      org.apache.spark.SparkUnsupportedOperationException cannotFindEncoderForTypeError(String typeName)
    • cannotHaveCircularReferencesInBeanClassError

      org.apache.spark.SparkUnsupportedOperationException cannotHaveCircularReferencesInBeanClassError(Class<?> clazz)
    • cannotFindConstructorForTypeError

      org.apache.spark.SparkUnsupportedOperationException cannotFindConstructorForTypeError(String tpe)
    • cannotHaveCircularReferencesInClassError

      org.apache.spark.SparkUnsupportedOperationException cannotHaveCircularReferencesInClassError(String t)
    • cannotUseInvalidJavaIdentifierAsFieldNameError

      org.apache.spark.SparkUnsupportedOperationException cannotUseInvalidJavaIdentifierAsFieldNameError(String fieldName, org.apache.spark.sql.catalyst.WalkedTypePath walkedTypePath)
    • primaryConstructorNotFoundError

      org.apache.spark.SparkRuntimeException primaryConstructorNotFoundError(Class<?> cls)
    • cannotGetOuterPointerForInnerClassError

      org.apache.spark.SparkRuntimeException cannotGetOuterPointerForInnerClassError(Class<?> innerCls)