Uses of Class
org.apache.flink.runtime.checkpoint.CheckpointOptions
-
-
Uses of CheckpointOptions in org.apache.flink.contrib.streaming.state
Methods in org.apache.flink.contrib.streaming.state with parameters of type CheckpointOptions Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
RocksDBKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
Triggers an asynchronous snapshot of the keyed state backend from RocksDB. -
Uses of CheckpointOptions in org.apache.flink.contrib.streaming.state.snapshot
Methods in org.apache.flink.contrib.streaming.state.snapshot with parameters of type CheckpointOptions Modifier and Type Method Description SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle>
RocksIncrementalSnapshotStrategy. asyncSnapshot(RocksDBSnapshotStrategyBase.NativeRocksDBSnapshotResources snapshotResources, long checkpointId, long timestamp, CheckpointStreamFactory checkpointStreamFactory, CheckpointOptions checkpointOptions)
SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle>
RocksNativeFullSnapshotStrategy. asyncSnapshot(RocksDBSnapshotStrategyBase.NativeRocksDBSnapshotResources snapshotResources, long checkpointId, long timestamp, CheckpointStreamFactory checkpointStreamFactory, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.runtime.asyncprocessing.operators
Methods in org.apache.flink.runtime.asyncprocessing.operators with parameters of type CheckpointOptions Modifier and Type Method Description OperatorSnapshotFutures
AbstractAsyncStateStreamOperator. snapshotState(long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory factory)
OperatorSnapshotFutures
AbstractAsyncStateStreamOperatorV2. snapshotState(long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory factory)
-
Uses of CheckpointOptions in org.apache.flink.runtime.checkpoint
-
Uses of CheckpointOptions in org.apache.flink.runtime.checkpoint.channel
Methods in org.apache.flink.runtime.checkpoint.channel with parameters of type CheckpointOptions Modifier and Type Method Description void
ChannelStateWriter.NoOpChannelStateWriter. start(long checkpointId, CheckpointOptions checkpointOptions)
void
ChannelStateWriter. start(long checkpointId, CheckpointOptions checkpointOptions)
Initiate write of channel state for the given checkpoint id.void
ChannelStateWriterImpl. start(long checkpointId, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph with parameters of type CheckpointOptions Modifier and Type Method Description CompletableFuture<Acknowledge>
Execution. triggerCheckpoint(long checkpointId, long timestamp, CheckpointOptions checkpointOptions)
Trigger a new checkpoint on the task of this execution.CompletableFuture<Acknowledge>
Execution. triggerSynchronousSavepoint(long checkpointId, long timestamp, CheckpointOptions checkpointOptions)
Trigger a new checkpoint on the task of this execution. -
Uses of CheckpointOptions in org.apache.flink.runtime.io.network.api
Methods in org.apache.flink.runtime.io.network.api that return CheckpointOptions Modifier and Type Method Description CheckpointOptions
CheckpointBarrier. getCheckpointOptions()
Methods in org.apache.flink.runtime.io.network.api with parameters of type CheckpointOptions Modifier and Type Method Description CheckpointBarrier
CheckpointBarrier. withOptions(CheckpointOptions checkpointOptions)
Constructors in org.apache.flink.runtime.io.network.api with parameters of type CheckpointOptions Constructor Description CheckpointBarrier(long id, long timestamp, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.runtime.jobgraph.tasks
Methods in org.apache.flink.runtime.jobgraph.tasks with parameters of type CheckpointOptions Modifier and Type Method Description CompletableFuture<Boolean>
AbstractInvokable. triggerCheckpointAsync(CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions)
CompletableFuture<Boolean>
CheckpointableTask. triggerCheckpointAsync(CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions)
This method is called to trigger a checkpoint, asynchronously by the checkpoint coordinator.void
AbstractInvokable. triggerCheckpointOnBarrier(CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions, CheckpointMetricsBuilder checkpointMetrics)
void
CheckpointableTask. triggerCheckpointOnBarrier(CheckpointMetaData checkpointMetaData, CheckpointOptions checkpointOptions, CheckpointMetricsBuilder checkpointMetrics)
This method is called when a checkpoint is triggered as a result of receiving checkpoint barriers on all input streams. -
Uses of CheckpointOptions in org.apache.flink.runtime.jobmanager.slots
Methods in org.apache.flink.runtime.jobmanager.slots with parameters of type CheckpointOptions Modifier and Type Method Description CompletableFuture<Acknowledge>
TaskManagerGateway. triggerCheckpoint(ExecutionAttemptID executionAttemptID, JobID jobId, long checkpointId, long timestamp, CheckpointOptions checkpointOptions)
Trigger for the given task a checkpoint. -
Uses of CheckpointOptions in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster with parameters of type CheckpointOptions Modifier and Type Method Description CompletableFuture<Acknowledge>
RpcTaskManagerGateway. triggerCheckpoint(ExecutionAttemptID executionAttemptID, JobID jobId, long checkpointId, long timestamp, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with parameters of type CheckpointOptions Modifier and Type Method Description SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle>
SavepointSnapshotStrategy. asyncSnapshot(FullSnapshotResources<K> savepointResources, long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
SnapshotStrategy.SnapshotResultSupplier<S>
SnapshotStrategy. asyncSnapshot(SR syncPartResource, long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
Operation that writes a snapshot into a stream that is provided by the givenCheckpointStreamFactory
and returns a @SupplierWithException
that gives a state handle to the snapshot.RunnableFuture<SnapshotResult<OperatorStateHandle>>
DefaultOperatorStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
RunnableFuture<S>
Snapshotable. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
Operation that writes a snapshot into a stream that is provided by the givenCheckpointStreamFactory
and returns a @RunnableFuture
that gives a state handle to the snapshot.RunnableFuture<SnapshotResult<T>>
SnapshotStrategyRunner. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.runtime.state.heap
Methods in org.apache.flink.runtime.state.heap with parameters of type CheckpointOptions Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
HeapKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.runtime.state.v2.adaptor
Methods in org.apache.flink.runtime.state.v2.adaptor with parameters of type CheckpointOptions Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
AsyncKeyedStateBackendAdaptor. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.runtime.taskexecutor
Methods in org.apache.flink.runtime.taskexecutor with parameters of type CheckpointOptions Modifier and Type Method Description CompletableFuture<Acknowledge>
TaskExecutor. triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointId, long checkpointTimestamp, CheckpointOptions checkpointOptions)
CompletableFuture<Acknowledge>
TaskExecutorGateway. triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointID, long checkpointTimestamp, CheckpointOptions checkpointOptions)
Trigger the checkpoint for the given task.CompletableFuture<Acknowledge>
TaskExecutorGatewayDecoratorBase. triggerCheckpoint(ExecutionAttemptID executionAttemptID, long checkpointID, long checkpointTimestamp, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.runtime.taskmanager
Methods in org.apache.flink.runtime.taskmanager with parameters of type CheckpointOptions Modifier and Type Method Description void
Task. triggerCheckpointBarrier(long checkpointID, long checkpointTimestamp, CheckpointOptions checkpointOptions)
Calls the invokable to trigger a checkpoint. -
Uses of CheckpointOptions in org.apache.flink.state.api.output.operators
Methods in org.apache.flink.state.api.output.operators with parameters of type CheckpointOptions Modifier and Type Method Description OperatorSnapshotFutures
StateBootstrapWrapperOperator. snapshotState(long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory storageLocation)
-
Uses of CheckpointOptions in org.apache.flink.state.changelog
Methods in org.apache.flink.state.changelog with parameters of type CheckpointOptions Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
ChangelogKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.state.forst
Methods in org.apache.flink.state.forst with parameters of type CheckpointOptions Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
ForStKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.state.forst.snapshot
Methods in org.apache.flink.state.forst.snapshot with parameters of type CheckpointOptions Modifier and Type Method Description SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle>
ForStIncrementalSnapshotStrategy. asyncSnapshot(ForStSnapshotStrategyBase.ForStNativeSnapshotResources snapshotResources, long checkpointId, long timestamp, CheckpointStreamFactory checkpointStreamFactory, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.state.forst.sync
Methods in org.apache.flink.state.forst.sync with parameters of type CheckpointOptions Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
ForStSyncKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
Triggers an asynchronous snapshot of the keyed state backend from RocksDB. -
Uses of CheckpointOptions in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators with parameters of type CheckpointOptions Modifier and Type Method Description OperatorSnapshotFutures
AbstractStreamOperator. snapshotState(long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory factory)
OperatorSnapshotFutures
AbstractStreamOperatorV2. snapshotState(long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory factory)
OperatorSnapshotFutures
StreamOperator. snapshotState(long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory storageLocation)
Called to draw a state snapshot from the operator.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 CheckpointOptions in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state with parameters of type CheckpointOptions Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
BatchExecutionKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-
Uses of CheckpointOptions in org.apache.flink.streaming.runtime.tasks
-