public class SparkCoreErrors
extends Object
Constructor and Description |
---|
SparkCoreErrors() |
Modifier and Type | Method and Description |
---|---|
static Throwable |
accessNonExistentAccumulatorError(long id) |
static Throwable |
askStandaloneSchedulerToShutDownExecutorsError(Exception e) |
static Throwable |
barrierStageWithDynamicAllocationError() |
static Throwable |
barrierStageWithRDDChainPatternError() |
static Throwable |
blockDoesNotExistError(BlockId blockId) |
static Throwable |
blockHaveBeenRemovedError(String string) |
static Throwable |
blockNotFoundError(BlockId blockId) |
static Throwable |
blockStatusQueryReturnedNullError(BlockId blockId) |
static Throwable |
cannotChangeStorageLevelError() |
static Throwable |
cannotRunSubmitMapStageOnZeroPartitionRDDError() |
static Throwable |
cannotSaveBlockOnDecommissionedExecutorError(BlockId blockId) |
static Throwable |
cannotUseMapSideCombiningWithArrayKeyError() |
static Throwable |
canOnlyZipRDDsWithSamePartitionSizeError() |
static Throwable |
checkpointDirectoryHasNotBeenSetInSparkContextError() |
static Throwable |
checkpointFailedToSaveError(int task,
org.apache.hadoop.fs.Path path) |
static Throwable |
checkpointRDDBlockIdNotFoundError(RDDBlockId rddBlockId) |
static Throwable |
checkpointRDDHasDifferentNumberOfPartitionsFromOriginalRDDError(int originalRDDId,
int originalRDDLength,
int newRDDId,
int newRDDLength) |
static Throwable |
clusterSchedulerError(String message) |
static Throwable |
countByValueApproxNotSupportArraysError() |
static Throwable |
durationCalledOnUnfinishedTaskError() |
static Throwable |
emptyCollectionError() |
static Throwable |
emptyRDDError() |
static Throwable |
endOfStreamError() |
static Throwable |
eofExceptionWhileReadPortNumberError(String daemonModule,
scala.Option<Object> daemonExitValue) |
static Throwable |
failToCreateCheckpointPathError(org.apache.hadoop.fs.Path checkpointDirPath) |
static Throwable |
failToCreateDirectoryError(String path,
int maxAttempts) |
static Throwable |
failToGetBlockWithLockError(BlockId blockId) |
static Throwable |
failToGetNonShuffleBlockError(BlockId blockId,
Throwable e) |
static Throwable |
failToSerializeTaskError(Throwable e) |
static Throwable |
failToStoreBlockOnBlockManagerError(BlockManagerId blockManagerId,
BlockId blockId) |
static Throwable |
fetchFailedError(BlockManagerId bmAddress,
int shuffleId,
long mapId,
int mapIndex,
int reduceId,
String message,
Throwable cause) |
static Throwable |
graphiteSinkInvalidProtocolError(String invalidProtocol) |
static Throwable |
graphiteSinkPropertyMissingError(String missingProperty) |
static Throwable |
hashPartitionerCannotPartitionArrayKeyError() |
static Throwable |
histogramOnEmptyRDDOrContainingInfinityOrNaNError() |
static Throwable |
interruptedError() |
static Throwable |
invalidCheckpointFileError(org.apache.hadoop.fs.Path path) |
static Throwable |
mustSpecifyCheckpointDirError() |
static Throwable |
noExecutorIdleError(String id) |
static Throwable |
nonEmptyEventQueueAfterTimeoutError(long timeoutMillis) |
static Throwable |
noSuchElementError() |
static Throwable |
numPartitionsGreaterThanMaxNumConcurrentTasksError(int numPartitions,
int maxNumConcurrentTasks) |
static OutOfMemoryError |
outOfMemoryError(long requestedBytes,
long receivedBytes) |
static Throwable |
pathNotSupportedError(String path) |
static Throwable |
rddBlockNotFoundError(BlockId blockId,
int id) |
static Throwable |
rddLacksSparkContextError() |
static Throwable |
readLockedBlockNotFoundError(BlockId blockId) |
static Throwable |
reduceByKeyLocallyNotSupportArrayKeysError() |
static Throwable |
sendResubmittedTaskStatusForShuffleMapStagesOnlyError() |
static Throwable |
sparkError(String errorMsg) |
static Throwable |
stopStandaloneSchedulerDriverEndpointError(Exception e) |
static Throwable |
taskHasNotLockedBlockError(long currentTaskAttemptId,
BlockId blockId) |
static Throwable |
unableToRegisterWithExternalShuffleServerError(Throwable e) |
static Throwable |
unexpectedBlockManagerMasterEndpointResultError() |
static Throwable |
unexpectedPy4JServerError(Object other) |
static Throwable |
unexpectedShuffleBlockWithUnsupportedResolverError(org.apache.spark.shuffle.ShuffleManager shuffleManager,
BlockId blockId) |
static Throwable |
unrecognizedBlockIdError(String name) |
static Throwable |
unrecognizedSchedulerModePropertyError(String schedulerModeProperty,
String schedulingModeConf) |
static Throwable |
unsupportedDataTypeError(Object other) |
static Throwable |
unsupportedOperationError() |
static Throwable |
waitingForAsyncReregistrationError(Throwable e) |
static Throwable |
waitingForReplicationToFinishError(Throwable e) |
public static Throwable unexpectedPy4JServerError(Object other)
public static Throwable eofExceptionWhileReadPortNumberError(String daemonModule, scala.Option<Object> daemonExitValue)
public static Throwable unsupportedDataTypeError(Object other)
public static Throwable rddBlockNotFoundError(BlockId blockId, int id)
public static Throwable blockHaveBeenRemovedError(String string)
public static Throwable histogramOnEmptyRDDOrContainingInfinityOrNaNError()
public static Throwable emptyRDDError()
public static Throwable pathNotSupportedError(String path)
public static Throwable checkpointRDDBlockIdNotFoundError(RDDBlockId rddBlockId)
public static Throwable endOfStreamError()
public static Throwable cannotUseMapSideCombiningWithArrayKeyError()
public static Throwable hashPartitionerCannotPartitionArrayKeyError()
public static Throwable reduceByKeyLocallyNotSupportArrayKeysError()
public static Throwable rddLacksSparkContextError()
public static Throwable cannotChangeStorageLevelError()
public static Throwable canOnlyZipRDDsWithSamePartitionSizeError()
public static Throwable emptyCollectionError()
public static Throwable countByValueApproxNotSupportArraysError()
public static Throwable checkpointDirectoryHasNotBeenSetInSparkContextError()
public static Throwable invalidCheckpointFileError(org.apache.hadoop.fs.Path path)
public static Throwable failToCreateCheckpointPathError(org.apache.hadoop.fs.Path checkpointDirPath)
public static Throwable checkpointRDDHasDifferentNumberOfPartitionsFromOriginalRDDError(int originalRDDId, int originalRDDLength, int newRDDId, int newRDDLength)
public static Throwable checkpointFailedToSaveError(int task, org.apache.hadoop.fs.Path path)
public static Throwable mustSpecifyCheckpointDirError()
public static Throwable askStandaloneSchedulerToShutDownExecutorsError(Exception e)
public static Throwable stopStandaloneSchedulerDriverEndpointError(Exception e)
public static Throwable noExecutorIdleError(String id)
public static Throwable barrierStageWithRDDChainPatternError()
public static Throwable barrierStageWithDynamicAllocationError()
public static Throwable numPartitionsGreaterThanMaxNumConcurrentTasksError(int numPartitions, int maxNumConcurrentTasks)
public static Throwable cannotRunSubmitMapStageOnZeroPartitionRDDError()
public static Throwable accessNonExistentAccumulatorError(long id)
public static Throwable sendResubmittedTaskStatusForShuffleMapStagesOnlyError()
public static Throwable nonEmptyEventQueueAfterTimeoutError(long timeoutMillis)
public static Throwable durationCalledOnUnfinishedTaskError()
public static Throwable unrecognizedSchedulerModePropertyError(String schedulerModeProperty, String schedulingModeConf)
public static Throwable sparkError(String errorMsg)
public static Throwable clusterSchedulerError(String message)
public static Throwable failToSerializeTaskError(Throwable e)
public static Throwable unrecognizedBlockIdError(String name)
public static Throwable taskHasNotLockedBlockError(long currentTaskAttemptId, BlockId blockId)
public static Throwable blockDoesNotExistError(BlockId blockId)
public static Throwable cannotSaveBlockOnDecommissionedExecutorError(BlockId blockId)
public static Throwable waitingForReplicationToFinishError(Throwable e)
public static Throwable unableToRegisterWithExternalShuffleServerError(Throwable e)
public static Throwable waitingForAsyncReregistrationError(Throwable e)
public static Throwable unexpectedShuffleBlockWithUnsupportedResolverError(org.apache.spark.shuffle.ShuffleManager shuffleManager, BlockId blockId)
public static Throwable failToStoreBlockOnBlockManagerError(BlockManagerId blockManagerId, BlockId blockId)
public static Throwable readLockedBlockNotFoundError(BlockId blockId)
public static Throwable failToGetBlockWithLockError(BlockId blockId)
public static Throwable blockNotFoundError(BlockId blockId)
public static Throwable interruptedError()
public static Throwable blockStatusQueryReturnedNullError(BlockId blockId)
public static Throwable unexpectedBlockManagerMasterEndpointResultError()
public static Throwable failToCreateDirectoryError(String path, int maxAttempts)
public static Throwable unsupportedOperationError()
public static Throwable noSuchElementError()
public static Throwable fetchFailedError(BlockManagerId bmAddress, int shuffleId, long mapId, int mapIndex, int reduceId, String message, Throwable cause)
public static Throwable failToGetNonShuffleBlockError(BlockId blockId, Throwable e)
public static Throwable graphiteSinkInvalidProtocolError(String invalidProtocol)
public static Throwable graphiteSinkPropertyMissingError(String missingProperty)
public static OutOfMemoryError outOfMemoryError(long requestedBytes, long receivedBytes)