Uses of Class
org.apache.flink.runtime.checkpoint.CheckpointException
-
Packages that use CheckpointException Package Description org.apache.flink.runtime.checkpoint org.apache.flink.runtime.execution org.apache.flink.runtime.io.network.api.writer org.apache.flink.runtime.io.network.partition org.apache.flink.runtime.io.network.partition.consumer org.apache.flink.runtime.io.network.partition.hybrid.tiered.shuffle org.apache.flink.runtime.jobgraph.tasks org.apache.flink.runtime.messages.checkpoint This package contains the messages that are sent betweenJobMasterandTaskExecutorto coordinate the checkpoint snapshots of the distributed dataflow.org.apache.flink.runtime.taskexecutor.rpc org.apache.flink.runtime.taskmanager org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sort org.apache.flink.streaming.runtime.io org.apache.flink.streaming.runtime.io.checkpointing org.apache.flink.streaming.runtime.io.recovery org.apache.flink.streaming.runtime.tasks -
-
Uses of CheckpointException in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return CheckpointException Modifier and Type Method Description CheckpointExceptionPendingCheckpoint. getFailureCause()Methods in org.apache.flink.runtime.checkpoint with parameters of type CheckpointException Modifier and Type Method Description voidCheckpointCoordinator. abortPendingCheckpoints(CheckpointException exception)Aborts all the pending checkpoints due to en exception.voidCheckpointFailureManager. checkFailureCounter(CheckpointException exception, long checkpointId)voidCheckpointFailureManager. handleCheckpointException(PendingCheckpoint pendingCheckpoint, CheckpointProperties checkpointProperties, CheckpointException exception, ExecutionAttemptID executionAttemptID, org.apache.flink.api.common.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 booleanCheckpointCoordinator. 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 voidEnvironment. 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 voidRecordWriter. abortCheckpoint(long checkpointId, CheckpointException cause)voidResultPartitionWriter. 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 voidBufferWritingResultPartition. abortCheckpoint(long checkpointId, CheckpointException cause)voidPipelinedSubpartition. abortCheckpoint(long checkpointId, CheckpointException cause)abstract voidResultSubpartition. abortCheckpoint(long checkpointId, CheckpointException cause)voidSortMergeResultPartition. 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 voidCheckpointableInput. checkpointStarted(CheckpointBarrier barrier)voidIndexedInputGate. checkpointStarted(CheckpointBarrier barrier)voidInputChannel. checkpointStarted(CheckpointBarrier barrier)Called by task thread when checkpointing is started (e.g., any input channel received barrier).voidLocalInputChannel. checkpointStarted(CheckpointBarrier barrier)voidRecoveredInputChannel. checkpointStarted(CheckpointBarrier barrier)voidRemoteInputChannel. checkpointStarted(CheckpointBarrier barrier)Spills all queued buffers on checkpoint start.protected voidChannelStatePersister. 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 voidTieredResultPartition. 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 voidAbstractInvokable. abortCheckpointOnBarrier(long checkpointId, CheckpointException cause)voidCheckpointableTask. 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 CheckpointExceptionSerializedCheckpointException. unwrap()Constructors in org.apache.flink.runtime.messages.checkpoint with parameters of type CheckpointException Constructor Description DeclineCheckpoint(org.apache.flink.api.common.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 voidRpcCheckpointResponder. declineCheckpoint(org.apache.flink.api.common.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 voidCheckpointResponder. declineCheckpoint(org.apache.flink.api.common.JobID jobID, ExecutionAttemptID executionAttemptID, long checkpointId, CheckpointException checkpointException)Declines the given checkpoint.voidRuntimeEnvironment. 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 OperatorSnapshotFuturesStreamOperatorStateHandler. 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 voidRecordWriterOutput. 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 voidCheckpointBarrierHandler. 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 voidOperatorChain. abortCheckpoint(long checkpointId, CheckpointException cause)voidMultipleInputStreamTask. abortCheckpointOnBarrier(long checkpointId, CheckpointException cause)voidStreamTask. abortCheckpointOnBarrier(long checkpointId, CheckpointException cause)voidSubtaskCheckpointCoordinator. abortCheckpointOnBarrier(long checkpointId, CheckpointException cause, OperatorChain<?,?> operatorChain)Methods in org.apache.flink.streaming.runtime.tasks that throw CheckpointException Modifier and Type Method Description voidSubtaskCheckpointCoordinator. initInputsCheckpoint(long id, CheckpointOptions checkpointOptions)Initialize new checkpoint.
-