Uses of Class
org.apache.flink.runtime.checkpoint.CheckpointException
-
-
Uses of CheckpointException in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return CheckpointException Modifier and Type Method Description CheckpointException
PendingCheckpoint. getFailureCause()
Methods in org.apache.flink.runtime.checkpoint with parameters of type CheckpointException Modifier and Type Method Description void
CheckpointCoordinator. abortPendingCheckpoints(CheckpointException exception)
Aborts all the pending checkpoints due to en exception.void
CheckpointFailureManager. checkFailureCounter(CheckpointException exception, long checkpointId)
void
CheckpointFailureManager. handleCheckpointException(PendingCheckpoint pendingCheckpoint, CheckpointProperties checkpointProperties, CheckpointException exception, ExecutionAttemptID executionAttemptID, JobID job, PendingCheckpointStats pendingCheckpointStats, CheckpointStatsTracker statsTracker)
Failures on JM: all checkpoints - go against failure counter.Methods in org.apache.flink.runtime.checkpoint that throw CheckpointException Modifier and Type Method Description boolean
CheckpointCoordinator. receiveAcknowledgeMessage(AcknowledgeCheckpoint message, String taskManagerLocationInfo)
Receives an AcknowledgeCheckpoint message and returns whether the message was associated with a pending checkpoint. -
Uses of CheckpointException in org.apache.flink.runtime.execution
Methods in org.apache.flink.runtime.execution with parameters of type CheckpointException Modifier and Type Method Description void
Environment. declineCheckpoint(long checkpointId, CheckpointException checkpointException)
Declines a checkpoint. -
Uses of CheckpointException in org.apache.flink.runtime.io.network.api.writer
Methods in org.apache.flink.runtime.io.network.api.writer with parameters of type CheckpointException Modifier and Type Method Description void
RecordWriter. abortCheckpoint(long checkpointId, CheckpointException cause)
void
ResultPartitionWriter. abortCheckpoint(long checkpointId, CheckpointException cause)
Abort the checkpoint. -
Uses of CheckpointException in org.apache.flink.runtime.io.network.partition
Methods in org.apache.flink.runtime.io.network.partition with parameters of type CheckpointException Modifier and Type Method Description void
BufferWritingResultPartition. abortCheckpoint(long checkpointId, CheckpointException cause)
void
PipelinedSubpartition. abortCheckpoint(long checkpointId, CheckpointException cause)
abstract void
ResultSubpartition. abortCheckpoint(long checkpointId, CheckpointException cause)
void
SortMergeResultPartition. abortCheckpoint(long checkpointId, CheckpointException cause)
-
Uses of CheckpointException in org.apache.flink.runtime.io.network.partition.consumer
Methods in org.apache.flink.runtime.io.network.partition.consumer that throw CheckpointException Modifier and Type Method Description void
CheckpointableInput. checkpointStarted(CheckpointBarrier barrier)
void
IndexedInputGate. checkpointStarted(CheckpointBarrier barrier)
void
InputChannel. checkpointStarted(CheckpointBarrier barrier)
Called by task thread when checkpointing is started (e.g., any input channel received barrier).void
LocalInputChannel. checkpointStarted(CheckpointBarrier barrier)
void
RecoveredInputChannel. checkpointStarted(CheckpointBarrier barrier)
void
RemoteInputChannel. checkpointStarted(CheckpointBarrier barrier)
Spills all queued buffers on checkpoint start.protected void
ChannelStatePersister. startPersisting(long barrierId, List<Buffer> knownBuffers)
-
Uses of CheckpointException in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle
Methods in org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle with parameters of type CheckpointException Modifier and Type Method Description void
TieredResultPartition. abortCheckpoint(long checkpointId, CheckpointException cause)
-
Uses of CheckpointException in org.apache.flink.runtime.jobgraph.tasks
Methods in org.apache.flink.runtime.jobgraph.tasks with parameters of type CheckpointException Modifier and Type Method Description void
AbstractInvokable. abortCheckpointOnBarrier(long checkpointId, CheckpointException cause)
void
CheckpointableTask. abortCheckpointOnBarrier(long checkpointId, CheckpointException cause)
Aborts a checkpoint as the result of receiving possibly some checkpoint barriers, but at least oneCancelCheckpointMarker
. -
Uses of CheckpointException in org.apache.flink.runtime.messages.checkpoint
Methods in org.apache.flink.runtime.messages.checkpoint that return CheckpointException Modifier and Type Method Description CheckpointException
SerializedCheckpointException. unwrap()
Constructors in org.apache.flink.runtime.messages.checkpoint with parameters of type CheckpointException Constructor Description DeclineCheckpoint(JobID job, ExecutionAttemptID taskExecutionId, long checkpointId, CheckpointException checkpointException)
SerializedCheckpointException(CheckpointException checkpointException)
-
Uses of CheckpointException in org.apache.flink.runtime.taskexecutor.rpc
Methods in org.apache.flink.runtime.taskexecutor.rpc with parameters of type CheckpointException Modifier and Type Method Description void
RpcCheckpointResponder. declineCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointException checkpointException)
-
Uses of CheckpointException in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager with parameters of type CheckpointException Modifier and Type Method Description void
CheckpointResponder. declineCheckpoint(JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointException checkpointException)
Declines the given checkpoint.void
RuntimeEnvironment. declineCheckpoint(long checkpointId, CheckpointException checkpointException)
-
Uses of CheckpointException in org.apache.flink.state.api.runtime
Methods in org.apache.flink.state.api.runtime with parameters of type CheckpointException Modifier and Type Method Description void
SavepointEnvironment. declineCheckpoint(long checkpointId, CheckpointException checkpointException)
-
Uses of CheckpointException in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that throw CheckpointException Modifier and Type Method Description OperatorSnapshotFutures
StreamOperatorStateHandler. snapshotState(StreamOperatorStateHandler.CheckpointedStreamOperator streamOperator, Optional<InternalTimeServiceManager<?>> timeServiceManager, String operatorName, long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory factory, boolean isUsingCustomRawKeyedState, boolean useAsyncState)
-
Uses of CheckpointException in org.apache.flink.streaming.api.operators.sort
Methods in org.apache.flink.streaming.api.operators.sort that throw CheckpointException Modifier and Type Method Description CompletableFuture<Void>
SortingDataInput. prepareSnapshot(ChannelStateWriter channelStateWriter, long checkpointId)
-
Uses of CheckpointException in org.apache.flink.streaming.runtime.io
Methods in org.apache.flink.streaming.runtime.io with parameters of type CheckpointException Modifier and Type Method Description void
RecordWriterOutput. abortCheckpoint(long checkpointId, CheckpointException cause)
Methods in org.apache.flink.streaming.runtime.io that throw CheckpointException Modifier and Type Method Description CompletableFuture<Void>
StreamInputProcessor. prepareSnapshot(ChannelStateWriter channelStateWriter, long checkpointId)
CompletableFuture<Void>
StreamMultipleInputProcessor. prepareSnapshot(ChannelStateWriter channelStateWriter, long checkpointId)
CompletableFuture<Void>
StreamOneInputProcessor. prepareSnapshot(ChannelStateWriter channelStateWriter, long checkpointId)
CompletableFuture<Void>
StreamTaskInput. prepareSnapshot(ChannelStateWriter channelStateWriter, long checkpointId)
Prepares to spill the in-flight input buffers as checkpoint snapshot.CompletableFuture<Void>
StreamTaskNetworkInput. prepareSnapshot(ChannelStateWriter channelStateWriter, long checkpointId)
CompletableFuture<Void>
StreamTaskSourceInput. prepareSnapshot(ChannelStateWriter channelStateWriter, long checkpointId)
-
Uses of CheckpointException in org.apache.flink.streaming.runtime.io.checkpointing
Methods in org.apache.flink.streaming.runtime.io.checkpointing with parameters of type CheckpointException Modifier and Type Method Description protected void
CheckpointBarrierHandler. notifyAbort(long checkpointId, CheckpointException cause)
-
Uses of CheckpointException in org.apache.flink.streaming.runtime.io.recovery
Methods in org.apache.flink.streaming.runtime.io.recovery that throw CheckpointException Modifier and Type Method Description CompletableFuture<Void>
RescalingStreamTaskNetworkInput. prepareSnapshot(ChannelStateWriter channelStateWriter, long checkpointId)
-
Uses of CheckpointException in org.apache.flink.streaming.runtime.tasks
Methods in org.apache.flink.streaming.runtime.tasks with parameters of type CheckpointException Modifier and Type Method Description void
OperatorChain. abortCheckpoint(long checkpointId, CheckpointException cause)
void
MultipleInputStreamTask. abortCheckpointOnBarrier(long checkpointId, CheckpointException cause)
void
StreamTask. abortCheckpointOnBarrier(long checkpointId, CheckpointException cause)
void
SubtaskCheckpointCoordinator. abortCheckpointOnBarrier(long checkpointId, CheckpointException cause, OperatorChain<?,?> operatorChain)
Methods in org.apache.flink.streaming.runtime.tasks that throw CheckpointException Modifier and Type Method Description void
SubtaskCheckpointCoordinator. initInputsCheckpoint(long id, CheckpointOptions checkpointOptions)
Initialize new checkpoint.
-