|
Change Parameter Type restoreState : Collection<KeyGroupsStateHandle> to restoreState : Collection<KeyedStateHandle> in method public restore(restoreState Collection<KeyedStateHandle>) : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Parameter Type keyedStateRawFuture : RunnableFuture<KeyGroupsStateHandle> to keyedStateRawFuture : RunnableFuture<KeyedStateHandle> in method public OperatorSnapshotResult(keyedStateManagedFuture RunnableFuture<KeyedStateHandle>, keyedStateRawFuture RunnableFuture<KeyedStateHandle>, operatorStateManagedFuture RunnableFuture<OperatorStateHandle>, operatorStateRawFuture RunnableFuture<OperatorStateHandle>) in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult |
From |
To |
|
Change Parameter Type rawKeyedState : KeyGroupsStateHandle to rawKeyedState : KeyedStateHandle in method public SubtaskState(legacyOperatorState ChainedStateHandle<StreamStateHandle>, managedOperatorState ChainedStateHandle<OperatorStateHandle>, rawOperatorState ChainedStateHandle<OperatorStateHandle>, managedKeyedState KeyedStateHandle, rawKeyedState KeyedStateHandle) in class org.apache.flink.runtime.checkpoint.SubtaskState |
From |
To |
|
Change Parameter Type stateHandles : Collection<KeyGroupsStateHandle> to stateHandles : Collection<KeyedStateHandle> in method private restoreOldSavepointKeyedState(stateHandles Collection<KeyedStateHandle>) : void in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Parameter Type keyGroupsStateHandles : Collection<KeyGroupsStateHandle> to keyedStateHandles : Collection<KeyedStateHandle> in method public StateInitializationContextImpl(restored boolean, operatorStateStore OperatorStateStore, keyedStateStore KeyedStateStore, keyedStateHandles Collection<KeyedStateHandle>, operatorStateHandles Collection<OperatorStateHandle>, closableRegistry CloseableRegistry) in class org.apache.flink.runtime.state.StateInitializationContextImpl |
From |
To |
|
Change Parameter Type restoreState : Collection<KeyGroupsStateHandle> to restoreState : Collection<KeyedStateHandle> in method private restoreOldSavepointKeyedState(restoreState Collection<KeyedStateHandle>) : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Parameter Type keyGroupsStateHandles : Collection<KeyGroupsStateHandle> to keyedStateHandles : Collection<KeyedStateHandle> in method public doRestore(keyedStateHandles Collection<KeyedStateHandle>) : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBRestoreOperation |
From |
To |
|
Change Parameter Type managedKeyedState : Collection<KeyGroupsStateHandle> to managedKeyedState : Collection<KeyedStateHandle> in method public OperatorStateHandles(operatorChainIndex int, legacyOperatorState StreamStateHandle, managedKeyedState Collection<KeyedStateHandle>, rawKeyedState Collection<KeyedStateHandle>, managedOperatorState Collection<OperatorStateHandle>, rawOperatorState Collection<OperatorStateHandle>) in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles |
From |
To |
|
Change Parameter Type managedKeyedState : KeyGroupsStateHandle to managedKeyedState : KeyedStateHandle in method public SubtaskState(legacyOperatorState ChainedStateHandle<StreamStateHandle>, managedOperatorState ChainedStateHandle<OperatorStateHandle>, rawOperatorState ChainedStateHandle<OperatorStateHandle>, managedKeyedState KeyedStateHandle, rawKeyedState KeyedStateHandle) in class org.apache.flink.runtime.checkpoint.SubtaskState |
From |
To |
|
Change Parameter Type allKeyGroupsHandles : Collection<KeyGroupsStateHandle> to allKeyGroupsHandles : Collection<KeyedStateHandle> in method private hasMigrationHandles(allKeyGroupsHandles Collection<KeyedStateHandle>) : boolean in class org.apache.flink.streaming.util.KeyedOneInputStreamOperatorTestHarness |
From |
To |
|
Change Parameter Type rawKeyedState : Collection<KeyGroupsStateHandle> to rawKeyedState : Collection<KeyedStateHandle> in method public TaskStateHandles(legacyOperatorState ChainedStateHandle<StreamStateHandle>, managedOperatorState List<Collection<OperatorStateHandle>>, rawOperatorState List<Collection<OperatorStateHandle>>, managedKeyedState Collection<KeyedStateHandle>, rawKeyedState Collection<KeyedStateHandle>) in class org.apache.flink.runtime.state.TaskStateHandles |
From |
To |
|
Change Parameter Type keyedStateHandleStream : KeyGroupsStateHandle to keyedStateHandleStream : KeyedStateHandle in method private createSubtaskStateFromSnapshotStateHandles(chainedNonPartitionedOperatorsState ChainedStateHandle<StreamStateHandle>, chainedOperatorStateBackend ChainedStateHandle<OperatorStateHandle>, chainedOperatorStateStream ChainedStateHandle<OperatorStateHandle>, keyedStateHandleBackend KeyedStateHandle, keyedStateHandleStream KeyedStateHandle) : SubtaskState in class org.apache.flink.streaming.runtime.tasks.StreamTask.AsyncCheckpointRunnable |
From |
To |
|
Change Parameter Type state : List<KeyGroupsStateHandle> to state : List<KeyedStateHandle> in method protected restoreKeyedBackend(keySerializer TypeSerializer<K>, numberOfKeyGroups int, keyGroupRange KeyGroupRange, state List<KeyedStateHandle>, env Environment) : AbstractKeyedStateBackend<K> in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Parameter Type keyedStateRawFuture : RunnableFuture<KeyGroupsStateHandle> to keyedStateRawFuture : RunnableFuture<KeyedStateHandle> in method public setKeyedStateRawFuture(keyedStateRawFuture RunnableFuture<KeyedStateHandle>) : void in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult |
From |
To |
|
Change Parameter Type state : KeyGroupsStateHandle to state : KeyedStateHandle in method protected restoreKeyedBackend(keySerializer TypeSerializer<K>, state KeyedStateHandle, env Environment) : AbstractKeyedStateBackend<K> in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Parameter Type allKeyGroupsHandles : Collection<KeyGroupsStateHandle> to keyedStateHandles : Collection<? extends KeyedStateHandle> in method public getKeyedStateHandles(keyedStateHandles Collection<? extends KeyedStateHandle>, subtaskKeyGroupRange KeyGroupRange) : List<KeyedStateHandle> in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Parameter Type keyedStateHandleBackend : KeyGroupsStateHandle to keyedStateHandleBackend : KeyedStateHandle in method private createSubtaskStateFromSnapshotStateHandles(chainedNonPartitionedOperatorsState ChainedStateHandle<StreamStateHandle>, chainedOperatorStateBackend ChainedStateHandle<OperatorStateHandle>, chainedOperatorStateStream ChainedStateHandle<OperatorStateHandle>, keyedStateHandleBackend KeyedStateHandle, keyedStateHandleStream KeyedStateHandle) : SubtaskState in class org.apache.flink.streaming.runtime.tasks.StreamTask.AsyncCheckpointRunnable |
From |
To |
|
Change Parameter Type snapshotRunnableFuture : RunnableFuture<KeyGroupsStateHandle> to snapshotRunnableFuture : RunnableFuture<KeyedStateHandle> in method private runSnapshot(snapshotRunnableFuture RunnableFuture<KeyedStateHandle>) : KeyedStateHandle in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Parameter Type in : KeyGroupsStateHandle to in : T in method private transform(in T) : List<T> in class org.apache.flink.runtime.state.TaskStateHandles |
From |
To |
|
Change Parameter Type actualPartitionedKeyGroupState : Collection<KeyGroupsStateHandle> to actualPartitionedKeyGroupState : Collection<? extends KeyedStateHandle> in method public compareKeyedState(expectPartitionedKeyGroupState Collection<KeyGroupsStateHandle>, actualPartitionedKeyGroupState Collection<? extends KeyedStateHandle>) : void in class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorTest |
From |
To |
|
Change Parameter Type managedKeyedState : Collection<KeyGroupsStateHandle> to managedKeyedState : Collection<KeyedStateHandle> in method public TaskStateHandles(legacyOperatorState ChainedStateHandle<StreamStateHandle>, managedOperatorState List<Collection<OperatorStateHandle>>, rawOperatorState List<Collection<OperatorStateHandle>>, managedKeyedState Collection<KeyedStateHandle>, rawKeyedState Collection<KeyedStateHandle>) in class org.apache.flink.runtime.state.TaskStateHandles |
From |
To |
|
Change Parameter Type state : KeyGroupsStateHandle to state : KeyedStateHandle in method protected restoreKeyedBackend(keySerializer TypeSerializer<K>, state KeyedStateHandle) : AbstractKeyedStateBackend<K> in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Parameter Type keyedStateManagedFuture : RunnableFuture<KeyGroupsStateHandle> to keyedStateManagedFuture : RunnableFuture<KeyedStateHandle> in method public setKeyedStateManagedFuture(keyedStateManagedFuture RunnableFuture<KeyedStateHandle>) : void in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult |
From |
To |
|
Change Parameter Type keyedStateManagedFuture : RunnableFuture<KeyGroupsStateHandle> to keyedStateManagedFuture : RunnableFuture<KeyedStateHandle> in method public OperatorSnapshotResult(keyedStateManagedFuture RunnableFuture<KeyedStateHandle>, keyedStateRawFuture RunnableFuture<KeyedStateHandle>, operatorStateManagedFuture RunnableFuture<OperatorStateHandle>, operatorStateRawFuture RunnableFuture<OperatorStateHandle>) in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult |
From |
To |
|
Change Parameter Type restoredState : Collection<KeyGroupsStateHandle> to restoredState : Collection<KeyedStateHandle> in method public restore(restoredState Collection<KeyedStateHandle>) : void in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Parameter Type state : Collection<KeyGroupsStateHandle> to state : Collection<KeyedStateHandle> in method private restorePartitionedState(state Collection<KeyedStateHandle>) : void in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Parameter Type keyGroupsStateHandles : Collection<KeyGroupsStateHandle> to keyedStateHandles : Collection<KeyedStateHandle> in method public isOldSavepointKeyedState(keyedStateHandles Collection<KeyedStateHandle>) : boolean in class org.apache.flink.migration.MigrationUtil |
From |
To |
|
Change Parameter Type rawKeyedState : Collection<KeyGroupsStateHandle> to rawKeyedState : Collection<KeyedStateHandle> in method public OperatorStateHandles(operatorChainIndex int, legacyOperatorState StreamStateHandle, managedKeyedState Collection<KeyedStateHandle>, rawKeyedState Collection<KeyedStateHandle>, managedOperatorState Collection<OperatorStateHandle>, rawOperatorState Collection<OperatorStateHandle>) in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles |
From |
To |
|
Change Variable Type ioCallable : AbstractAsyncIOCallable<KeyGroupsStateHandle,CheckpointStreamFactory.CheckpointStateOutputStream> to ioCallable : AbstractAsyncIOCallable<KeyedStateHandle,CheckpointStreamFactory.CheckpointStateOutputStream> in method public snapshot(checkpointId long, timestamp long, streamFactory CheckpointStreamFactory, checkpointOptions CheckpointOptions) : RunnableFuture<KeyedStateHandle> in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Variable Type rawKeyedStateHandle : KeyGroupsStateHandle to rawKeyedStateHandle : KeyedStateHandle in method public testAsyncCheckpointingConcurrentCloseAfterAcknowledge() : void in class org.apache.flink.streaming.runtime.tasks.StreamTaskTest |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testMapStateRestoreWithWrongSerializers() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type snapshot : RunnableFuture<KeyGroupsStateHandle> to snapshot : RunnableFuture<KeyedStateHandle> in method public testDismissingSnapshot() : void in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendTest |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testReducingStateRestoreWithWrongSerializers() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type keyedStateHandleBackend : KeyGroupsStateHandle to keyedStateHandleBackend : KeyedStateHandle in method public run() : void in class org.apache.flink.streaming.runtime.tasks.StreamTask.AsyncCheckpointRunnable |
From |
To |
|
Change Variable Type snapshot : RunnableFuture<KeyGroupsStateHandle> to snapshot : RunnableFuture<KeyedStateHandle> in method public testReleasingSnapshotAfterBackendClosed() : void in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendTest |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testMapState() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type keyedStateStream : KeyGroupsStateHandle to keyedStateStream : KeyedStateHandle in method private serializeSubtaskState(subtaskState SubtaskState, dos DataOutputStream) : void in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer |
From |
To |
|
Change Variable Type task : AsyncStoppableTaskWithCallback<KeyGroupsStateHandle> to task : AsyncStoppableTaskWithCallback<KeyedStateHandle> in method public snapshot(checkpointId long, timestamp long, streamFactory CheckpointStreamFactory, checkpointOptions CheckpointOptions) : RunnableFuture<KeyedStateHandle> in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend |
From |
To |
|
Change Variable Type serializedKeyGroupStates : KeyGroupsStateHandle to serializedKeyGroupStates : KeyedStateHandle in method public testSetState() : void in class org.apache.flink.runtime.checkpoint.CheckpointStateRestoreTest |
From |
To |
|
Change Variable Type snapshot : RunnableFuture<KeyGroupsStateHandle> to snapshot : RunnableFuture<KeyedStateHandle> in method public testAsyncSnapshot() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type secondHalfKeyGroupStates : List<KeyGroupsStateHandle> to secondHalfKeyGroupStates : List<KeyedStateHandle> in method public testKeyGroupSnapshotRestore() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type snapshot : KeyGroupsStateHandle to snapshot : KeyedStateHandle in method public testQueryableStateRegistration() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type localRawKeyGroupState : List<KeyGroupsStateHandle> to localRawKeyGroupState : List<KeyedStateHandle> in method public initializeState(operatorStateHandles OperatorStateHandles) : void in class org.apache.flink.streaming.util.AbstractStreamOperatorTestHarness |
From |
To |
|
Change Variable Type snapshot2 : KeyGroupsStateHandle to snapshot2 : KeyedStateHandle in method public testMapState() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type snapshotFuture : RunnableFuture<KeyGroupsStateHandle> to snapshotFuture : RunnableFuture<KeyedStateHandle> in method public testCleanupOfSnapshotsInFailureCase() : void in class org.apache.flink.contrib.streaming.state.RocksDBAsyncSnapshotTest |
From |
To |
|
Change Variable Type snapshot : KeyGroupsStateHandle to snapshot : KeyedStateHandle in method public testKryoRegisteringRestoreResilienceWithDefaultSerializer() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type keyedStateHandlesRaw : Collection<KeyGroupsStateHandle> to keyedStateHandlesRaw : Collection<KeyedStateHandle> in method public initializeState(stateHandles OperatorStateHandles) : void in class org.apache.flink.streaming.api.operators.AbstractStreamOperator |
From |
To |
|
Change Variable Type keyGroupsStateHandle : KeyGroupsStateHandle to keyedStateHandle : KeyedStateHandle in method public testCompletingSnapshot() : void in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendTest |
From |
To |
|
Change Variable Type handle : KeyGroupsStateHandle to handle : KeyedStateHandle in method public setUp() : void in class org.apache.flink.streaming.api.operators.StateInitializationContextImplTest |
From |
To |
|
Change Variable Type snapshot2 : KeyGroupsStateHandle to snapshot2 : KeyedStateHandle in method public testKryoRegisteringRestoreResilienceWithRegisteredSerializer() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type futureKeyGroupStateHandle : RunnableFuture<KeyGroupsStateHandle> to futureKeyedStateHandle : RunnableFuture<KeyedStateHandle> in method public testFailingBackendSnapshotMethod() : void in class org.apache.flink.streaming.api.operators.AbstractStreamOperatorTest |
From |
To |
|
Change Variable Type handle : KeyGroupsStateHandle to handle : KeyedStateHandle in method private hasMigrationHandles(allKeyGroupsHandles Collection<KeyedStateHandle>) : boolean in class org.apache.flink.streaming.util.KeyedOneInputStreamOperatorTestHarness |
From |
To |
|
Change Variable Type rawKeyedState : Collection<KeyGroupsStateHandle> to rawKeyedState : Collection<KeyedStateHandle> in method public repackageState(handles OperatorStateHandles...) : OperatorStateHandles in class org.apache.flink.streaming.util.AbstractStreamOperatorTestHarness |
From |
To |
|
Change Variable Type keyGroupStateRaw : Collection<KeyGroupsStateHandle> to keyGroupStateRaw : Collection<KeyedStateHandle> in method private testRestoreLatestCheckpointedStateWithChangingParallelism(scaleOut boolean) : void in class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorTest |
From |
To |
|
Change Variable Type managedKeyedState : Collection<KeyGroupsStateHandle> to managedKeyedState : Collection<KeyedStateHandle> in method public repackageState(handles OperatorStateHandles...) : OperatorStateHandles in class org.apache.flink.streaming.util.AbstractStreamOperatorTestHarness |
From |
To |
|
Change Variable Type keyedStateHandleStream : KeyGroupsStateHandle to keyedStateHandleStream : KeyedStateHandle in method public run() : void in class org.apache.flink.streaming.runtime.tasks.StreamTask.AsyncCheckpointRunnable |
From |
To |
|
Change Variable Type snapshot : RunnableFuture<KeyGroupsStateHandle> to snapshot : RunnableFuture<KeyedStateHandle> in method public testAsyncSnapshotCancellation() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type mergedRawKeyedState : List<KeyGroupsStateHandle> to mergedRawKeyedState : List<KeyedStateHandle> in method public repackageState(handles OperatorStateHandles...) : OperatorStateHandles in class org.apache.flink.streaming.util.AbstractStreamOperatorTestHarness |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testReducingState() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type newKeyedStatesBackend : List<KeyGroupsStateHandle> to newKeyedStatesBackend : List<KeyedStateHandle> in method private assignTaskStatesToOperatorInstances(taskState TaskState, executionJobVertex ExecutionJobVertex) : void in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type keyGroupStateFromBackend : List<KeyGroupsStateHandle> to keyedStateFromBackend : List<KeyedStateHandle> in method private createTask(taskConfig Configuration, state StreamStateHandle, mode int) : Task in class org.apache.flink.streaming.runtime.tasks.InterruptSensitiveRestoreTest |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testValueStateRestoreWithWrongSerializers() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type parallelKeyedStateStream : List<KeyGroupsStateHandle> to parallelKeyedStateStream : List<KeyedStateHandle> in method private assignTaskStatesToOperatorInstances(taskState TaskState, executionJobVertex ExecutionJobVertex) : void in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type keyGroupStatesList : List<KeyGroupsStateHandle> to keyGroupStatesList : List<KeyedStateHandle> in method public initializeStateFromLegacyCheckpoint(checkpointFilename String) : void in class org.apache.flink.streaming.util.AbstractStreamOperatorTestHarness |
From |
To |
|
Change Variable Type subtaskKeyGroupStates : List<KeyGroupsStateHandle> to subtaskKeyedStateHandles : List<KeyedStateHandle> in method public getKeyedStateHandles(keyedStateHandles Collection<? extends KeyedStateHandle>, subtaskKeyGroupRange KeyGroupRange) : List<KeyedStateHandle> in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type keyGroupsStateHandles : List<KeyGroupsStateHandle> to keyedStateHandles : List<KeyedStateHandle> in method public setUp() : void in class org.apache.flink.streaming.api.operators.StateInitializationContextImplTest |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testListState() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testListStateRestoreWithWrongSerializers() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type keyedStateBackend : KeyGroupsStateHandle to keyedStateBackend : KeyedStateHandle in method private assignTaskStatesToOperatorInstances(taskState TaskState, executionJobVertex ExecutionJobVertex) : void in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type snapshot2 : KeyGroupsStateHandle to snapshot2 : KeyedStateHandle in method public testReducingState() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type oldKeyedStatesBackend : KeyGroupsStateHandle to oldKeyedStatesBackend : KeyedStateHandle in method private assignTaskStatesToOperatorInstances(taskState TaskState, executionJobVertex ExecutionJobVertex) : void in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type mergedManagedKeyedState : List<KeyGroupsStateHandle> to mergedManagedKeyedState : List<KeyedStateHandle> in method public repackageState(handles OperatorStateHandles...) : OperatorStateHandles in class org.apache.flink.streaming.util.AbstractStreamOperatorTestHarness |
From |
To |
|
Change Variable Type parallelKeyedStatesBackend : List<KeyGroupsStateHandle> to parallelKeyedStatesBackend : List<KeyedStateHandle> in method private assignTaskStatesToOperatorInstances(taskState TaskState, executionJobVertex ExecutionJobVertex) : void in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type keyGroupsStateHandle : KeyGroupsStateHandle to keyedStateHandle : KeyedStateHandle in method public doRestore(keyedStateHandles Collection<KeyedStateHandle>) : void in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend.RocksDBRestoreOperation |
From |
To |
|
Change Variable Type keyedStateBackend : KeyGroupsStateHandle to keyedStateBackend : KeyedStateHandle in method private deserializeSubtaskState(dis DataInputStream) : SubtaskState in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer |
From |
To |
|
Change Variable Type keyedManaged : KeyGroupsStateHandle to keyedManaged : KeyedStateHandle in method public snapshot(checkpointId long, timestamp long) : OperatorStateHandles in class org.apache.flink.streaming.util.AbstractStreamOperatorTestHarness |
From |
To |
|
Change Variable Type keyedManagedStateHandle : KeyGroupsStateHandle to keyedManagedStateHandle : KeyedStateHandle in method public testCancelAndCleanup() : void in class org.apache.flink.streaming.api.operators.OperatorSnapshotResultTest |
From |
To |
|
Change Variable Type stateHandle : KeyGroupsStateHandle to stateHandle : KeyedStateHandle in method public testAsyncSnapshot() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type keyGroupsStateHandle : KeyGroupsStateHandle to keyedStateHandle : KeyedStateHandle in method public compareKeyedState(expectPartitionedKeyGroupState Collection<KeyGroupsStateHandle>, actualPartitionedKeyGroupState Collection<? extends KeyedStateHandle>) : void in class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorTest |
From |
To |
|
Change Variable Type keyedRawStateHandle : KeyGroupsStateHandle to keyedRawStateHandle : KeyedStateHandle in method public testCancelAndCleanup() : void in class org.apache.flink.streaming.api.operators.OperatorSnapshotResultTest |
From |
To |
|
Change Variable Type ioCallable : AbstractAsyncIOCallable<KeyGroupsStateHandle,CheckpointStreamFactory.CheckpointStateOutputStream> to ioCallable : AbstractAsyncIOCallable<KeyedStateHandle,CheckpointStreamFactory.CheckpointStateOutputStream> in method public snapshot(checkpointId long, timestamp long, streamFactory CheckpointStreamFactory, checkpointOptions CheckpointOptions) : RunnableFuture<KeyedStateHandle> in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend |
From |
To |
|
Change Variable Type snapshot : KeyGroupsStateHandle to snapshot : KeyedStateHandle in method public testKryoRegisteringRestoreResilienceWithRegisteredType() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type snapshot : RunnableFuture<KeyGroupsStateHandle> to snapshot : RunnableFuture<KeyedStateHandle> in method public testDismissingSnapshotNotRunnable() : void in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendTest |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testMultipleValueStates() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type managedKeyedStateHandle : KeyGroupsStateHandle to managedKeyedStateHandle : KeyedStateHandle in method public testAsyncCheckpointingConcurrentCloseAfterAcknowledge() : void in class org.apache.flink.streaming.runtime.tasks.StreamTaskTest |
From |
To |
|
Change Variable Type localManagedKeyGroupState : List<KeyGroupsStateHandle> to localManagedKeyGroupState : List<KeyedStateHandle> in method public initializeState(operatorStateHandles OperatorStateHandles) : void in class org.apache.flink.streaming.util.AbstractStreamOperatorTestHarness |
From |
To |
|
Change Variable Type result : List<KeyGroupsStateHandle> to result : List<KeyedStateHandle> in method public initializeState(operatorStateHandles OperatorStateHandles) : void in class org.apache.flink.streaming.util.KeyedOneInputStreamOperatorTestHarness |
From |
To |
|
Change Variable Type oldKeyedStatesStream : KeyGroupsStateHandle to oldKeyedStatesStream : KeyedStateHandle in method private assignTaskStatesToOperatorInstances(taskState TaskState, executionJobVertex ExecutionJobVertex) : void in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type intersection : KeyGroupsStateHandle to intersectedKeyedStateHandle : KeyedStateHandle in method public getKeyedStateHandles(keyedStateHandles Collection<? extends KeyedStateHandle>, subtaskKeyGroupRange KeyGroupRange) : List<KeyedStateHandle> in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type keyGroupsStateHandles : List<KeyGroupsStateHandle> to keyedStateHandles : List<KeyedStateHandle> in method private createTask(taskConfig Configuration, state StreamStateHandle, mode int) : Task in class org.apache.flink.streaming.runtime.tasks.InterruptSensitiveRestoreTest |
From |
To |
|
Change Variable Type keyedRaw : KeyGroupsStateHandle to keyedRaw : KeyedStateHandle in method public snapshot(checkpointId long, timestamp long) : OperatorStateHandles in class org.apache.flink.streaming.util.AbstractStreamOperatorTestHarness |
From |
To |
|
Change Variable Type keyedStateManagedFuture : RunnableFuture<KeyGroupsStateHandle> to keyedStateManagedFuture : RunnableFuture<KeyedStateHandle> in method public testCancelAndCleanup() : void in class org.apache.flink.streaming.api.operators.OperatorSnapshotResultTest |
From |
To |
|
Change Variable Type keyedStateBackend : KeyGroupsStateHandle to keyedStateBackend : KeyedStateHandle in method private serializeSubtaskState(subtaskState SubtaskState, dos DataOutputStream) : void in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer |
From |
To |
|
Change Variable Type rawKeyedStateHandle : KeyGroupsStateHandle to rawKeyedStateHandle : KeyedStateHandle in method public testAsyncCheckpointingConcurrentCloseBeforeAcknowledge() : void in class org.apache.flink.streaming.runtime.tasks.StreamTaskTest |
From |
To |
|
Change Variable Type managedKeyedState : Collection<KeyGroupsStateHandle> to managedKeyedState : Collection<KeyedStateHandle> in method public initializeState(operatorStateHandles OperatorStateHandles) : void in class org.apache.flink.streaming.util.KeyedOneInputStreamOperatorTestHarness |
From |
To |
|
Change Variable Type snapshot2 : KeyGroupsStateHandle to snapshot2 : KeyedStateHandle in method public testKryoRegisteringRestoreResilienceWithDefaultSerializer() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type actualPartitionedKeyGroupState : Collection<KeyGroupsStateHandle> to actualPartitionedKeyGroupState : Collection<KeyedStateHandle> in method public verifyStateRestore(jobVertexID JobVertexID, executionJobVertex ExecutionJobVertex, keyGroupPartitions List<KeyGroupRange>) : void in class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorTest |
From |
To |
|
Change Variable Type snapshot : KeyGroupsStateHandle to snapshot : KeyedStateHandle in method public testKeyGroupSnapshotRestore() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type snapshot : RunnableFuture<KeyGroupsStateHandle> to snapshot : RunnableFuture<KeyedStateHandle> in method public testRunningSnapshotAfterBackendClosed() : void in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendTest |
From |
To |
|
Change Variable Type managedKeyedStateHandle : KeyGroupsStateHandle to managedKeyedStateHandle : KeyedStateHandle in method public testAsyncCheckpointingConcurrentCloseBeforeAcknowledge() : void in class org.apache.flink.streaming.runtime.tasks.StreamTaskTest |
From |
To |
|
Change Variable Type keyedStateRawFuture : RunnableFuture<KeyGroupsStateHandle> to keyedStateRawFuture : RunnableFuture<KeyedStateHandle> in method public testCancelAndCleanup() : void in class org.apache.flink.streaming.api.operators.OperatorSnapshotResultTest |
From |
To |
|
Change Variable Type snapshot2 : KeyGroupsStateHandle to snapshot2 : KeyedStateHandle in method public testFoldingState() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type snapshot : KeyGroupsStateHandle to snapshot : KeyedStateHandle in method public testEmptyStateCheckpointing() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type keyedStateStream : KeyGroupsStateHandle to keyedStateStream : KeyedStateHandle in method private assignTaskStatesToOperatorInstances(taskState TaskState, executionJobVertex ExecutionJobVertex) : void in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type snapshot2 : KeyGroupsStateHandle to snapshot2 : KeyedStateHandle in method public testListState() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type keyedSnapshotRunnable : RunnableFuture<KeyGroupsStateHandle> to keyedSnapshotRunnable : RunnableFuture<KeyedStateHandle> in method public snapshotLegacy(checkpointId long, timestamp long) : StreamStateHandle in class org.apache.flink.streaming.util.KeyedOneInputStreamOperatorTestHarness |
From |
To |
|
Change Variable Type snapshot2 : KeyGroupsStateHandle to snapshot2 : KeyedStateHandle in method public testValueState() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type newKeyedStateStream : List<KeyGroupsStateHandle> to newKeyedStateStream : List<KeyedStateHandle> in method private assignTaskStatesToOperatorInstances(taskState TaskState, executionJobVertex ExecutionJobVertex) : void in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type storedKeyGroup : KeyGroupsStateHandle to keyedStateHandle : KeyedStateHandle in method public getKeyedStateHandles(keyedStateHandles Collection<? extends KeyedStateHandle>, subtaskKeyGroupRange KeyGroupRange) : List<KeyedStateHandle> in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testValueState() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type snapshot : RunnableFuture<KeyGroupsStateHandle> to snapshot : RunnableFuture<KeyedStateHandle> in method public testCompletingSnapshot() : void in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendTest |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testValueStateNullUpdate() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type snapshot : KeyGroupsStateHandle to snapshot : KeyedStateHandle in method public testKryoRegisteringRestoreResilienceWithRegisteredSerializer() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type keyedStateStream : KeyGroupsStateHandle to keyedStateStream : KeyedStateHandle in method private deserializeSubtaskState(dis DataInputStream) : SubtaskState in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer |
From |
To |
|
Change Variable Type keyGroupStateFromStream : List<KeyGroupsStateHandle> to keyedStateFromStream : List<KeyedStateHandle> in method private createTask(taskConfig Configuration, state StreamStateHandle, mode int) : Task in class org.apache.flink.streaming.runtime.tasks.InterruptSensitiveRestoreTest |
From |
To |
|
Change Variable Type snapshot : RunnableFuture<KeyGroupsStateHandle> to snapshot : RunnableFuture<KeyedStateHandle> in method public testCancelRunningSnapshot() : void in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendTest |
From |
To |
|
Change Variable Type firstHalfKeyGroupStates : List<KeyGroupsStateHandle> to firstHalfKeyGroupStates : List<KeyedStateHandle> in method public testKeyGroupSnapshotRestore() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |
|
Change Variable Type snapshot1 : KeyGroupsStateHandle to snapshot1 : KeyedStateHandle in method public testFoldingState() : void in class org.apache.flink.runtime.state.StateBackendTestBase |
From |
To |