6cd8ceb10c841827cf89b74ecf5a0495a6933d53
Files Diff
- Added: 6
- Removed: 0
- Renamed: 0
- Modified: 22
Refactorings reported:
Refactoring Name | Occurences | ||
---|---|---|---|
Move And Rename Method | 1 | ||
Move And Rename Method public onProcessingTime(time long, window GlobalWindow, ctx TriggerContext) : TriggerResult from class org.apache.flink.streaming.examples.windowing.SessionWindowing.SessionTrigger to public onMerge(window GlobalWindow, ctx OnMergeContext) : TriggerResult from class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger | From | To | |
Change Parameter Type | 3 | ||
Change Parameter Type ctx : TriggerContext to ctx : OnMergeContext in method public onMerge(window GlobalWindow, ctx OnMergeContext) : TriggerResult in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger | From | To | |
Change Parameter Type windowStateDescriptor : StateDescriptor<? extends MergingState<IN,ACC>,?> to windowStateDescriptor : StateDescriptor<? extends AppendingState<IN,ACC>,?> in method public WindowOperator(windowAssigner WindowAssigner<? super IN,W>, windowSerializer TypeSerializer<W>, keySelector KeySelector<IN,K>, keySerializer TypeSerializer<K>, windowStateDescriptor StateDescriptor<? extends AppendingState<IN,ACC>,?>, windowFunction InternalWindowFunction<ACC,OUT,K,W>, trigger Trigger<? super IN,? super W>) in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator | From | To | |
Change Parameter Type window : GlobalWindow to window : W in method public clear(window W, ctx TriggerContext) : void in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger | From | To | |
Move Method | 1 | ||
Move Method public clear(window GlobalWindow, ctx TriggerContext) : void from class org.apache.flink.streaming.examples.windowing.SessionWindowing.SessionTrigger to public clear(window W, ctx TriggerContext) : void from class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger | From | To | |
Rename Variable | 3 | ||
Rename Variable first : ValueState<Boolean> to fireTimestamp : ReducingState<Long> in method public onElement(element Object, timestamp long, window W, ctx TriggerContext) : TriggerResult in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger | From | To | |
Rename Variable fireState : ValueState<Long> to fireTimestamp : ReducingState<Long> in method public onElement(element Object, timestamp long, window W, ctx TriggerContext) : TriggerResult in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger | From | To | |
Rename Variable fireState : ValueState<Long> to fireTimestamp : ReducingState<Long> in method public onProcessingTime(time long, window W, ctx TriggerContext) : TriggerResult in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger | From | To | |
Change Return Type | 2 | ||
Change Return Type StateDescriptor<? extends MergingState<IN,Iterable<IN>>,?> to StateDescriptor<? extends AppendingState<IN,Iterable<IN>>,?> in method public getStateDescriptor() : StateDescriptor<? extends AppendingState<IN,Iterable<IN>>,?> in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator | From | To | |
Change Return Type StateDescriptor<? extends MergingState<IN,ACC>,?> to StateDescriptor<? extends AppendingState<IN,ACC>,?> in method public getStateDescriptor() : StateDescriptor<? extends AppendingState<IN,ACC>,?> in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator | From | To | |
Rename Class | 1 | ||
Rename Class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest.ResultSortComparator renamed to org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest.Tuple2ResultSortComparator | From | To | |
Parameterize Variable | 1 | ||
Parameterize Variable currentTime : long to timestamp : long in method public onElement(element Object, timestamp long, window W, ctx TriggerContext) : TriggerResult in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger | From | To | |
Change Variable Type | 5 | ||
Change Variable Type fireState : ValueState<Long> to fireTimestamp : ReducingState<Long> in method public onProcessingTime(time long, window W, ctx TriggerContext) : TriggerResult in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger | From | To | |
Change Variable Type windowState : MergingState<IN,ACC> to windowState : AppendingState<IN,ACC> in method public processElement(element StreamRecord<IN>) : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator | From | To | |
Change Variable Type first : ValueState<Boolean> to fireTimestamp : ReducingState<Long> in method public onElement(element Object, timestamp long, window W, ctx TriggerContext) : TriggerResult in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger | From | To | |
Change Variable Type count : ValueState<Long> to count : ReducingState<Long> in method public onElement(element Object, timestamp long, window W, ctx TriggerContext) : TriggerResult in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger | From | To | |
Change Variable Type fireState : ValueState<Long> to fireTimestamp : ReducingState<Long> in method public onElement(element Object, timestamp long, window W, ctx TriggerContext) : TriggerResult in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger | From | To | |
Extract Interface | 1 | ||
Extract Interface org.apache.flink.api.common.state.AppendingState from classes [org.apache.flink.api.common.state.MergingState] | From | To | |
Change Attribute Type | 4 | ||
Change Attribute Type windowStateDescriptor : StateDescriptor<? extends MergingState<IN,ACC>,?> to windowStateDescriptor : StateDescriptor<? extends AppendingState<IN,ACC>,?> in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator | From | To | |
Change Attribute Type stateDesc : ValueStateDescriptor<Long> to stateDesc : ReducingStateDescriptor<Long> in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger | From | To | |
Change Attribute Type stateDesc : ValueStateDescriptor<Boolean> to stateDesc : ReducingStateDescriptor<Long> in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger | From | To | |
Change Attribute Type stateDesc : ValueStateDescriptor<Long> to stateDesc : ReducingStateDescriptor<Long> in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger | From | To |