Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.contrib.streaming.state.snapshot | |
org.apache.flink.runtime.checkpoint | |
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.messages.checkpoint |
This package contains the messages that are sent between
JobMaster
and TaskExecutor to coordinate the checkpoint snapshots of the
distributed dataflow. |
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.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 |
---|---|
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>> |
RocksFullSnapshotStrategy.doSnapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory primaryStreamFactory,
CheckpointOptions checkpointOptions) |
protected RunnableFuture<SnapshotResult<KeyedStateHandle>> |
RocksIncrementalSnapshotStrategy.doSnapshot(long checkpointId,
long checkpointTimestamp,
CheckpointStreamFactory checkpointStreamFactory,
CheckpointOptions checkpointOptions) |
RunnableFuture<SnapshotResult<KeyedStateHandle>> |
RocksDBSnapshotStrategyBase.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
static CheckpointOptions |
CheckpointOptions.forCheckpointWithDefaultLocation() |
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.
|
Modifier and Type | Method and Description |
---|---|
CheckpointOptions |
CheckpointBarrier.getCheckpointOptions() |
Constructor and Description |
---|
CheckpointBarrier(long id,
long timestamp,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
boolean |
AbstractInvokable.triggerCheckpoint(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions)
This method is called to trigger a checkpoint, asynchronously by the checkpoint
coordinator.
|
void |
AbstractInvokable.triggerCheckpointOnBarrier(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions,
CheckpointMetrics 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 |
ActorTaskManagerGateway.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
JobID jobId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions) |
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 |
---|---|
CheckpointOptions |
TriggerCheckpoint.getCheckpointOptions() |
Constructor and Description |
---|
TriggerCheckpoint(JobID job,
ExecutionAttemptID taskExecutionId,
long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions) |
Modifier and Type | Method and Description |
---|---|
RunnableFuture<SnapshotResult<OperatorStateHandle>> |
DefaultOperatorStateBackend.snapshot(long checkpointId,
long timestamp,
CheckpointStreamFactory streamFactory,
CheckpointOptions checkpointOptions) |
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. |
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> |
TaskExecutorGateway.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
long checkpointID,
long checkpointTimestamp,
CheckpointOptions checkpointOptions)
Trigger the checkpoint for the given task.
|
CompletableFuture<Acknowledge> |
TaskExecutor.triggerCheckpoint(ExecutionAttemptID executionAttemptID,
long checkpointId,
long checkpointTimestamp,
CheckpointOptions checkpointOptions) |
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 |
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) |
Modifier and Type | Method and Description |
---|---|
void |
OperatorChain.broadcastCheckpointBarrier(long id,
long timestamp,
CheckpointOptions checkpointOptions) |
boolean |
StreamTask.triggerCheckpoint(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions) |
boolean |
SourceStreamTask.triggerCheckpoint(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions) |
void |
StreamTask.triggerCheckpointOnBarrier(CheckpointMetaData checkpointMetaData,
CheckpointOptions checkpointOptions,
CheckpointMetrics checkpointMetrics) |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.