Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
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.changelog.restore | |
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 |
AbstractKeyedStateBackend<K>
Base implementation of KeyedStateBackend.
|
Modifier and Type | Method and Description |
---|---|
<K> CheckpointableKeyedStateBackend<K> |
StateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry)
Creates a new
CheckpointableKeyedStateBackend that is responsible for holding
keyed state and checkpointing it. |
default <K> CheckpointableKeyedStateBackend<K> |
StateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction)
Creates a new
CheckpointableKeyedStateBackend with the given managed memory fraction. |
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 | Method and Description |
---|---|
<K> CheckpointableKeyedStateBackend<K> |
AbstractChangelogStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
<K> CheckpointableKeyedStateBackend<K> |
AbstractChangelogStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry,
double managedMemoryFraction) |
protected abstract <K> CheckpointableKeyedStateBackend<K> |
AbstractChangelogStateBackend.restore(Environment env,
String operatorIdentifier,
KeyGroupRange keyGroupRange,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<ChangelogStateBackendHandle> stateBackendHandles,
ChangelogBackendRestoreOperation.BaseBackendBuilder<K> baseBackendBuilder) |
protected <K> CheckpointableKeyedStateBackend<K> |
ChangelogStateBackend.restore(Environment env,
String operatorIdentifier,
KeyGroupRange keyGroupRange,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<ChangelogStateBackendHandle> stateBackendHandles,
ChangelogBackendRestoreOperation.BaseBackendBuilder<K> baseBackendBuilder) |
protected <K> CheckpointableKeyedStateBackend<K> |
DeactivatedChangelogStateBackend.restore(Environment env,
String operatorIdentifier,
KeyGroupRange keyGroupRange,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<ChangelogStateBackendHandle> stateBackendHandles,
ChangelogBackendRestoreOperation.BaseBackendBuilder<K> baseBackendBuilder) |
Modifier and Type | Method and Description |
---|---|
CheckpointableKeyedStateBackend<K> |
ChangelogMigrationRestoreTarget.getRestoredKeyedStateBackend() |
CheckpointableKeyedStateBackend<K> |
ChangelogRestoreTarget.getRestoredKeyedStateBackend()
Returns keyed state backend restored finally.
|
static <K> CheckpointableKeyedStateBackend<K> |
ChangelogBackendRestoreOperation.restore(Configuration configuration,
ClassLoader classLoader,
TaskStateManager taskStateManager,
Collection<ChangelogStateBackendHandle> stateHandles,
ChangelogBackendRestoreOperation.BaseBackendBuilder<K> baseBackendBuilder,
ChangelogBackendRestoreOperation.ChangelogRestoreTargetBuilder<K> changelogRestoreTargetBuilder) |
Modifier and Type | Method and Description |
---|---|
CheckpointableKeyedStateBackend<?> |
StreamOperatorStateContext.keyedStateBackend()
Returns the keyed state backend for the stream operator.
|
protected <K> CheckpointableKeyedStateBackend<K> |
StreamTaskStateInitializerImpl.keyedStatedBackend(TypeSerializer<K> keySerializer,
String operatorIdentifierText,
PrioritizedOperatorSubtaskState prioritizedOperatorSubtaskStates,
CloseableRegistry backendCloseableRegistry,
MetricGroup metricGroup,
double managedMemoryFraction) |
Modifier and Type | Class and Description |
---|---|
class |
BatchExecutionKeyedStateBackend<K>
A
CheckpointableKeyedStateBackend which keeps values for a single key at a time. |
Modifier and Type | Method and Description |
---|---|
<K> CheckpointableKeyedStateBackend<K> |
BatchExecutionStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry,
TtlTimeProvider ttlTimeProvider,
MetricGroup metricGroup,
Collection<KeyedStateHandle> stateHandles,
CloseableRegistry cancelStreamRegistry) |
Modifier and Type | Method and Description |
---|---|
static <K> InternalTimeServiceManager<K> |
BatchExecutionInternalTimeServiceManager.create(CheckpointableKeyedStateBackend<K> keyedStatedBackend,
ClassLoader userClassloader,
KeyContext keyContext,
ProcessingTimeService processingTimeService,
Iterable<KeyGroupStatePartitionStreamProvider> rawKeyedStates,
StreamTaskCancellationContext cancellationContext) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.