|
Rename Parameter nextCpId : long to recoveryTimestamp : long in method public restoreState(stateBackend FsStateBackend, keySerializer TypeSerializer<K>, valueSerializer TypeSerializer<V>, defaultValue V, classLoader ClassLoader, recoveryTimestamp long) : FsHeapKvState<K,V> in class org.apache.flink.runtime.state.filesystem.FsHeapKvStateSnapshot |
From |
To |
|
Rename Parameter nextCpId : long to recoveryTimestamp : long in method public restoreState(taskState StreamTaskState, recoveryTimestamp long) : void in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator |
From |
To |
|
Rename Parameter nextCpId : long to recoveryTimestamp : long in method public restoreState(taskState StreamTaskState, recoveryTimestamp long) : void in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator |
From |
To |
|
Rename Parameter nextCheckpointId : long to recoveryTimestamp : long in method public restoreState(stateBackend Backend, keySerializer TypeSerializer<K>, valueSerializer TypeSerializer<V>, defaultValue V, classLoader ClassLoader, recoveryTimestamp long) : KvState<K,V,Backend> in class org.apache.flink.runtime.state.KvStateSnapshot |
From |
To |
|
Rename Parameter nextCpId : long to recoveryTimestamp : long in method public restoreState(state StreamTaskState, recoveryTimestamp long) : void in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator |
From |
To |
|
Rename Parameter checkpointId : long to checkpointTs : long in method public insertBatch(stateId String, conf DbBackendConfig, con Connection, insertStatement PreparedStatement, checkpointTs long, toInsert List<Tuple2<byte[],byte[]>>) : void in class org.apache.flink.contrib.streaming.state.MySqlAdapter |
From |
To |
|
Rename Parameter nextId : long to recoveryTs : long in method public cleanupFailedCheckpoints(stateId String, con Connection, checkpointTs long, recoveryTs long) : void in class org.apache.flink.contrib.streaming.state.MySqlAdapter |
From |
To |
|
Rename Parameter checkpointId : long to timestamp : long in method public add(next Entry<K,Optional<V>>, timestamp long) : void in class org.apache.flink.contrib.streaming.state.LazyDbKvState.BatchInserter |
From |
To |
|
Rename Parameter checkpointId : long to timestamp : long in method public flush(timestamp long) : void in class org.apache.flink.contrib.streaming.state.LazyDbKvState.BatchInserter |
From |
To |
|
Rename Parameter checkpointId : long to timestamp : long in method public snapshot(checkpointId long, timestamp long) : DbKvStateSnapshot<K,V> in class org.apache.flink.contrib.streaming.state.LazyDbKvState |
From |
To |
|
Rename Parameter nextCpId : long to recoveryTimestamp : long in method public restoreState(stateBackend MemoryStateBackend, keySerializer TypeSerializer<K>, valueSerializer TypeSerializer<V>, defaultValue V, classLoader ClassLoader, recoveryTimestamp long) : MemHeapKvState<K,V> in class org.apache.flink.runtime.state.memory.MemoryHeapKvStateSnapshot |
From |
To |
|
Rename Parameter nextCpId : long to recoveryTimestamp : long in method public restoreState(state StreamTaskState, recoveryTimestamp long) : void in class org.apache.flink.streaming.api.operators.StreamOperator |
From |
To |
|
Rename Parameter nextCpId : long to recoveryTimestamp : long in method public restoreState(taskState StreamTaskState, recoveryTimestamp long) : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator |
From |
To |
|
Rename Parameter checkpointId : long to checkpointTs : long in method public cleanupFailedCheckpoints(stateId String, con Connection, checkpointTs long, recoveryTs long) : void in class org.apache.flink.contrib.streaming.state.MySqlAdapter |
From |
To |
|
Rename Parameter checkpointId : long to checkpointTs : long in method private setKvInsertParams(stateId String, insertStatement PreparedStatement, checkpointTs long, key byte[], value byte[]) : void in class org.apache.flink.contrib.streaming.state.MySqlAdapter |
From |
To |
|
Rename Parameter nextCheckpointId : long to recoveryTimestamp : long in method public setOperatorState(op StatefulTask<?>, state StateHandle<?>, recoveryTimestamp long) : void in class org.apache.flink.runtime.state.StateUtils |
From |
To |
|
Rename Parameter checkpointId : long to checkpointTs : long in method public insertBatch(stateId String, conf DbBackendConfig, con Connection, insertStatement PreparedStatement, checkpointTs long, toInsert List<Tuple2<byte[],byte[]>>) : void in class org.apache.flink.contrib.streaming.state.DerbyAdapter |
From |
To |
|
Rename Parameter nextCpId : long to recoveryTimestamp : long in method public setInitialState(initialState SerializedValue<StateHandle<?>>, recoveryTimestamp long) : void in class org.apache.flink.runtime.executiongraph.Execution |
From |
To |
|
Rename Parameter nextId : long to nextTs : long in method public LazyDbKvState(kvStateId String, compact boolean, cons ShardedConnection, conf DbBackendConfig, keySerializer TypeSerializer<K>, valueSerializer TypeSerializer<V>, defaultValue V, nextTs long) in class org.apache.flink.contrib.streaming.state.LazyDbKvState |
From |
To |
|
Rename Parameter nextCpId : long to recoveryTimestamp : long in method public setInitialState(initialState StreamTaskStateList, recoveryTimestamp long) : void in class org.apache.flink.streaming.runtime.tasks.StreamTask |
From |
To |
|
Rename Parameter checkpointId : long to checkpointTimestamp : long in method public insertBatch(stateId String, conf DbBackendConfig, con Connection, insertStatement PreparedStatement, checkpointTimestamp long, toInsert List<Tuple2<byte[],byte[]>>) : void in class org.apache.flink.contrib.streaming.state.DbAdapter |
From |
To |
|
Rename Parameter nextCheckpointId : long to recoveryTimestamp : long in method public setInitialState(stateHandle T, recoveryTimestamp long) : void in class org.apache.flink.runtime.jobgraph.tasks.StatefulTask |
From |
To |
|
Rename Parameter lookupId : long to lookupTs : long in method public lookupKey(stateId String, lookupStatement PreparedStatement, key byte[], lookupTs long) : byte[] in class org.apache.flink.contrib.streaming.state.MySqlAdapter |
From |
To |
|
Rename Parameter nextCheckpointId : long to recoveryTimestamp : long in method public restoreState(state StreamTaskState, recoveryTimestamp long) : void in class org.apache.flink.streaming.api.operators.AbstractStreamOperator |
From |
To |
|
Rename Parameter checkpointId : long to checkpointTimestamp : long in method public DbKvStateSnapshot(kvStateId String, checkpointTimestamp long) in class org.apache.flink.contrib.streaming.state.LazyDbKvState.DbKvStateSnapshot |
From |
To |
|
Rename Parameter nextId : long to recoveryTimestamp : long in method public restoreState(stateBackend DbStateBackend, keySerializer TypeSerializer<K>, valueSerializer TypeSerializer<V>, defaultValue V, classLoader ClassLoader, recoveryTimestamp long) : LazyDbKvState<K,V> in class org.apache.flink.contrib.streaming.state.LazyDbKvState.DbKvStateSnapshot |
From |
To |
|
Rename Parameter nextCpId : long to recoveryTimestamp : long in method public TaskDeploymentDescriptor(jobID JobID, vertexID JobVertexID, executionId ExecutionAttemptID, taskName String, indexInSubtaskGroup int, numberOfSubtasks int, jobConfiguration Configuration, taskConfiguration Configuration, invokableClassName String, producedPartitions List<ResultPartitionDeploymentDescriptor>, inputGates List<InputGateDeploymentDescriptor>, requiredJarFiles List<BlobKey>, requiredClasspaths List<URL>, targetSlotNumber int, operatorState SerializedValue<StateHandle<?>>, recoveryTimestamp long) in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor |
From |
To |