Package | Description |
---|---|
org.apache.flink.state.api | |
org.apache.flink.state.api.output | |
org.apache.flink.state.api.output.operators |
Modifier and Type | Method and Description |
---|---|
StreamOperator<TaggedOperatorSubtaskState> |
SavepointWriterOperatorFactory.createOperator(long savepointTimestamp,
Path savepointPath)
Creates a
StreamOperator to be used for generating and snapshotting state. |
Modifier and Type | Method and Description |
---|---|
static <OUT,OP extends StreamOperator<OUT>> |
SnapshotUtils.snapshot(OP operator,
int index,
long timestamp,
boolean isExactlyOnceMode,
boolean isUnalignedCheckpoint,
Configuration configuration,
Path savepointPath) |
Modifier and Type | Method and Description |
---|---|
void |
BoundedOneInputStreamTaskRunner.mapPartition(Iterable<IN> values,
Collector<TaggedOperatorSubtaskState> out)
Deprecated.
|
void |
OperatorSubtaskStateReducer.reduce(Iterable<TaggedOperatorSubtaskState> values,
Collector<OperatorState> out) |
Modifier and Type | Method and Description |
---|---|
void |
StateBootstrapWrapperOperator.setup(StreamTask<?,?> containingTask,
StreamConfig config,
Output<StreamRecord<TaggedOperatorSubtaskState>> output) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.