Uses of Interface
org.apache.flink.api.common.state.OperatorStateStore
-
-
Uses of OperatorStateStore in org.apache.flink.connector.file.table.stream
Methods in org.apache.flink.connector.file.table.stream with parameters of type OperatorStateStore Modifier and Type Method Description static PartitionCommitTrigger
PartitionCommitTrigger. create(boolean isRestored, OperatorStateStore stateStore, Configuration conf, ClassLoader cl, List<String> partitionKeys, ProcessingTimeService procTimeService)
Constructors in org.apache.flink.connector.file.table.stream with parameters of type OperatorStateStore Constructor Description PartitionTimeCommitTrigger(boolean isRestored, OperatorStateStore stateStore, PartitionCommitPredicate partitionCommitPredicate)
ProcTimeCommitTrigger(boolean isRestored, OperatorStateStore stateStore, ProcessingTimeService procTimeService, PartitionCommitPredicate partitionCommitPredicate)
-
Uses of OperatorStateStore in org.apache.flink.datastream.impl.context
Fields in org.apache.flink.datastream.impl.context declared as OperatorStateStore Modifier and Type Field Description protected OperatorStateStore
DefaultStateManager. operatorStateStore
Constructors in org.apache.flink.datastream.impl.context with parameters of type OperatorStateStore Constructor Description DefaultPartitionedContext(RuntimeContext context, Supplier<Object> currentKeySupplier, Consumer<Object> currentKeySetter, ProcessingTimeManager processingTimeManager, StreamingRuntimeContext operatorContext, OperatorStateStore operatorStateStore)
DefaultStateManager(Supplier<Object> currentKeySupplier, Consumer<Object> currentKeySetter, StreamingRuntimeContext operatorContext, OperatorStateStore operatorStateStore)
-
Uses of OperatorStateStore in org.apache.flink.runtime.state
Subinterfaces of OperatorStateStore in org.apache.flink.runtime.state Modifier and Type Interface Description interface
OperatorStateBackend
Interface that combines both, the user facingOperatorStateStore
interface and the system interfaceSnapshotable
Classes in org.apache.flink.runtime.state that implement OperatorStateStore Modifier and Type Class Description class
DefaultOperatorStateBackend
Default implementation of OperatorStateStore that provides the ability to make snapshots.Methods in org.apache.flink.runtime.state that return OperatorStateStore Modifier and Type Method Description OperatorStateStore
ManagedInitializationContext. getOperatorStateStore()
Returns an interface that allows for registering operator state with the backend.OperatorStateStore
StateInitializationContextImpl. getOperatorStateStore()
Constructors in org.apache.flink.runtime.state with parameters of type OperatorStateStore Constructor Description StateInitializationContextImpl(Long restoredCheckpointId, OperatorStateStore operatorStateStore, KeyedStateStore keyedStateStore, Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStateInputs, Iterable<StatePartitionStreamProvider> rawOperatorStateInputs)
-
Uses of OperatorStateStore in org.apache.flink.streaming.api.functions.sink.filesystem
Constructors in org.apache.flink.streaming.api.functions.sink.filesystem with parameters of type OperatorStateStore Constructor Description StreamingFileSinkHelper(Buckets<IN,?> buckets, boolean isRestored, OperatorStateStore stateStore, ProcessingTimeService procTimeService, long bucketCheckInterval)
-