Uses of Interface
org.apache.flink.runtime.state.InternalKeyContext
-
Packages that use InternalKeyContext Package Description 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. -
-
Uses of InternalKeyContext in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state that implement InternalKeyContext Modifier and Type Class Description classAbstractKeyedStateBackend<K>Base implementation of KeyedStateBackend.classInternalKeyContextImpl<K>The defaultInternalKeyContextimplementation.Fields in org.apache.flink.runtime.state declared as InternalKeyContext Modifier and Type Field Description protected InternalKeyContext<K>AbstractKeyedStateBackend. keyContextThe key context for this backend.Methods in org.apache.flink.runtime.state that return InternalKeyContext Modifier and Type Method Description InternalKeyContext<K>AbstractKeyedStateBackend. getKeyContext()Constructors in org.apache.flink.runtime.state with parameters of type InternalKeyContext Constructor Description AbstractKeyedStateBackend(TaskKvStateRegistry kvStateRegistry, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry, InternalKeyContext<K> keyContext)AbstractKeyedStateBackend(TaskKvStateRegistry kvStateRegistry, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer, ClassLoader userCodeClassLoader, org.apache.flink.api.common.ExecutionConfig executionConfig, TtlTimeProvider ttlTimeProvider, LatencyTrackingStateConfig latencyTrackingStateConfig, org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry, StreamCompressionDecorator keyGroupCompressionDecorator, InternalKeyContext<K> keyContext) -
Uses of InternalKeyContext in org.apache.flink.runtime.state.heap
Classes in org.apache.flink.runtime.state.heap that implement InternalKeyContext Modifier and Type Class Description classHeapKeyedStateBackend<K>AAbstractKeyedStateBackendthat keeps state on the Java Heap and will serialize state to streams provided by aCheckpointStreamFactoryupon checkpointing.Fields in org.apache.flink.runtime.state.heap declared as InternalKeyContext Modifier and Type Field Description protected InternalKeyContext<K>StateTable. keyContextThe key context view on the backend.Constructors in org.apache.flink.runtime.state.heap with parameters of type InternalKeyContext 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, 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)StateTable(InternalKeyContext<K> keyContext, RegisteredKeyValueStateBackendMetaInfo<N,S> metaInfo, org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer)
-