Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.runtime.checkpoint.metadata | |
org.apache.flink.runtime.operators.sort | |
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.state.changelog | |
org.apache.flink.state.forst | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.api.operators.sorted.state |
Modifier and Type | Class and Description |
---|---|
class |
RocksDBKeyedStateBackend<K>
An
AbstractKeyedStateBackend that stores its state in RocksDB and serializes
state to streams provided by a CheckpointStreamFactory
upon checkpointing. |
Modifier and Type | Class and Description |
---|---|
class |
CheckpointMetadata
The metadata of a snapshot (checkpoint or savepoint).
|
Modifier and Type | Interface and Description |
---|---|
interface |
InMemorySorter<T> |
Modifier and Type | Class and Description |
---|---|
class |
FixedLengthRecordSorter<T> |
class |
NormalizedKeySorter<T> |
Modifier and Type | Interface and Description |
---|---|
interface |
AsyncKeyedStateBackend
An async keyed state backend provides methods supporting to access keyed state asynchronously and
in batch.
|
interface |
CheckpointableKeyedStateBackend<K>
Interface that combines both, the
KeyedStateBackend interface, which encapsulates methods
responsible for keyed state management and the Snapshotable which tells the system how to
snapshot the underlying state. |
interface |
KeyedStateBackend<K>
A keyed state backend provides methods for managing keyed state.
|
interface |
OperatorStateBackend
Interface that combines both, the user facing
OperatorStateStore interface and the system
interface Snapshotable |
interface |
TestableKeyedStateBackend<K>
A keyed state backend interface for internal testing purpose.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractKeyedStateBackend<K>
Base implementation of KeyedStateBackend.
|
class |
DefaultOperatorStateBackend
Default implementation of OperatorStateStore that provides the ability to make snapshots.
|
Modifier and Type | Class and Description |
---|---|
class |
HeapKeyedStateBackend<K>
A
AbstractKeyedStateBackend that keeps state on the Java Heap and will serialize state to
streams provided by a CheckpointStreamFactory upon checkpointing. |
Modifier and Type | Class and Description |
---|---|
class |
ChangelogKeyedStateBackend<K>
A
KeyedStateBackend that keeps state on the underlying delegated keyed state backend as
well as on the state change log. |
Modifier and Type | Class and Description |
---|---|
class |
ForStKeyedStateBackend<K>
A KeyedStateBackend that stores its state in
ForSt . |
Modifier and Type | Class and Description |
---|---|
class |
BackendRestorerProcedure<T extends Closeable & Disposable,S extends StateObject>
This class implements the logic that creates (and potentially restores) a state backend.
|
protected static interface |
StreamTaskStateInitializerImpl.KeyedStateBackendCreator<K,R extends Disposable & Closeable>
Functional interface to create the keyed state backend.
|
Modifier and Type | Method and Description |
---|---|
protected <K,R extends Disposable & Closeable> |
StreamTaskStateInitializerImpl.keyedStatedBackend(TypeSerializer<K> keySerializer,
String operatorIdentifierText,
PrioritizedOperatorSubtaskState prioritizedOperatorSubtaskStates,
CloseableRegistry backendCloseableRegistry,
MetricGroup metricGroup,
double managedMemoryFraction,
StateObject.StateObjectSizeStatsCollector statsCollector,
StreamTaskStateInitializerImpl.KeyedStateBackendCreator<K,R> keyedStateBackendCreator) |
Modifier and Type | Class and Description |
---|---|
class |
BatchExecutionKeyedStateBackend<K>
A
CheckpointableKeyedStateBackend which keeps values for a single key at a time. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.