Package | Description |
---|---|
org.apache.flink.runtime.state | |
org.apache.flink.streaming.api.functions.source | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.async | |
org.apache.flink.streaming.runtime.operators |
This package contains the operators that perform the stream transformations.
|
org.apache.flink.streaming.util.functions | |
org.apache.flink.table.filesystem.stream | |
org.apache.flink.table.runtime.operators.sort |
Modifier and Type | Class and Description |
---|---|
class |
StateSnapshotContextSynchronousImpl
This class is a default implementation for StateSnapshotContext.
|
Modifier and Type | Method and Description |
---|---|
void |
ContinuousFileReaderOperator.snapshotState(StateSnapshotContext context) |
Modifier and Type | Method and Description |
---|---|
void |
InternalTimeServiceManager.snapshotState(KeyedStateBackend<?> keyedStateBackend,
StateSnapshotContext context,
String operatorName) |
void |
SourceOperator.snapshotState(StateSnapshotContext context) |
void |
AbstractStreamOperator.snapshotState(StateSnapshotContext context)
Stream operators with state, which want to participate in a snapshot need to override this
hook method.
|
void |
AbstractStreamOperatorV2.snapshotState(StateSnapshotContext context)
Stream operators with state, which want to participate in a snapshot need to override this
hook method.
|
void |
AbstractUdfStreamOperator.snapshotState(StateSnapshotContext context) |
void |
StreamOperatorStateHandler.CheckpointedStreamOperator.snapshotState(StateSnapshotContext context) |
Modifier and Type | Method and Description |
---|---|
void |
AsyncWaitOperator.snapshotState(StateSnapshotContext context) |
Modifier and Type | Method and Description |
---|---|
void |
GenericWriteAheadSink.snapshotState(StateSnapshotContext context) |
Modifier and Type | Method and Description |
---|---|
static void |
StreamingFunctionUtils.snapshotFunctionState(StateSnapshotContext context,
OperatorStateBackend backend,
Function userFunction) |
Modifier and Type | Method and Description |
---|---|
void |
StreamingFileCommitter.snapshotState(StateSnapshotContext context) |
void |
StreamingFileWriter.snapshotState(StateSnapshotContext context) |
Modifier and Type | Method and Description |
---|---|
void |
StreamSortOperator.snapshotState(StateSnapshotContext context) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.