|
Change Parameter Type newMetaInfo : RegisteredKeyedBackendStateMetaInfo<N,V> to newMetaInfo : RegisteredKeyValueStateBackendMetaInfo<N,V> in method public newStateTable(newMetaInfo RegisteredKeyValueStateBackendMetaInfo<N,V>) : StateTable<K,N,V> in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend.HeapSnapshotStrategy |
From |
To |
|
Change Parameter Type registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<N,SV>> to registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>> in method package create(stateDesc StateDescriptor<S,SV>, registerResult Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>>, backend RocksDBKeyedStateBackend<K>) : IS in class org.apache.flink.contrib.streaming.state.RocksDBReducingState |
From |
To |
|
Change Parameter Type copy : RegisteredOperatorBackendStateMetaInfo<S> to copy : RegisteredOperatorStateBackendMetaInfo<S> in method private RegisteredOperatorStateBackendMetaInfo(copy RegisteredOperatorStateBackendMetaInfo<S>) in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo |
From |
To |
|
Change Parameter Type stateMetaInfo : RegisteredOperatorBackendStateMetaInfo<S> to stateMetaInfo : RegisteredOperatorStateBackendMetaInfo<S> in method private PartitionableListState(stateMetaInfo RegisteredOperatorStateBackendMetaInfo<S>, internalList ArrayList<S>) in class org.apache.flink.runtime.state.DefaultOperatorStateBackend.PartitionableListState |
From |
To |
|
Change Parameter Type copy : RegisteredBroadcastBackendStateMetaInfo<K,V> to copy : RegisteredBroadcastStateBackendMetaInfo<K,V> in method public RegisteredBroadcastStateBackendMetaInfo(copy RegisteredBroadcastStateBackendMetaInfo<K,V>) in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo |
From |
To |
|
Change Parameter Type stateMetaInfo : RegisteredBroadcastBackendStateMetaInfo<K,V> to stateMetaInfo : RegisteredBroadcastStateBackendMetaInfo<K,V> in method package HeapBroadcastState(stateMetaInfo RegisteredBroadcastStateBackendMetaInfo<K,V>) in class org.apache.flink.runtime.state.HeapBroadcastState |
From |
To |
|
Change Parameter Type metaInfo : RegisteredKeyedBackendStateMetaInfo<N,S> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<N,S> in method public NestedMapsStateTable(keyContext InternalKeyContext<K>, metaInfo RegisteredKeyValueStateBackendMetaInfo<N,S>) in class org.apache.flink.runtime.state.heap.NestedMapsStateTable |
From |
To |
|
Change Parameter Type stateMetaInfo : RegisteredBroadcastBackendStateMetaInfo<K,V> to stateMetaInfo : RegisteredBroadcastStateBackendMetaInfo<K,V> in method public setStateMetaInfo(stateMetaInfo RegisteredBroadcastStateBackendMetaInfo<K,V>) : void in class org.apache.flink.runtime.state.HeapBroadcastState |
From |
To |
|
Change Parameter Type newMetaInfo : RegisteredKeyedBackendStateMetaInfo<N,V> to newMetaInfo : RegisteredKeyValueStateBackendMetaInfo<N,V> in method public newStateTable(newMetaInfo RegisteredKeyValueStateBackendMetaInfo<N,V>) : StateTable<K,N,V> in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend.SyncSnapshotStrategySynchronicityBehavior |
From |
To |
|
Change Parameter Type registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<N,SV>> to registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>> in method package create(stateDesc StateDescriptor<S,SV>, registerResult Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>>, backend RocksDBKeyedStateBackend<K>) : IS in class org.apache.flink.contrib.streaming.state.RocksDBValueState |
From |
To |
|
Change Parameter Type stateMetaInfo : RegisteredOperatorBackendStateMetaInfo<S> to stateMetaInfo : RegisteredOperatorStateBackendMetaInfo<S> in method public setStateMetaInfo(stateMetaInfo RegisteredOperatorStateBackendMetaInfo<S>) : void in class org.apache.flink.runtime.state.DefaultOperatorStateBackend.PartitionableListState |
From |
To |
|
Change Parameter Type newMetaInfo : RegisteredKeyedBackendStateMetaInfo<N,V> to newMetaInfo : RegisteredKeyValueStateBackendMetaInfo<N,V> in method public newStateTable(newMetaInfo RegisteredKeyValueStateBackendMetaInfo<N,V>) : StateTable<K,N,V> in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend.SnapshotStrategySynchronicityBehavior |
From |
To |
|
Change Parameter Type newMetaInfo : RegisteredKeyedBackendStateMetaInfo<N,V> to newMetaInfo : RegisteredKeyValueStateBackendMetaInfo<N,V> in method public newStateTable(newMetaInfo RegisteredKeyValueStateBackendMetaInfo<N,V>) : StateTable<K,N,V> in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend.AsyncSnapshotStrategySynchronicityBehavior |
From |
To |
|
Change Parameter Type metaInfo : RegisteredKeyedBackendStateMetaInfo<N,S> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<N,S> in method public StateTable(keyContext InternalKeyContext<K>, metaInfo RegisteredKeyValueStateBackendMetaInfo<N,S>) in class org.apache.flink.runtime.state.heap.StateTable |
From |
To |
|
Change Parameter Type registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<N,SV>> to registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>> in method package create(stateDesc StateDescriptor<S,SV>, registerResult Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>>, backend RocksDBKeyedStateBackend<K>) : IS in class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState |
From |
To |
|
Change Parameter Type priorityQueueSetFactory : PriorityQueueSetFactory to priorityQueueSetFactory : HeapPriorityQueueSetFactory in method public HeapKeyedStateBackend(kvStateRegistry TaskKvStateRegistry, keySerializer TypeSerializer<K>, userCodeClassLoader ClassLoader, numberOfKeyGroups int, keyGroupRange KeyGroupRange, asynchronousSnapshots boolean, executionConfig ExecutionConfig, localRecoveryConfig LocalRecoveryConfig, priorityQueueSetFactory HeapPriorityQueueSetFactory, ttlTimeProvider TtlTimeProvider) in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Parameter Type metaInfo : RegisteredKeyedBackendStateMetaInfo<N,S> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<N,S> in method public setMetaInfo(metaInfo RegisteredKeyValueStateBackendMetaInfo<N,S>) : void in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable |
From |
To |
|
Change Parameter Type metaInfo : RegisteredKeyedBackendStateMetaInfo<N,S> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<N,S> in method package CopyOnWriteStateTable(keyContext InternalKeyContext<K>, metaInfo RegisteredKeyValueStateBackendMetaInfo<N,S>) in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable |
From |
To |
|
Change Parameter Type metaInfo : RegisteredKeyedBackendStateMetaInfo<N,S> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<N,S> in method public setMetaInfo(metaInfo RegisteredKeyValueStateBackendMetaInfo<N,S>) : void in class org.apache.flink.runtime.state.heap.StateTable |
From |
To |
|
Change Parameter Type metaInfo : RegisteredKeyedBackendStateMetaInfo<N,S> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<N,S> in method private CopyOnWriteStateTable(keyContext InternalKeyContext<K>, metaInfo RegisteredKeyValueStateBackendMetaInfo<N,S>, capacity int) in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable |
From |
To |
|
Change Parameter Type registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<N,SV>> to registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>> in method package create(stateDesc StateDescriptor<S,SV>, registerResult Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>>, backend RocksDBKeyedStateBackend<K>) : IS in class org.apache.flink.contrib.streaming.state.RocksDBMapState |
From |
To |
|
Change Parameter Type stateMetaInfo : RegisteredBroadcastBackendStateMetaInfo<K,V> to stateMetaInfo : RegisteredBroadcastStateBackendMetaInfo<K,V> in method public setStateMetaInfo(stateMetaInfo RegisteredBroadcastStateBackendMetaInfo<K,V>) : void in class org.apache.flink.runtime.state.BackendWritableBroadcastState |
From |
To |
|
Change Parameter Type stateMetaInfo : RegisteredBroadcastBackendStateMetaInfo<K,V> to stateMetaInfo : RegisteredBroadcastStateBackendMetaInfo<K,V> in method private HeapBroadcastState(stateMetaInfo RegisteredBroadcastStateBackendMetaInfo<K,V>, internalMap Map<K,V>) in class org.apache.flink.runtime.state.HeapBroadcastState |
From |
To |
|
Change Parameter Type registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<N,SV>> to registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>> in method package create(stateDesc StateDescriptor<S,SV>, registerResult Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>>, backend RocksDBKeyedStateBackend<K>) : IS in class org.apache.flink.contrib.streaming.state.RocksDBListState |
From |
To |
|
Change Parameter Type stateMetaInfo : RegisteredOperatorBackendStateMetaInfo<S> to stateMetaInfo : RegisteredOperatorStateBackendMetaInfo<S> in method package PartitionableListState(stateMetaInfo RegisteredOperatorStateBackendMetaInfo<S>) in class org.apache.flink.runtime.state.DefaultOperatorStateBackend.PartitionableListState |
From |
To |
|
Change Parameter Type registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<N,SV>> to registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>> in method package create(stateDesc StateDescriptor<S,SV>, registerResult Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>>, backend RocksDBKeyedStateBackend<K>) : IS in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState |
From |
To |
|
Change Variable Type metaInfo : RegisteredKeyedBackendStateMetaInfo<Integer,ArrayList<Integer>> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<Integer,ArrayList<Integer>> in method public checkCompatibleSerializationFormats() : void in class org.apache.flink.runtime.state.heap.StateTableSnapshotCompatibilityTest |
From |
To |
|
Change Variable Type registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<N,SV>> to registerResult : Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,SV>> in method public createInternalState(namespaceSerializer TypeSerializer<N>, stateDesc StateDescriptor<S,SV>) : IS in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Variable Type that : RegisteredKeyedBackendStateMetaInfo<?,?> to that : RegisteredKeyValueStateBackendMetaInfo<?,?> in method public equals(o Object) : boolean in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo |
From |
To |
|
Change Variable Type partitionedSnapshot : StateSnapshot.KeyGroupPartitionedSnapshot to partitionedSnapshot : StateSnapshot.StateKeyGroupWriter in method public testSerializerDuplicationInSnapshot() : void in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableTest |
From |
To |
|
Change Variable Type result : StateSnapshot.KeyGroupPartitionedSnapshot to result : StateSnapshot.StateKeyGroupWriter in method private testPartitionByKeyGroupForSize(testSize int, random Random) : void in class org.apache.flink.runtime.state.KeyGroupPartitionerTestBase |
From |
To |
|
Change Variable Type timerSerializer : TimerHeapInternalTimer.TimerSerializer<K,N> to timerSerializer : LegacyTimerSerializer<K,N> in method public writeTimersSnapshot(out DataOutputView) : void in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.AbstractInternalTimersSnapshotWriter |
From |
To |
|
Change Variable Type columnInfo : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<?,?>> to columnInfo : Tuple2<ColumnFamilyHandle,RegisteredStateMetaInfoBase> in method public getKeys(state String, namespace N) : Stream<K> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredBroadcastBackendStateMetaInfo<K,V> to restoredMetaInfo : RegisteredBroadcastStateBackendMetaInfo<K,V> in method public getBroadcastState(stateDescriptor MapStateDescriptor<K,V>) : BroadcastState<K,V> in class org.apache.flink.runtime.state.DefaultOperatorStateBackend |
From |
To |
|
Change Variable Type registeredKeyedBackendStateMetaInfo : RegisteredKeyedBackendStateMetaInfo<?,?> to registeredKeyedBackendStateMetaInfo : RegisteredKeyValueStateBackendMetaInfo<?,?> in method private restorePartitionedState(state Collection<KeyedStateHandle>) : void in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Variable Type metaInfo : RegisteredKeyedBackendStateMetaInfo<Integer,ArrayList<Integer>> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<Integer,ArrayList<Integer>> in method public testCopyOnWriteContracts() : void in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableTest |
From |
To |
|
Change Variable Type metaInfo : RegisteredKeyedBackendStateMetaInfo<Integer,Integer> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<Integer,Integer> in method public testSerializerDuplicationInSnapshot() : void in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableTest |
From |
To |
|
Change Variable Type keyGroupPartitionedSnapshot : StateSnapshot.KeyGroupPartitionedSnapshot to keyGroupPartitionedSnapshot : StateSnapshot.StateKeyGroupWriter in method private restoreStateTableFromSnapshot(stateTable StateTable<K,N,S>, snapshot StateSnapshot, keyGroupRange KeyGroupRange) : void in class org.apache.flink.runtime.state.heap.StateTableSnapshotCompatibilityTest |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredBroadcastBackendStateMetaInfo<?,?> to restoredMetaInfo : RegisteredBroadcastStateBackendMetaInfo<?,?> in method public testBroadcastStateMetaInfoSerialization() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type newMetaInfo : RegisteredKeyedBackendStateMetaInfo<N,V> to newMetaInfo : RegisteredKeyValueStateBackendMetaInfo<N,V> 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 stateTable : StateTable<K,?,?> to state : StateSnapshotRestore in method public numStateEntries(namespace Object) : int in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Variable Type kvState : Map.Entry<String,StateTable<K,?,?>> to kvState : Map.Entry<String,StateSnapshotRestore> 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 stateTable : StateTable<K,?,?> to snapshotRestore : StateSnapshotRestore in method private restorePartitionedState(state Collection<KeyedStateHandle>) : void in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Variable Type stateTable : StateTable<K,?,?> to registeredState : StateSnapshotRestore in method private restorePartitionedState(state Collection<KeyedStateHandle>) : void in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredKeyedBackendStateMetaInfo<?,?> to restoredMetaInfo : RegisteredKeyValueStateBackendMetaInfo<?,?> in method public testKeyedBackendSerializationProxyRoundtripWithSerializerSerializationFailures() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type stateTable : StateTable<K,?,?> to state : StateSnapshotRestore 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 stateInfo : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<?,?>> to stateInfo : Tuple2<ColumnFamilyHandle,RegisteredStateMetaInfoBase> in method private tryRegisterKvStateInformation(stateDesc StateDescriptor<?,S>, namespaceSerializer TypeSerializer<N>) : Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,S>> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Variable Type metaInfo : RegisteredKeyedBackendStateMetaInfo<Integer,ArrayList<Integer>> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<Integer,ArrayList<Integer>> in method public testRandomModificationsAndCopyOnWriteIsolation() : void in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableTest |
From |
To |
|
Change Variable Type metaInfo : RegisteredKeyedBackendStateMetaInfo<Integer,ArrayList<Integer>> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<Integer,ArrayList<Integer>> in method public testIncrementalRehash() : void in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableTest |
From |
To |
|
Change Variable Type other : RegisteredBroadcastBackendStateMetaInfo to other : RegisteredBroadcastStateBackendMetaInfo in method public equals(obj Object) : boolean in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo |
From |
To |
|
Change Variable Type registeredColumn : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<?,?>> to registeredColumn : Tuple2<ColumnFamilyHandle,RegisteredStateMetaInfoBase> in method private restoreKVStateMetaData() : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBFullRestoreOperation |
From |
To |
|
Change Variable Type timerSerializer : TimerHeapInternalTimer.TimerSerializer<K,N> to timerSerializer : LegacyTimerSerializer<K,N> in method public readTimersSnapshot(in DataInputView) : InternalTimersSnapshot<K,N> in class org.apache.flink.streaming.api.operators.InternalTimersSnapshotReaderWriters.AbstractInternalTimersSnapshotReader |
From |
To |
|
Change Variable Type tuple2 : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<?,?>> to tuple2 : Tuple2<ColumnFamilyHandle,RegisteredStateMetaInfoBase> in method public takeDBSnapShot() : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBFullSnapshotOperation |
From |
To |
|
Change Variable Type column : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<?,?>> to column : Tuple2<ColumnFamilyHandle,RegisteredStateMetaInfoBase> in method public numStateEntries() : int in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Variable Type partitionedSnapshot : StateSnapshot.KeyGroupPartitionedSnapshot to partitionedSnapshot : StateSnapshot.StateKeyGroupWriter in method protected performOperation() : SnapshotResult<KeyedStateHandle> in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend.HeapSnapshotStrategy.performSnapshot.ioCallable |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredKeyedBackendStateMetaInfo<?,?> to restoredMetaInfo : RegisteredKeyValueStateBackendMetaInfo<?,?> in method public testKeyedStateMetaInfoReadSerializerFailureResilience() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type metaInfo : RegisteredOperatorBackendStateMetaInfo<S> to metaInfo : RegisteredOperatorStateBackendMetaInfo<S> 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 metaInfo : RegisteredKeyedBackendStateMetaInfo<Integer,ArrayList<Integer>> to metaInfo : RegisteredKeyValueStateBackendMetaInfo<Integer,ArrayList<Integer>> in method public testPutGetRemoveContainsTransform() : void in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableTest |
From |
To |
|
Change Variable Type stateMetaInfoEntry : Map.Entry<String,Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<?,?>>> to stateMetaInfoEntry : Map.Entry<String,Tuple2<ColumnFamilyHandle,RegisteredStateMetaInfoBase>> in method package takeSnapshot() : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalSnapshotOperation |
From |
To |
|
Change Variable Type keyGroupReader : StateTableByKeyGroupReader to keyGroupReader : StateSnapshotKeyGroupReader in method private restoreStateTableFromSnapshot(stateTable StateTable<K,N,S>, snapshot StateSnapshot, keyGroupRange KeyGroupRange) : void in class org.apache.flink.runtime.state.heap.StateTableSnapshotCompatibilityTest |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredOperatorBackendStateMetaInfo<?> to restoredMetaInfo : RegisteredOperatorStateBackendMetaInfo<?> in method public restore(restoreSnapshots Collection<OperatorStateHandle>) : void in class org.apache.flink.runtime.state.DefaultOperatorStateBackend |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredOperatorBackendStateMetaInfo<?> to restoredMetaInfo : RegisteredOperatorStateBackendMetaInfo<?> in method public testOperatorStateMetaInfoReadSerializerFailureResilience() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type stateTable : StateTable<K,?,?> to state : StateSnapshotRestore in method public numStateEntries() : int in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Variable Type newMetaInfo : RegisteredKeyedBackendStateMetaInfo<N,S> to newMetaInfo : RegisteredKeyValueStateBackendMetaInfo<N,S> in method private tryRegisterKvStateInformation(stateDesc StateDescriptor<?,S>, namespaceSerializer TypeSerializer<N>) : Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,S>> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredOperatorBackendStateMetaInfo<?> to restoredMetaInfo : RegisteredOperatorStateBackendMetaInfo<?> in method public testOperatorStateMetaInfoSerialization() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredBroadcastBackendStateMetaInfo<?,?> to restoredMetaInfo : RegisteredBroadcastStateBackendMetaInfo<?,?> in method public restore(restoreSnapshots Collection<OperatorStateHandle>) : void in class org.apache.flink.runtime.state.DefaultOperatorStateBackend |
From |
To |
|
Change Variable Type registeredStateMetaInfoEntry : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<?,?>> to registeredStateMetaInfoEntry : Tuple2<ColumnFamilyHandle,RegisteredStateMetaInfoBase> in method private getOrRegisterColumnFamilyHandle(columnFamilyDescriptor ColumnFamilyDescriptor, columnFamilyHandle ColumnFamilyHandle, stateMetaInfoSnapshot StateMetaInfoSnapshot) : ColumnFamilyHandle in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBIncrementalRestoreOperation |
From |
To |
|
Change Variable Type restoredMetaInfo : RegisteredBroadcastBackendStateMetaInfo<?,?> to restoredMetaInfo : RegisteredBroadcastStateBackendMetaInfo<?,?> in method public testBroadcastStateMetaInfoReadSerializerFailureResilience() : void in class org.apache.flink.runtime.state.SerializationProxiesTest |
From |
To |
|
Change Variable Type columnMetaData : Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<?,?>> to columnMetaData : Tuple2<ColumnFamilyHandle,RegisteredStateMetaInfoBase> in method public dispose() : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Return Type RegisteredOperatorBackendStateMetaInfo<S> to RegisteredOperatorStateBackendMetaInfo<S> in method public deepCopy() : RegisteredOperatorStateBackendMetaInfo<S> in class org.apache.flink.runtime.state.RegisteredOperatorStateBackendMetaInfo |
From |
To |
|
Change Return Type RegisteredKeyedBackendStateMetaInfo<N,S> to RegisteredKeyValueStateBackendMetaInfo<N,S> in method public resolveKvStateCompatibility(restoredStateMetaInfoSnapshot StateMetaInfoSnapshot, newNamespaceSerializer TypeSerializer<N>, newStateDescriptor StateDescriptor<?,S>) : RegisteredKeyValueStateBackendMetaInfo<N,S> in class org.apache.flink.runtime.state.RegisteredKeyValueStateBackendMetaInfo |
From |
To |
|
Change Return Type RegisteredKeyedBackendStateMetaInfo<N,S> to RegisteredKeyValueStateBackendMetaInfo<N,S> in method public getMetaInfo() : RegisteredKeyValueStateBackendMetaInfo<N,S> in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable |
From |
To |
|
Change Return Type StateTableByKeyGroupReader to StateSnapshotKeyGroupReader in method package readerForVersion(stateTable StateTable<K,N,S>, version int) : StateSnapshotKeyGroupReader in class org.apache.flink.runtime.state.heap.StateTableByKeyGroupReaders |
From |
To |
|
Change Return Type RegisteredOperatorBackendStateMetaInfo<S> to RegisteredOperatorStateBackendMetaInfo<S> in method public getStateMetaInfo() : RegisteredOperatorStateBackendMetaInfo<S> in class org.apache.flink.runtime.state.DefaultOperatorStateBackend.PartitionableListState |
From |
To |
|
Change Return Type StateSnapshot.KeyGroupPartitionedSnapshot to StateSnapshot.StateKeyGroupWriter in method public partitionByKeyGroup() : StateSnapshot.StateKeyGroupWriter in class org.apache.flink.runtime.state.KeyGroupPartitioner |
From |
To |
|
Change Return Type KeyGroupedInternalPriorityQueue<T> to HeapPriorityQueueSet<T> in method public create(stateName String, byteOrderedElementSerializer TypeSerializer<T>) : HeapPriorityQueueSet<T> in class org.apache.flink.runtime.state.heap.HeapPriorityQueueSetFactory |
From |
To |
|
Change Return Type Tuple2<ColumnFamilyHandle,RegisteredKeyedBackendStateMetaInfo<N,S>> to Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,S>> in method private tryRegisterKvStateInformation(stateDesc StateDescriptor<?,S>, namespaceSerializer TypeSerializer<N>) : Tuple2<ColumnFamilyHandle,RegisteredKeyValueStateBackendMetaInfo<N,S>> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Return Type RegisteredBroadcastBackendStateMetaInfo<K,V> to RegisteredBroadcastStateBackendMetaInfo<K,V> in method public getStateMetaInfo() : RegisteredBroadcastStateBackendMetaInfo<K,V> in class org.apache.flink.runtime.state.BackendWritableBroadcastState |
From |
To |
|
Change Return Type KeyGroupPartitionedSnapshot to StateKeyGroupWriter in method public getKeyGroupWriter() : StateKeyGroupWriter in class org.apache.flink.runtime.state.heap.NestedMapsStateTable.NestedMapsStateTableSnapshot |
From |
To |
|
Change Return Type RegisteredKeyedBackendStateMetaInfo<N,S> to RegisteredKeyValueStateBackendMetaInfo<N,S> in method public getMetaInfo() : RegisteredKeyValueStateBackendMetaInfo<N,S> in class org.apache.flink.runtime.state.heap.StateTable |
From |
To |
|
Change Return Type KeyGroupPartitionedSnapshot to StateKeyGroupWriter in method public getKeyGroupWriter() : StateKeyGroupWriter in class org.apache.flink.runtime.state.StateSnapshot |
From |
To |
|
Change Return Type RegisteredBroadcastBackendStateMetaInfo<K,V> to RegisteredBroadcastStateBackendMetaInfo<K,V> in method public deepCopy() : RegisteredBroadcastStateBackendMetaInfo<K,V> in class org.apache.flink.runtime.state.RegisteredBroadcastStateBackendMetaInfo |
From |
To |
|
Change Return Type KeyGroupPartitionedSnapshot to StateKeyGroupWriter in method public getKeyGroupWriter() : StateKeyGroupWriter in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot |
From |
To |
|
Change Return Type RegisteredBroadcastBackendStateMetaInfo<K,V> to RegisteredBroadcastStateBackendMetaInfo<K,V> in method public getStateMetaInfo() : RegisteredBroadcastStateBackendMetaInfo<K,V> in class org.apache.flink.runtime.state.HeapBroadcastState |
From |
To |