Class HeapKeyedStateBackendBuilder<K>
- java.lang.Object
-
- org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder<K>
-
- org.apache.flink.runtime.state.heap.HeapKeyedStateBackendBuilder<K>
-
- Type Parameters:
K
- The data type that the key serializer serializes.
- All Implemented Interfaces:
StateBackendBuilder<AbstractKeyedStateBackend<K>,BackendBuildingException>
public class HeapKeyedStateBackendBuilder<K> extends AbstractKeyedStateBackendBuilder<K>
Builder class forHeapKeyedStateBackend
which handles all necessary initializations and clean ups.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.state.AbstractKeyedStateBackendBuilder
cancelStreamRegistry, executionConfig, keyGroupCompressionDecorator, keyGroupRange, keySerializerProvider, kvStateRegistry, latencyTrackingStateConfig, logger, numberOfKeyGroups, restoreStateHandles, ttlTimeProvider, userCodeClassLoader
-
-
Constructor Summary
Constructors Constructor Description HeapKeyedStateBackendBuilder(TaskKvStateRegistry kvStateRegistry, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, int numberOfKeyGroups, KeyGroupRange keyGroupRange, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, LocalRecoveryConfig localRecoveryConfig, HeapPriorityQueueSetFactory priorityQueueSetFactory, boolean asynchronousSnapshots, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
-
-
-
Constructor Detail
-
HeapKeyedStateBackendBuilder
public HeapKeyedStateBackendBuilder(TaskKvStateRegistry kvStateRegistry, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, int numberOfKeyGroups, KeyGroupRange keyGroupRange, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, @Nonnull Collection<KeyedStateHandle> stateHandles, StreamCompressionDecorator keyGroupCompressionDecorator, LocalRecoveryConfig localRecoveryConfig, HeapPriorityQueueSetFactory priorityQueueSetFactory, boolean asynchronousSnapshots, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry)
-
-
Method Detail
-
build
public HeapKeyedStateBackend<K> build() throws BackendBuildingException
- Throws:
BackendBuildingException
-
-