Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.contrib.streaming.state.snapshot | |
org.apache.flink.runtime.checkpoint | |
org.apache.flink.runtime.checkpoint.channel | |
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.io.network.api | |
org.apache.flink.runtime.jobgraph.tasks | |
org.apache.flink.runtime.jobmanager.slots | |
org.apache.flink.runtime.jobmaster | |
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.heap |
This package contains the classes for key/value state backends that store the state on the JVM
heap as objects.
|
org.apache.flink.runtime.taskexecutor | |
org.apache.flink.runtime.taskmanager | |
org.apache.flink.state.api.output.operators | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
RocksFullSnapshotStrategy.doSnapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory primaryStreamFactory,
CheckpointOptions checkpointOptions) |
protected RunnableFuture<SnapshotResult<KeyedStateHandle>> |
RocksIncrementalSnapshotStrategy.doSnapshot(long checkpointId,
long checkpointTimestamp,
CheckpointStreamFactory checkpointStreamFactory,
CheckpointOptions checkpointOptions) |
protected abstract RunnableFuture<SnapshotResult<KeyedStateHandle>> |
RocksDBSnapshotStrategyBase.doSnapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions)
This method implements the concrete snapshot logic for a non-empty state.
|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
RocksDBSnapshotStrategyBase.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
void |
ChannelStateWriterImpl.start(long checkpointId,
CheckpointOptions checkpointOptions) |
void |
ChannelStateWriter.start(long checkpointId,
CheckpointOptions checkpointOptions)
Initiate write of channel state for the given checkpoint id.
|
void |
ChannelStateWriter.NoOpChannelStateWriter.start(long checkpointId,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
void |
Execution.triggerCheckpoint(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions)
Trigger a new checkpoint on the task of this execution.
|
void |
Execution.triggerSynchronousSavepoint(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions)
Trigger a new checkpoint on the task of this execution.
|
Modifier and Type | Method and Description |
---|---|
CheckpointOptions |
CheckpointBarrier.getCheckpointOptions() |
Modifier and Type | Method and Description |
---|---|
CheckpointBarrier |
CheckpointBarrier.withOptions(CheckpointOptions checkpointOptions) |
Constructor and Description |
---|
CheckpointBarrier(long id,
long timestamp,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
Future<Boolean> |
AbstractInvokable.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)
This method is called when a checkpoint is triggered as a result of receiving checkpoint
barriers on all input streams.
|
Modifier and Type | Method and Description |
---|---|
void |
TaskManagerGateway.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions)
Trigger for the given task a checkpoint.
|
Modifier and Type | Method and Description |
---|---|
void |
RpcTaskManagerGateway.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<S> |
SnapshotStrategy.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions)
Operation that writes a snapshot into a stream that is provided by the given
CheckpointStreamFactory and returns a @RunnableFuture that gives a state handle to
the snapshot. |
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
DefaultOperatorStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
HeapKeyedStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
TaskExecutor.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
long checkpointId,
long checkpointTimestamp,
CheckpointOptions checkpointOptions) |
CompletableFuture<Acknowledge> |
TaskExecutorGatewayDecoratorBase.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.
|
Modifier and Type | Method and Description |
---|---|
void |
Task.triggerCheckpointBarrier(long checkpointID,
long checkpointTimestamp,
CheckpointOptions checkpointOptions)
Calls the invokable to trigger a checkpoint.
|
Modifier and Type | Method and Description |
---|---|
OperatorSnapshotFutures |
StateBootstrapWrapperOperator.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory storageLocation) |
Modifier and Type | Method and Description |
---|---|
OperatorSnapshotFutures |
StreamOperator.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory storageLocation)
Called to draw a state snapshot from the operator.
|
OperatorSnapshotFutures |
AbstractStreamOperator.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory) |
OperatorSnapshotFutures |
AbstractStreamOperatorV2.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory) |
OperatorSnapshotFutures |
StreamOperatorStateHandler.snapshotState(StreamOperatorStateHandler.CheckpointedStreamOperator streamOperator,
Optional<InternalTimeServiceManager<?>> timeServiceManager,
String operatorName,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory,
boolean isUsingCustomRawKeyedState) |
Modifier and Type | Method and Description |
---|---|
void |
SubtaskCheckpointCoordinator.checkpointState(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions,
CheckpointMetricsBuilder checkpointMetrics,
OperatorChain<?,?> operatorChain,
java.util.function.Supplier<Boolean> isRunning)
Must be called after
SubtaskCheckpointCoordinator.initCheckpoint(long, CheckpointOptions) . |
void |
SubtaskCheckpointCoordinator.initCheckpoint(long id,
CheckpointOptions checkpointOptions)
Initialize new checkpoint.
|
Future<Boolean> |
StreamTask.triggerCheckpointAsync(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions) |
Future<Boolean> |
SourceStreamTask.triggerCheckpointAsync(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions) |
Future<Boolean> |
SourceOperatorStreamTask.triggerCheckpointAsync(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions) |
Future<Boolean> |
MultipleInputStreamTask.triggerCheckpointAsync(CheckpointMetaData metadata,
CheckpointOptions options) |
void |
StreamTask.triggerCheckpointOnBarrier(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions,
CheckpointMetricsBuilder checkpointMetrics) |
void |
MultipleInputStreamTask.triggerCheckpointOnBarrier(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions,
CheckpointMetricsBuilder checkpointMetrics) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.