@Internal public interface SubtaskCheckpointCoordinator extends Closeable
Task
and StreamTask
). Responsibilities:
Modifier and Type | Method and Description |
---|---|
void |
abortCheckpointOnBarrier(long checkpointId,
CheckpointException cause,
OperatorChain<?,?> operatorChain) |
void |
cancel()
Cancel all resources.
|
void |
checkpointState(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions,
CheckpointMetricsBuilder checkpointMetrics,
OperatorChain<?,?> operatorChain,
boolean isTaskFinished,
java.util.function.Supplier<Boolean> isRunning)
Must be called after
initInputsCheckpoint(long, CheckpointOptions) . |
ChannelStateWriter |
getChannelStateWriter() |
CheckpointStorageWorkerView |
getCheckpointStorage() |
void |
initInputsCheckpoint(long id,
CheckpointOptions checkpointOptions)
Initialize new checkpoint.
|
void |
notifyCheckpointAborted(long checkpointId,
OperatorChain<?,?> operatorChain,
java.util.function.Supplier<Boolean> isRunning)
Notified on the task side once a distributed checkpoint has been aborted.
|
void |
notifyCheckpointComplete(long checkpointId,
OperatorChain<?,?> operatorChain,
java.util.function.Supplier<Boolean> isRunning)
Notified on the task side once a distributed checkpoint has been completed.
|
void |
notifyCheckpointSubsumed(long checkpointId,
OperatorChain<?,?> operatorChain,
java.util.function.Supplier<Boolean> isRunning)
Notified on the task side once a distributed checkpoint has been subsumed.
|
void |
waitForPendingCheckpoints()
Waits for all the pending checkpoints to finish their asynchronous step.
|
void initInputsCheckpoint(long id, CheckpointOptions checkpointOptions) throws CheckpointException
CheckpointException
ChannelStateWriter getChannelStateWriter()
CheckpointStorageWorkerView getCheckpointStorage()
void abortCheckpointOnBarrier(long checkpointId, CheckpointException cause, OperatorChain<?,?> operatorChain) throws IOException
IOException
void checkpointState(CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions, CheckpointMetricsBuilder checkpointMetrics, OperatorChain<?,?> operatorChain, boolean isTaskFinished, java.util.function.Supplier<Boolean> isRunning) throws Exception
initInputsCheckpoint(long, CheckpointOptions)
.Exception
void notifyCheckpointComplete(long checkpointId, OperatorChain<?,?> operatorChain, java.util.function.Supplier<Boolean> isRunning) throws Exception
checkpointId
- The checkpoint id to notify as been completed.operatorChain
- The chain of operators executed by the task.isRunning
- Whether the task is running.Exception
void notifyCheckpointAborted(long checkpointId, OperatorChain<?,?> operatorChain, java.util.function.Supplier<Boolean> isRunning) throws Exception
checkpointId
- The checkpoint id to notify as been completed.operatorChain
- The chain of operators executed by the task.isRunning
- Whether the task is running.Exception
void notifyCheckpointSubsumed(long checkpointId, OperatorChain<?,?> operatorChain, java.util.function.Supplier<Boolean> isRunning) throws Exception
checkpointId
- The checkpoint id to notify as been subsumed.operatorChain
- The chain of operators executed by the task.isRunning
- Whether the task is running.Exception
void waitForPendingCheckpoints() throws Exception
Exception
void cancel() throws IOException
IOException
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.