|
Change Parameter Type stateMetaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method package RestoredDBInstance(db RocksDB, columnFamilyHandles List<ColumnFamilyHandle>, columnFamilyDescriptors List<ColumnFamilyDescriptor>, stateMetaInfoSnapshots List<StateMetaInfoSnapshot>) in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation.RestoredDBInstance |
From |
To |
|
Change Parameter Type restoredStateMetaInfoSnapshot : RegisteredKeyedBackendStateMetaInfo.Snapshot<N,S> to restoredStateMetaInfoSnapshot : StateMetaInfoSnapshot in method public resolveKvStateCompatibility(restoredStateMetaInfoSnapshot StateMetaInfoSnapshot, newNamespaceSerializer TypeSerializer<N>, newStateDescriptor StateDescriptor<?,S>) : RegisteredKeyedBackendStateMetaInfo<N,S> in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo |
From |
To |
|
Change Parameter Type stateMetaInfoSnapshot : RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?> to stateMetaInfoSnapshot : StateMetaInfoSnapshot in method private getOrRegisterColumnFamilyHandle(columnFamilyDescriptor ColumnFamilyDescriptor, columnFamilyHandle ColumnFamilyHandle, stateMetaInfoSnapshot StateMetaInfoSnapshot) : ColumnFamilyHandle in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation |
From |
To |
|
Change Parameter Type operatorStateMetaInfoSnapshots : List<RegisteredOperatorBackendStateMetaInfo.Snapshot<?>> to operatorStateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method public OperatorBackendSerializationProxy(operatorStateMetaInfoSnapshots List<StateMetaInfoSnapshot>, broadcastStateMetaInfoSnapshots List<StateMetaInfoSnapshot>) in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy |
From |
To |
|
Change Parameter Type stateMetaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method public KeyedBackendSerializationProxy(keySerializer TypeSerializer<K>, stateMetaInfoSnapshots List<StateMetaInfoSnapshot>, compression boolean) in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy |
From |
To |
|
Change Parameter Type stateMetaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method private createAndRegisterColumnFamilyDescriptors(stateMetaInfoSnapshots List<StateMetaInfoSnapshot>) : List<ColumnFamilyDescriptor> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation |
From |
To |
|
Change Parameter Type stateMetaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method private restoreLocalStateIntoFullInstance(restoreStateHandle IncrementalLocalKeyedStateHandle, columnFamilyDescriptors List<ColumnFamilyDescriptor>, stateMetaInfoSnapshots List<StateMetaInfoSnapshot>) : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation |
From |
To |
|
Change Parameter Type broadcastStateMetaInfoSnapshots : List<RegisteredBroadcastBackendStateMetaInfo.Snapshot<?,?>> to broadcastStateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method public OperatorBackendSerializationProxy(operatorStateMetaInfoSnapshots List<StateMetaInfoSnapshot>, broadcastStateMetaInfoSnapshots List<StateMetaInfoSnapshot>) in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy |
From |
To |
|
Change Return Type List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to List<StateMetaInfoSnapshot> in method public getStateMetaInfoSnapshots() : List<StateMetaInfoSnapshot> in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy |
From |
To |
|
Change Return Type List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to List<StateMetaInfoSnapshot> in method private readMetaData(metaStateHandle StreamStateHandle) : List<StateMetaInfoSnapshot> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation |
From |
To |
|
Change Return Type List<RegisteredOperatorBackendStateMetaInfo.Snapshot<?>> to List<StateMetaInfoSnapshot> in method public getOperatorStateMetaInfoSnapshots() : List<StateMetaInfoSnapshot> in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy |
From |
To |
|
Change Return Type RegisteredBroadcastBackendStateMetaInfo.Snapshot<K,V> to StateMetaInfoSnapshot in method public snapshot() : StateMetaInfoSnapshot in class org.apache.flink.runtime.state.RegisteredBroadcastBackendStateMetaInfo |
From |
To |
|
Change Return Type List<RegisteredBroadcastBackendStateMetaInfo.Snapshot<?,?>> to List<StateMetaInfoSnapshot> in method public getBroadcastStateMetaInfoSnapshots() : List<StateMetaInfoSnapshot> in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy |
From |
To |
|
Change Return Type Snapshot<N,S> to StateMetaInfoSnapshot in method public snapshot() : StateMetaInfoSnapshot in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo |
From |
To |
|
Change Return Type Snapshot<S> to StateMetaInfoSnapshot in method public snapshot() : StateMetaInfoSnapshot in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo |
From |
To |
|
Change Variable Type stateMetaInfoSnapshot : RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?> to stateMetaInfoSnapshot : StateMetaInfoSnapshot in method private createAndRegisterColumnFamilyDescriptors(stateMetaInfoSnapshots List<StateMetaInfoSnapshot>) : List<ColumnFamilyDescriptor> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation |
From |
To |
|
Change Variable Type stateMetaInfoSnapshot : RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?> to stateMetaInfoSnapshot : StateMetaInfoSnapshot in method private restoreLocalStateIntoFullInstance(restoreStateHandle IncrementalLocalKeyedStateHandle, columnFamilyDescriptors List<ColumnFamilyDescriptor>, stateMetaInfoSnapshots List<StateMetaInfoSnapshot>) : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation |
From |
To |
|
Change Variable Type broadcastMetaInfoSnapshots : List<RegisteredBroadcastBackendStateMetaInfo.Snapshot<?,?>> to broadcastMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method public performOperation() : SnapshotResult<OperatorStateHandle> in class org.apache.flink.runtime.state.DefaultOperatorStateBackend.snapshot.ioCallable |
From |
To |
|
Change Variable Type stateMetaInfoList : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoList : List<StateMetaInfoSnapshot> in method public testKeyedBackendSerializationProxyRoundtrip() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?> to restoredMetaInfo : StateMetaInfoSnapshot in method private restorePartitionedState(state Collection<KeyedStateHandle>) : void in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Variable Type restoredBroadcastMetaInfoSnapshots : List<RegisteredBroadcastBackendStateMetaInfo.Snapshot<?,?>> to restoredBroadcastMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method public restore(restoreSnapshots Collection<OperatorStateHandle>) : void in class org.apache.flink.runtime.state.DefaultOperatorStateBackend |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredOperatorBackendStateMetaInfo.Snapshot<S> to restoredSnapshot : StateMetaInfoSnapshot in method private getListState(stateDescriptor ListStateDescriptor<S>, mode OperatorStateHandle.Mode) : ListState<S> in class org.apache.flink.runtime.state.DefaultOperatorStateBackend |
From |
To |
|
Change Variable Type stateMetaInfoList : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoList : List<StateMetaInfoSnapshot> in method public testKeyedBackendSerializationProxyRoundtripWithSerializerSerializationFailures() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type restoredMetaInfos : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to restoredMetaInfos : List<StateMetaInfoSnapshot> in method private restorePartitionedState(state Collection<KeyedStateHandle>) : void in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Variable Type stateMetaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method private restoreDBInstanceFromStateHandle(restoreStateHandle IncrementalKeyedStateHandle, temporaryRestoreInstancePath Path) : RestoredDBInstance in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation |
From |
To |
|
Change Variable Type restoredMetaInfoSnapshot : RegisteredKeyedBackendStateMetaInfo.Snapshot<N,V> to restoredMetaInfoSnapshot : StateMetaInfoSnapshot in method private tryRegisterStateTable(namespaceSerializer TypeSerializer<N>, stateDesc StateDescriptor<?,V>) : StateTable<K,N,V> in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Variable Type broadcastStateMetaInfoSnapshots : List<RegisteredBroadcastBackendStateMetaInfo.Snapshot<?,?>> to broadcastStateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method public testOperatorBackendSerializationProxyRoundtrip() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type stateMetaInfoSnapshots : List<RegisteredOperatorBackendStateMetaInfo.Snapshot<?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method public testOperatorBackendSerializationProxyRoundtrip() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type metaInfo : RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?> to metaInfo : StateMetaInfoSnapshot in method public testKeyedStateMetaInfoSerialization() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type stateMetaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method package restoreWithoutRescaling(rawStateHandle KeyedStateHandle) : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation |
From |
To |
|
Change Variable Type restoredMetaInfoSnapshot : RegisteredKeyedBackendStateMetaInfo.Snapshot<N,S> to restoredMetaInfoSnapshot : StateMetaInfoSnapshot in method private tryRegisterKvStateInformation(stateDesc StateDescriptor<?,S>, namespaceSerializer TypeSerializer<N>) : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<N,S>> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Variable Type operatorMetaInfoSnapshots : List<RegisteredOperatorBackendStateMetaInfo.Snapshot<?>> to operatorMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method public performOperation() : SnapshotResult<OperatorStateHandle> in class org.apache.flink.runtime.state.DefaultOperatorStateBackend.snapshot.ioCallable |
From |
To |
|
Change Variable Type restoredMetaInfos : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to restoredMetaInfos : List<StateMetaInfoSnapshot> in method private restoreKVStateMetaData() : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBFullRestoreOperation |
From |
To |
|
Change Variable Type metaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to metaInfoSnapshots : List<StateMetaInfoSnapshot> in method public performSnapshot(checkpointId long, timestamp long, primaryStreamFactory CheckpointStreamFactory, checkpointOptions CheckpointOptions) : RunnableFuture<SnapshotResult<KeyedStateHandle>> in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend.HeapSnapshotStrategy |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?> to restoredMetaInfo : StateMetaInfoSnapshot in method private restoreKVStateMetaData() : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBFullRestoreOperation |
From |
To |
|
Change Variable Type restoredOperatorMetaInfoSnapshots : List<RegisteredOperatorBackendStateMetaInfo.Snapshot<?>> to restoredOperatorMetaInfoSnapshots : List<StateMetaInfoSnapshot> in method public restore(restoreSnapshots Collection<OperatorStateHandle>) : void in class org.apache.flink.runtime.state.DefaultOperatorStateBackend |
From |
To |
|
Change Attribute Type restoredKvStateMetaInfos : Map<String,RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to restoredKvStateMetaInfos : Map<String,StateMetaInfoSnapshot> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Attribute Type restoredKvStateMetaInfos : Map<String,RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to restoredKvStateMetaInfos : Map<String,StateMetaInfoSnapshot> in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Attribute Type stateMetaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalSnapshotOperation |
From |
To |
|
Change Attribute Type stateMetaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy |
From |
To |
|
Change Attribute Type stateMetaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation.RestoredDBInstance |
From |
To |
|
Change Attribute Type operatorStateMetaInfoSnapshots : List<RegisteredOperatorBackendStateMetaInfo.Snapshot<?>> to operatorStateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy |
From |
To |
|
Change Attribute Type broadcastStateMetaInfoSnapshots : List<RegisteredBroadcastBackendStateMetaInfo.Snapshot<?,?>> to broadcastStateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy |
From |
To |
|
Change Attribute Type stateMetaInfoSnapshots : List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?,?>> to stateMetaInfoSnapshots : List<StateMetaInfoSnapshot> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBFullSnapshotOperation |
From |
To |
|
Change Attribute Type restoredOperatorStateMetaInfos : Map<String,RegisteredOperatorBackendStateMetaInfo.Snapshot<?>> to restoredOperatorStateMetaInfos : Map<String,StateMetaInfoSnapshot> in class org.apache.flink.runtime.state.DefaultOperatorStateBackend |
From |
To |
|
Change Attribute Type restoredBroadcastStateMetaInfos : Map<String,RegisteredBroadcastBackendStateMetaInfo.Snapshot<?,?>> to restoredBroadcastStateMetaInfos : Map<String,StateMetaInfoSnapshot> in class org.apache.flink.runtime.state.DefaultOperatorStateBackend |
From |
To |