Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.contrib.streaming.state.ttl | |
org.apache.flink.runtime.state |
Modifier and Type | Field and Description |
---|---|
RegisteredStateMetaInfoBase |
RocksDBKeyedStateBackend.RocksDbKvStateInfo.metaInfo |
Modifier and Type | Method and Description |
---|---|
static org.rocksdb.ColumnFamilyDescriptor |
RocksDBOperationUtils.createColumnFamilyDescriptor(RegisteredStateMetaInfoBase metaInfoBase,
Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
Long writeBufferManagerCapacity)
Creates a column descriptor for a state column family.
|
static RocksDBKeyedStateBackend.RocksDbKvStateInfo |
RocksDBOperationUtils.createStateInfo(RegisteredStateMetaInfoBase metaInfoBase,
org.rocksdb.RocksDB db,
Function<String,org.rocksdb.ColumnFamilyOptions> columnFamilyOptionsFactory,
RocksDbTtlCompactFiltersManager ttlCompactFiltersManager,
Long writeBufferManagerCapacity)
Creates a state info from a new meta info to use with a k/v state.
|
Constructor and Description |
---|
RocksDbKvStateInfo(org.rocksdb.ColumnFamilyHandle columnFamilyHandle,
RegisteredStateMetaInfoBase metaInfo) |
Modifier and Type | Method and Description |
---|---|
void |
RocksDbTtlCompactFiltersManager.setAndRegisterCompactFilterIfStateTtl(RegisteredStateMetaInfoBase metaInfoBase,
org.rocksdb.ColumnFamilyOptions options) |
Modifier and Type | Class and Description |
---|---|
class |
RegisteredBroadcastStateBackendMetaInfo<K,V> |
class |
RegisteredKeyValueStateBackendMetaInfo<N,S>
Compound meta information for a registered state in a keyed state backend.
|
class |
RegisteredOperatorStateBackendMetaInfo<S>
Compound meta information for a registered state in an operator state backend.
|
class |
RegisteredPriorityQueueStateBackendMetaInfo<T>
Meta information about a priority queue state in a backend.
|
Modifier and Type | Method and Description |
---|---|
static RegisteredStateMetaInfoBase |
RegisteredStateMetaInfoBase.fromMetaInfoSnapshot(StateMetaInfoSnapshot snapshot) |
abstract RegisteredStateMetaInfoBase |
RegisteredStateMetaInfoBase.withSerializerUpgradesAllowed()
create a new metadata object with Lazy serializer provider using existing one as a snapshot.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.