Package | Description |
---|---|
org.apache.flink.state.api.output.operators | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.runtime.operators.asyncprocessing | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
Modifier and Type | Method and Description |
---|---|
OperatorSnapshotFutures |
StateBootstrapWrapperOperator.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory storageLocation) |
Modifier and Type | Method and Description |
---|---|
OperatorSnapshotFutures |
AbstractStreamOperator.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 |
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) |
Constructor and Description |
---|
OperatorSnapshotFinalizer(OperatorSnapshotFutures snapshotFutures) |
Modifier and Type | Method and Description |
---|---|
OperatorSnapshotFutures |
AbstractAsyncStateStreamOperatorV2.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory) |
OperatorSnapshotFutures |
AbstractAsyncStateStreamOperator.snapshotState(long checkpointId,
long timestamp,
CheckpointOptions checkpointOptions,
CheckpointStreamFactory factory) |
Modifier and Type | Method and Description |
---|---|
protected void |
OperatorChain.snapshotChannelStates(StreamOperator<?> op,
ChannelStateWriter.ChannelStateWriteResult channelStateWriteResult,
OperatorSnapshotFutures snapshotInProgress) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.