Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.runtime.checkpoint | |
org.apache.flink.runtime.jobmaster | |
org.apache.flink.runtime.query | |
org.apache.flink.runtime.state | |
org.apache.flink.runtime.state.filesystem | |
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.runtime.state.memory | |
org.apache.flink.runtime.taskexecutor.rpc | |
org.apache.flink.runtime.taskmanager |
Modifier and Type | Method and Description |
---|---|
<K> AbstractKeyedStateBackend<K> |
RocksDBStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry) |
Constructor and Description |
---|
RocksDBKeyedStateBackend(String operatorIdentifier,
ClassLoader userCodeClassLoader,
File instanceBasePath,
org.rocksdb.DBOptions dbOptions,
org.rocksdb.ColumnFamilyOptions columnFamilyOptions,
TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
ExecutionConfig executionConfig,
boolean enableIncrementalCheckpointing,
LocalRecoveryConfig localRecoveryConfig) |
Modifier and Type | Method and Description |
---|---|
static List<KeyGroupRange> |
StateAssignmentOperation.createKeyGroupPartitions(int numberKeyGroups,
int parallelism)
Groups the available set of key groups into key group partitions.
|
Modifier and Type | Method and Description |
---|---|
static List<KeyedStateHandle> |
StateAssignmentOperation.getKeyedStateHandles(Collection<? extends KeyedStateHandle> keyedStateHandles,
KeyGroupRange subtaskKeyGroupRange)
Determine the subset of
KeyGroupsStateHandles with correct
key group index for the given subtask KeyGroupRange . |
static List<KeyedStateHandle> |
StateAssignmentOperation.getManagedKeyedStateHandles(OperatorState operatorState,
KeyGroupRange subtaskKeyGroupRange)
Collect
managedKeyedStateHandles which have intersection with given
KeyGroupRange from operatorState |
static List<KeyedStateHandle> |
StateAssignmentOperation.getRawKeyedStateHandles(OperatorState operatorState,
KeyGroupRange subtaskKeyGroupRange)
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
KvStateRegistryGateway.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress)
Notifies that queryable state has been registered.
|
CompletableFuture<Acknowledge> |
JobMaster.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress) |
CompletableFuture<Acknowledge> |
KvStateRegistryGateway.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName)
Notifies that queryable state has been unregistered.
|
CompletableFuture<Acknowledge> |
JobMaster.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName) |
Modifier and Type | Method and Description |
---|---|
KeyGroupRange |
KvStateMessage.NotifyKvStateRegistered.getKeyGroupRange()
Returns the key group index the KvState instance belongs to.
|
KeyGroupRange |
KvStateMessage.NotifyKvStateUnregistered.getKeyGroupRange()
Returns the key group index the KvState instance belongs to.
|
Modifier and Type | Method and Description |
---|---|
void |
KvStateRegistryListener.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId)
Notifies the listener about a registered KvState instance.
|
void |
KvStateLocationRegistry.notifyKvStateRegistered(JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress)
Notifies the registry about a registered KvState instance.
|
void |
KvStateRegistryListener.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName)
Notifies the listener about an unregistered KvState instance.
|
void |
KvStateLocationRegistry.notifyKvStateUnregistered(JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName)
Notifies the registry about an unregistered KvState instance.
|
KvStateID |
KvStateRegistry.registerKvState(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
InternalKvState<?,?,?> kvState)
Registers the KvState instance and returns the assigned ID.
|
void |
KvStateLocation.registerKvState(KeyGroupRange keyGroupRange,
KvStateID kvStateId,
InetSocketAddress kvStateAddress)
Registers a KvState instance for the given key group index.
|
void |
TaskKvStateRegistry.registerKvState(KeyGroupRange keyGroupRange,
String registrationName,
InternalKvState<?,?,?> kvState)
Registers the KvState instance at the KvStateRegistry.
|
void |
KvStateRegistry.unregisterKvState(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId)
Unregisters the KvState instance identified by the given KvStateID.
|
Constructor and Description |
---|
NotifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId,
InetSocketAddress kvStateServerAddress)
Notifies the JobManager about a registered
InternalKvState instance. |
NotifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName)
Notifies the JobManager about an unregistered
InternalKvState instance. |
Modifier and Type | Field and Description |
---|---|
static KeyGroupRange |
KeyGroupRange.EMPTY_KEY_GROUP_RANGE
The empty key-group
|
protected KeyGroupRange |
AbstractKeyedStateBackend.keyGroupRange
Range of key-groups for which this backend is responsible
|
Modifier and Type | Method and Description |
---|---|
static KeyGroupRange |
KeyGroupRangeAssignment.computeKeyGroupRangeForOperatorIndex(int maxParallelism,
int parallelism,
int operatorIndex)
Computes the range of key-groups that are assigned to a given operator under the given parallelism and maximum
parallelism.
|
KeyGroupRange |
KeyGroupRange.getIntersection(KeyGroupRange other)
Create a range that represent the intersection between this range and the given range.
|
KeyGroupRange |
KeyGroupRangeOffsets.getKeyGroupRange() |
KeyGroupRange |
KeyGroupsStateHandle.getKeyGroupRange() |
KeyGroupRange |
IncrementalKeyedStateHandle.getKeyGroupRange() |
KeyGroupRange |
KeyedStateHandle.getKeyGroupRange()
Returns the range of the key groups contained in the state.
|
KeyGroupRange |
DirectoryKeyedStateHandle.getKeyGroupRange() |
KeyGroupRange |
AbstractKeyedStateBackend.getKeyGroupRange() |
static KeyGroupRange |
KeyGroupRange.of(int startKeyGroup,
int endKeyGroup)
Factory method that also handles creation of empty key-groups.
|
Modifier and Type | Method and Description |
---|---|
<K> AbstractKeyedStateBackend<K> |
StateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry)
Creates a new
AbstractKeyedStateBackend that is responsible for holding keyed state
and checkpointing it. |
abstract <K> AbstractKeyedStateBackend<K> |
AbstractStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry) |
KeyGroupRangeOffsets |
KeyGroupRangeOffsets.getIntersection(KeyGroupRange keyGroupRange)
Returns a key-group range with offsets which is the intersection of the internal key-group range with the given
key-group range.
|
KeyGroupsStateHandle |
KeyGroupsStateHandle.getIntersection(KeyGroupRange keyGroupRange) |
KeyedStateHandle |
IncrementalKeyedStateHandle.getIntersection(KeyGroupRange keyGroupRange) |
KeyedStateHandle |
KeyedStateHandle.getIntersection(KeyGroupRange keyGroupRange)
Returns a state over a range that is the intersection between this
handle's key-group range and the provided key-group range.
|
KeyedStateHandle |
DirectoryKeyedStateHandle.getIntersection(KeyGroupRange otherKeyGroupRange) |
KeyGroupRange |
KeyGroupRange.getIntersection(KeyGroupRange other)
Create a range that represent the intersection between this range and the given range.
|
Constructor and Description |
---|
AbstractKeyedStateBackend(TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
ClassLoader userCodeClassLoader,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
ExecutionConfig executionConfig) |
DirectoryKeyedStateHandle(DirectoryStateHandle directoryStateHandle,
KeyGroupRange keyGroupRange) |
IncrementalKeyedStateHandle(UUID backendIdentifier,
KeyGroupRange keyGroupRange,
long checkpointId,
Map<StateHandleID,StreamStateHandle> sharedState,
Map<StateHandleID,StreamStateHandle> privateState,
StreamStateHandle metaStateHandle) |
IncrementalLocalKeyedStateHandle(UUID backendIdentifier,
long checkpointId,
DirectoryStateHandle directoryStateHandle,
KeyGroupRange keyGroupRange,
StreamStateHandle metaDataState,
Set<StateHandleID> sharedStateHandleIDs) |
KeyedStateCheckpointOutputStream(CheckpointStreamFactory.CheckpointStateOutputStream delegate,
KeyGroupRange keyGroupRange) |
KeyGroupRangeOffsets(KeyGroupRange keyGroupRange)
Creates key-group range with offsets for the given key-group range, where all offsets are initially zero.
|
KeyGroupRangeOffsets(KeyGroupRange keyGroupRange,
long[] offsets)
Creates key-group range with offsets from the given key-group range.
|
StateSnapshotContextSynchronousImpl(long checkpointId,
long checkpointTimestamp,
CheckpointStreamFactory streamFactory,
KeyGroupRange keyGroupRange,
CloseableRegistry closableRegistry) |
Modifier and Type | Method and Description |
---|---|
<K> AbstractKeyedStateBackend<K> |
FsStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry) |
Modifier and Type | Method and Description |
---|---|
KeyGroupRange |
InternalKeyContext.getKeyGroupRange()
Returns the key groups for this backend.
|
Constructor and Description |
---|
HeapKeyedStateBackend(TaskKvStateRegistry kvStateRegistry,
TypeSerializer<K> keySerializer,
ClassLoader userCodeClassLoader,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
boolean asynchronousSnapshots,
ExecutionConfig executionConfig,
LocalRecoveryConfig localRecoveryConfig) |
Modifier and Type | Method and Description |
---|---|
<K> AbstractKeyedStateBackend<K> |
MemoryStateBackend.createKeyedStateBackend(Environment env,
JobID jobID,
String operatorIdentifier,
TypeSerializer<K> keySerializer,
int numberOfKeyGroups,
KeyGroupRange keyGroupRange,
TaskKvStateRegistry kvStateRegistry) |
Modifier and Type | Method and Description |
---|---|
void |
RpcKvStateRegistryListener.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId) |
void |
RpcKvStateRegistryListener.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName) |
Modifier and Type | Method and Description |
---|---|
void |
ActorGatewayKvStateRegistryListener.notifyKvStateRegistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName,
KvStateID kvStateId) |
void |
ActorGatewayKvStateRegistryListener.notifyKvStateUnregistered(JobID jobId,
JobVertexID jobVertexId,
KeyGroupRange keyGroupRange,
String registrationName) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.