ceb64248daab04b01977ff02516696e4398d656e
Files Diff
- Added: 6
- Removed: 3
- Renamed: 0
- Modified: 64
Refactorings reported:
Refactoring Name | Occurences | ||
---|---|---|---|
Move Method | 1 | ||
Move Method public setTimestamp(timestamp long) : void from class org.apache.flink.streaming.api.operators.TimestampedCollector to public setTimestamp(timestamp long) : void from class org.apache.flink.streaming.runtime.streamrecord.StreamRecord | From | To | |
Rename Variable | 2 | ||
Rename Variable millis : long to tag : int in method public copy(source DataInputView, target DataOutputView) : void in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer | From | To | |
Rename Variable element : T to value : T in method public deserialize(reuse StreamElement, source DataInputView) : StreamElement in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer | From | To | |
Change Return Type | 10 | ||
Change Return Type long to Watermark in method public checkAndGetNextWatermark(lastElement T, extractedTimestamp long) : Watermark in class org.apache.flink.streaming.api.functions.AssignerWithPunctuatedWatermarks | From | To | |
Change Return Type long to Watermark in method public getCurrentWatermark() : Watermark in class org.apache.flink.streaming.api.functions.AssignerWithPeriodicWatermarks | From | To | |
Change Return Type long to Watermark in method public checkAndGetNextWatermark(lastElement Tuple2<Long,Boolean>, extractedTimestamp long) : Watermark in class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperatorTest.PunctuatedExtractor | From | To | |
Change Return Type long to Watermark in method public getCurrentWatermark() : Watermark in class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor | From | To | |
Change Return Type long to Watermark in method public checkAndGetNextWatermark(lastElement Tuple2<String,Integer>, extractedTimestamp long) : Watermark in class org.apache.flink.streaming.runtime.operators.windowing.WindowFoldITCase.Tuple2TimestampExtractor | From | To | |
Change Return Type TypeSerializer<StreamElement> to MultiplexingStreamRecordSerializer<T> in method public duplicate() : MultiplexingStreamRecordSerializer<T> in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer | From | To | |
Change Return Type long to Watermark in method public getCurrentWatermark() : Watermark in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperatorTest.LongExtractor | From | To | |
Change Return Type long to Watermark in method public checkAndGetNextWatermark(element Tuple2<String,Integer>, extractedTimestamp long) : Watermark in class org.apache.flink.streaming.runtime.operators.windowing.CoGroupJoinITCase.Tuple2TimestampExtractor | From | To | |
Change Return Type long to Watermark in method public checkAndGetNextWatermark(lastElement Tuple3<String,String,Integer>, extractedTimestamp long) : Watermark in class org.apache.flink.streaming.runtime.operators.windowing.CoGroupJoinITCase.Tuple3TimestampExtractor | From | To | |
Change Return Type long to Watermark in method public checkAndGetNextWatermark(lastElement Integer, extractedTimestamp long) : Watermark in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.LinearTimestamp | From | To | |
Rename Class | 1 | ||
Rename Class org.apache.flink.streaming.api.CoStreamTest renamed to org.apache.flink.streaming.api.CoStreamITCase | From | To | |
Rename Attribute | 2 | ||
Rename Attribute environemnt : StreamExecutionEnvironment to environment : StreamExecutionEnvironment in class org.apache.flink.streaming.api.graph.StreamGraph | From | To | |
Rename Attribute watermarkMultiplexingEnabled : boolean to owner : StreamSource<?,?> in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext | From | To | |
Change Variable Type | 3 | ||
Change Variable Type millis : long to tag : int in method public copy(source DataInputView, target DataOutputView) : void in class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer | From | To | |
Change Variable Type nextWatermark : long to nextWatermark : Watermark in method public processElement(element StreamRecord<T>) : void in class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator | From | To | |
Change Variable Type newWatermark : long to newWatermark : Watermark in method public trigger(timestamp long) : void in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator | From | To | |
Inline Variable | 2 | ||
Inline Variable checkpointLock : Object in method protected run() : void from class org.apache.flink.streaming.runtime.tasks.SourceStreamTask | From | To | |
Inline Variable element : T in method public deserialize(source DataInputView) : StreamElement from class org.apache.flink.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer | From | To | |
Change Attribute Type | 1 | ||
Change Attribute Type watermarkMultiplexingEnabled : boolean to owner : StreamSource<?,?> in class org.apache.flink.streaming.api.operators.StreamSource.ManualWatermarkContext | From | To | |
Rename Parameter | 2 | ||
Rename Parameter lockingObjectParam : Object to lockingObject : Object in method public NonTimestampContext(owner StreamSource<?,?>, lockingObject Object, output Output<StreamRecord<T>>) in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext | From | To | |
Rename Parameter outputParam : Output<StreamRecord<T>> to output : Output<StreamRecord<T>> in method public NonTimestampContext(owner StreamSource<?,?>, lockingObject Object, output Output<StreamRecord<T>>) in class org.apache.flink.streaming.api.operators.StreamSource.NonTimestampContext | From | To |