Uses of Class
org.apache.flink.runtime.state.heap.StateTable
-
Packages that use StateTable 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. -
-
Uses of StateTable in org.apache.flink.runtime.state.heap
Subclasses of StateTable in org.apache.flink.runtime.state.heap Modifier and Type Class Description classCopyOnWriteStateTable<K,N,S>This implementation ofStateTableusesCopyOnWriteStateMap.Fields in org.apache.flink.runtime.state.heap declared as StateTable Modifier and Type Field Description protected StateTable<K,N,S>AbstractStateTableSnapshot. owningStateTableTheStateTablefrom which this snapshot was created.protected StateTable<K,N,SV>AbstractHeapState. stateTableMap containing the actual key/value pairs.Methods in org.apache.flink.runtime.state.heap that return StateTable Modifier and Type Method Description StateTable<K,N,SV>AbstractHeapState. getStateTable()This should only be used for testing.Methods in org.apache.flink.runtime.state.heap with parameters of type StateTable Modifier and Type Method Description static <K,N,S>
StateSnapshotKeyGroupReaderStateTableByKeyGroupReaders. readerForVersion(StateTable<K,N,S> stateTable, int version)Creates a new StateTableByKeyGroupReader that inserts de-serialized mappings into the given table, using the de-serialization algorithm that matches the given version.Constructor parameters in org.apache.flink.runtime.state.heap with type arguments of type StateTable Constructor Description HeapKeyedStateBackend(TaskKvStateRegistry kvStateRegistry, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, SizeTrackingStateConfig sizeTrackingStateConfig, org.apache.flink.core.fs.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> checkpointStrategy, SnapshotExecutionType snapshotExecutionType, org.apache.flink.runtime.state.heap.StateTableFactory<K> stateTableFactory, InternalKeyContext<K> keyContext)
-