Package | Description |
---|---|
org.apache.flink.contrib.streaming.state | |
org.apache.flink.contrib.streaming.state.restore | |
org.apache.flink.runtime.state | |
org.apache.flink.util |
Modifier and Type | Method and Description |
---|---|
void |
AbstractRocksDBState.migrateSerializedValue(DataInputDeserializer serializedOldValueInput,
DataOutputSerializer serializedMigratedValueOutput,
TypeSerializer<V> priorSerializer,
TypeSerializer<V> newSerializer) |
Modifier and Type | Method and Description |
---|---|
RocksDBRestoreResult |
RocksDBFullRestoreOperation.restore()
Restores all key-groups data that is referenced by the passed state handles.
|
Modifier and Type | Method and Description |
---|---|
<K,V> BroadcastState<K,V> |
DefaultOperatorStateBackend.getBroadcastState(MapStateDescriptor<K,V> stateDescriptor) |
Modifier and Type | Method and Description |
---|---|
static StateMigrationException |
StateMigrationException.notSupported() |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.