Package | Description |
---|---|
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.
|
Modifier and Type | Class and Description |
---|---|
class |
CopyOnWriteStateTable<K,N,S>
This implementation of
StateTable uses CopyOnWriteStateMap . |
class |
NestedMapsStateTable<K,N,S>
This implementation of
StateTable uses NestedStateMap . |
Modifier and Type | Field and Description |
---|---|
protected StateTable<K,N,SV> |
AbstractHeapState.stateTable
Map containing the actual key/value pairs.
|
Modifier and Type | Method and Description |
---|---|
StateTable<K,N,SV> |
AbstractHeapState.getStateTable()
This should only be used for testing.
|
Constructor and Description |
---|
HeapKeyedStateBackend(TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
ClassLoader userCodeClassLoader,
ExecutionConfig executionConfig,
TtlTimeProvider ttlTimeProvider,
CloseableRegistry cancelStreamRegistry,
StreamCompressionDecorator keyGroupCompressionDecorator,
Map<String,StateTable<K,?,?>> registeredKVStates,
Map<String,HeapPriorityQueueSnapshotRestoreWrapper> registeredPQStates,
LocalRecoveryConfig localRecoveryConfig,
HeapPriorityQueueSetFactory priorityQueueSetFactory,
org.apache.flink.runtime.state.heap.HeapSnapshotStrategy<K> snapshotStrategy,
InternalKeyContext<K> keyContext) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.