Class SparkCoreErrors

Object
org.apache.spark.errors.SparkCoreErrors

public class SparkCoreErrors extends Object
Object for grouping error messages from (most) exceptions thrown during query execution.
  • Constructor Details

    • SparkCoreErrors

      public SparkCoreErrors()
  • Method Details

    • unexpectedPy4JServerError

      public static Throwable unexpectedPy4JServerError(Object other)
    • eofExceptionWhileReadPortNumberError

      public static Throwable eofExceptionWhileReadPortNumberError(String daemonModule, scala.Option<Object> daemonExitValue)
    • unsupportedDataTypeError

      public static Throwable unsupportedDataTypeError(Object other)
    • rddBlockNotFoundError

      public static Throwable rddBlockNotFoundError(BlockId blockId, int id)
    • blockHaveBeenRemovedError

      public static Throwable blockHaveBeenRemovedError(String string)
    • histogramOnEmptyRDDOrContainingInfinityOrNaNError

      public static Throwable histogramOnEmptyRDDOrContainingInfinityOrNaNError()
    • emptyRDDError

      public static Throwable emptyRDDError()
    • pathNotSupportedError

      public static Throwable pathNotSupportedError(String path)
    • checkpointRDDBlockIdNotFoundError

      public static Throwable checkpointRDDBlockIdNotFoundError(RDDBlockId rddBlockId)
    • endOfStreamError

      public static Throwable endOfStreamError()
    • cannotUseMapSideCombiningWithArrayKeyError

      public static Throwable cannotUseMapSideCombiningWithArrayKeyError()
    • hashPartitionerCannotPartitionArrayKeyError

      public static Throwable hashPartitionerCannotPartitionArrayKeyError()
    • reduceByKeyLocallyNotSupportArrayKeysError

      public static Throwable reduceByKeyLocallyNotSupportArrayKeysError()
    • rddLacksSparkContextError

      public static Throwable rddLacksSparkContextError()
    • cannotChangeStorageLevelError

      public static Throwable cannotChangeStorageLevelError()
    • canOnlyZipRDDsWithSamePartitionSizeError

      public static Throwable canOnlyZipRDDsWithSamePartitionSizeError()
    • emptyCollectionError

      public static Throwable emptyCollectionError()
    • countByValueApproxNotSupportArraysError

      public static Throwable countByValueApproxNotSupportArraysError()
    • checkpointDirectoryHasNotBeenSetInSparkContextError

      public static Throwable checkpointDirectoryHasNotBeenSetInSparkContextError()
    • invalidCheckpointFileError

      public static Throwable invalidCheckpointFileError(org.apache.hadoop.fs.Path path)
    • failToCreateCheckpointPathError

      public static Throwable failToCreateCheckpointPathError(org.apache.hadoop.fs.Path checkpointDirPath)
    • checkpointRDDHasDifferentNumberOfPartitionsFromOriginalRDDError

      public static Throwable checkpointRDDHasDifferentNumberOfPartitionsFromOriginalRDDError(int originalRDDId, int originalRDDLength, int newRDDId, int newRDDLength)
    • checkpointFailedToSaveError

      public static Throwable checkpointFailedToSaveError(int task, org.apache.hadoop.fs.Path path)
    • mustSpecifyCheckpointDirError

      public static Throwable mustSpecifyCheckpointDirError()
    • askStandaloneSchedulerToShutDownExecutorsError

      public static Throwable askStandaloneSchedulerToShutDownExecutorsError(Exception e)
    • stopStandaloneSchedulerDriverEndpointError

      public static Throwable stopStandaloneSchedulerDriverEndpointError(Exception e)
    • noExecutorIdleError

      public static Throwable noExecutorIdleError(String id)
    • barrierStageWithRDDChainPatternError

      public static Throwable barrierStageWithRDDChainPatternError()
    • barrierStageWithDynamicAllocationError

      public static Throwable barrierStageWithDynamicAllocationError()
    • numPartitionsGreaterThanMaxNumConcurrentTasksError

      public static Throwable numPartitionsGreaterThanMaxNumConcurrentTasksError(int numPartitions, int maxNumConcurrentTasks)
    • cannotRunSubmitMapStageOnZeroPartitionRDDError

      public static Throwable cannotRunSubmitMapStageOnZeroPartitionRDDError()
    • accessNonExistentAccumulatorError

      public static Throwable accessNonExistentAccumulatorError(long id)
    • sendResubmittedTaskStatusForShuffleMapStagesOnlyError

      public static Throwable sendResubmittedTaskStatusForShuffleMapStagesOnlyError()
    • nonEmptyEventQueueAfterTimeoutError

      public static Throwable nonEmptyEventQueueAfterTimeoutError(long timeoutMillis)
    • durationCalledOnUnfinishedTaskError

      public static Throwable durationCalledOnUnfinishedTaskError()
    • unrecognizedSchedulerModePropertyError

      public static Throwable unrecognizedSchedulerModePropertyError(String schedulerModeProperty, String schedulingModeConf)
    • sparkError

      public static Throwable sparkError(String errorMsg)
    • clusterSchedulerError

      public static Throwable clusterSchedulerError(String message)
    • failToSerializeTaskError

      public static Throwable failToSerializeTaskError(Throwable e)
    • unrecognizedBlockIdError

      public static Throwable unrecognizedBlockIdError(String name)
    • taskHasNotLockedBlockError

      public static Throwable taskHasNotLockedBlockError(long currentTaskAttemptId, BlockId blockId)
    • blockDoesNotExistError

      public static Throwable blockDoesNotExistError(BlockId blockId)
    • cannotSaveBlockOnDecommissionedExecutorError

      public static Throwable cannotSaveBlockOnDecommissionedExecutorError(BlockId blockId)
    • waitingForReplicationToFinishError

      public static Throwable waitingForReplicationToFinishError(Throwable e)
    • unableToRegisterWithExternalShuffleServerError

      public static Throwable unableToRegisterWithExternalShuffleServerError(Throwable e)
    • waitingForAsyncReregistrationError

      public static Throwable waitingForAsyncReregistrationError(Throwable e)
    • unexpectedShuffleBlockWithUnsupportedResolverError

      public static Throwable unexpectedShuffleBlockWithUnsupportedResolverError(org.apache.spark.shuffle.ShuffleManager shuffleManager, BlockId blockId)
    • failToStoreBlockOnBlockManagerError

      public static Throwable failToStoreBlockOnBlockManagerError(BlockManagerId blockManagerId, BlockId blockId)
    • readLockedBlockNotFoundError

      public static Throwable readLockedBlockNotFoundError(BlockId blockId)
    • failToGetBlockWithLockError

      public static Throwable failToGetBlockWithLockError(BlockId blockId)
    • blockNotFoundError

      public static Throwable blockNotFoundError(BlockId blockId)
    • interruptedError

      public static Throwable interruptedError()
    • blockStatusQueryReturnedNullError

      public static Throwable blockStatusQueryReturnedNullError(BlockId blockId)
    • unexpectedBlockManagerMasterEndpointResultError

      public static Throwable unexpectedBlockManagerMasterEndpointResultError()
    • failToCreateDirectoryError

      public static Throwable failToCreateDirectoryError(String path, int maxAttempts)
    • unsupportedOperationError

      public static Throwable unsupportedOperationError()
    • noSuchElementError

      public static Throwable noSuchElementError()
    • fetchFailedError

      public static Throwable fetchFailedError(BlockManagerId bmAddress, int shuffleId, long mapId, int mapIndex, int reduceId, String message, Throwable cause)
    • failToGetNonShuffleBlockError

      public static Throwable failToGetNonShuffleBlockError(BlockId blockId, Throwable e)
    • graphiteSinkInvalidProtocolError

      public static Throwable graphiteSinkInvalidProtocolError(String invalidProtocol)
    • graphiteSinkPropertyMissingError

      public static Throwable graphiteSinkPropertyMissingError(String missingProperty)
    • outOfMemoryError

      public static OutOfMemoryError outOfMemoryError(long requestedBytes, long receivedBytes)
    • failedRenameTempFileError

      public static Throwable failedRenameTempFileError(File srcFile, File dstFile)
    • addLocalDirectoryError

      public static Throwable addLocalDirectoryError(org.apache.hadoop.fs.Path path)
    • addDirectoryError

      public static Throwable addDirectoryError(org.apache.hadoop.fs.Path path)
    • toConf

      public static String toConf(String conf)
    • toConfVal

      public static String toConfVal(String conf)