|
Change Parameter Type function : WindowFunction<Type,Result,Key,Window> to function : WindowFunction<Iterable<Type>,Result,Key,Window> in method public AccumulatingKeyedTimePanes(keySelector KeySelector<Type,Key>, function WindowFunction<Iterable<Type>,Result,Key,Window>) in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes |
From |
To |
|
Change Parameter Type windowFunction : AllWindowFunction<IN,OUT,W> to windowFunction : AllWindowFunction<Iterable<IN>,OUT,W> in method public EvictingNonKeyedWindowOperator(windowAssigner WindowAssigner<? super IN,W>, windowSerializer TypeSerializer<W>, windowBufferFactory WindowBufferFactory<? super IN,? extends EvictingWindowBuffer<IN>>, windowFunction AllWindowFunction<Iterable<IN>,OUT,W>, trigger Trigger<? super IN,? super W>, evictor Evictor<? super IN,? super W>) in class org.apache.flink.streaming.runtime.operators.windowing.EvictingNonKeyedWindowOperator |
From |
To |
|
Change Parameter Type windowFunction : AllWindowFunction<IN,OUT,W> to windowFunction : AllWindowFunction<Iterable<IN>,OUT,W> in method public NonKeyedWindowOperator(windowAssigner WindowAssigner<? super IN,W>, windowSerializer TypeSerializer<W>, windowBufferFactory WindowBufferFactory<? super IN,? extends WindowBuffer<IN>>, windowFunction AllWindowFunction<Iterable<IN>,OUT,W>, trigger Trigger<? super IN,? super W>) in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator |
From |
To |
|
Change Parameter Type windowFunction : WindowFunction<IN,OUT,K,W> to windowFunction : WindowFunction<ACC,OUT,K,W> in method public WindowOperator(windowAssigner WindowAssigner<? super IN,W>, windowSerializer TypeSerializer<W>, keySelector KeySelector<IN,K>, keySerializer TypeSerializer<K>, windowStateDescriptor StateDescriptor<? extends MergingState<IN,ACC>>, windowFunction WindowFunction<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 function : WindowFunction<Type,Result,Key,Window> to function : WindowFunction<Iterable<Type>,Result,Key,Window> in method package WindowFunctionTraversal(function WindowFunction<Iterable<Type>,Result,Key,Window>, window TimeWindow, out Collector<Result>, contextOperator AbstractStreamOperator<Result>) in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes.WindowFunctionTraversal |
From |
To |
|
Change Parameter Type function : AllWindowFunction<T,R,W> to function : AllWindowFunction<Iterable<T>,R,W> in method public apply(function AllWindowFunction<Iterable<T>,R,W>, resultType TypeInformation<R>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.AllWindowedStream |
From |
To |
|
Change Parameter Type function : WindowFunction<T,R,K,W> to function : WindowFunction<Iterable<T>,R,K,W> in method public apply(function WindowFunction<Iterable<T>,R,K,W>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Parameter Type function : WindowFunction<T,R,K,W> to function : WindowFunction<Iterable<T>,R,K,W> in method public apply(function WindowFunction<Iterable<T>,R,K,W>, resultType TypeInformation<R>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Parameter Type windowFunction : WindowFunction<IN,OUT,K,W> to windowFunction : WindowFunction<Iterable<IN>,OUT,K,W> in method public EvictingWindowOperator(windowAssigner WindowAssigner<? super IN,W>, windowSerializer TypeSerializer<W>, keySelector KeySelector<IN,K>, keySerializer TypeSerializer<K>, windowStateDescriptor StateDescriptor<? extends ListState<StreamRecord<IN>>>, windowFunction WindowFunction<Iterable<IN>,OUT,K,W>, trigger Trigger<? super IN,? super W>, evictor Evictor<? super IN,? super W>) in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator |
From |
To |
|
Change Parameter Type function : AllWindowFunction<T,R,W> to function : AllWindowFunction<Iterable<T>,R,W> in method public apply(function AllWindowFunction<Iterable<T>,R,W>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.AllWindowedStream |
From |
To |
|
Change Parameter Type out : Collector<Tuple2<W,T>> to out : Collector<T> in method public apply(window W, input Iterable<T>, out Collector<T>) : void in class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction |
From |
To |
|
Change Parameter Type function : WindowFunction<IN,OUT,KEY,TimeWindow> to function : WindowFunction<Iterable<IN>,OUT,KEY,TimeWindow> in method public AccumulatingProcessingTimeWindowOperator(function WindowFunction<Iterable<IN>,OUT,KEY,TimeWindow>, keySelector KeySelector<IN,KEY>, keySerializer TypeSerializer<KEY>, valueSerializer TypeSerializer<IN>, windowLength long, windowSlide long) in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator |
From |
To |
|
Move Method public close() : void from class org.apache.flink.streaming.api.functions.windowing.ReduceWindowFunctionWithWindow to public close() : void from class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public open(parameters Configuration) : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingNonKeyedWindowOperatorTest.SumReducer to public open(parameters Configuration) : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public open(parameters Configuration) : void from class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest.SumReducer to public open(parameters Configuration) : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public apply(k K, window W, values Iterable<T>, out Collector<T>) : void from class org.apache.flink.streaming.api.functions.windowing.ReduceWindowFunction to public apply(window W, input Iterable<T>, out Collector<T>) : void from class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction |
From |
To |
|
Move Method public close() : void from class org.apache.flink.streaming.api.functions.windowing.ReduceAllWindowFunction to public close() : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public close() : void from class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperatorTest.SumReducer to public close() : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public close() : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingNonKeyedWindowOperatorTest.SumReducer to public close() : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public open(parameters Configuration) : void from class org.apache.flink.streaming.api.functions.windowing.ReduceAllWindowFunction to public open(parameters Configuration) : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public apply(k K, window W, values Iterable<T>, out Collector<Tuple2<W,T>>) : void from class org.apache.flink.streaming.api.functions.windowing.ReduceWindowFunctionWithWindow to public apply(window W, input Iterable<T>, out Collector<T>) : void from class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction |
From |
To |
|
Move Method public open(parameters Configuration) : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.SumReducer to public open(parameters Configuration) : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public open(parameters Configuration) : void from class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperatorTest.SumReducer to public open(parameters Configuration) : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public close() : void from class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest.SumReducer to public close() : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public close() : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.SumReducer to public close() : void from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public open(parameters Configuration) : void from class org.apache.flink.streaming.api.functions.windowing.ReduceWindowFunctionWithWindow to public open(parameters Configuration) : void from class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Method public apply(window W, values Iterable<T>, out Collector<T>) : void from class org.apache.flink.streaming.api.functions.windowing.ReduceAllWindowFunction to public apply(window W, input Iterable<T>, out Collector<T>) : void from class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction |
From |
To |
|
Move Attribute private reduceFunction : ReduceFunction<T> from class org.apache.flink.streaming.api.functions.windowing.ReduceWindowFunctionWithWindow to private reduceFunction : ReduceFunction<T> from class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction |
From |
To |
|
Move Attribute private closeCalled : AtomicInteger from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.SumReducer to private closeCalled : AtomicInteger from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Attribute private openCalled : boolean from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.SumReducer to private openCalled : boolean from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Attribute private reduceFunction : ReduceFunction<T> from class org.apache.flink.streaming.api.functions.windowing.ReduceAllWindowFunction to private reduceFunction : ReduceFunction<T> from class org.apache.flink.streaming.api.functions.windowing.ReduceIterableWindowFunction |
From |
To |
|
Move Attribute private openCalled : boolean from class org.apache.flink.streaming.runtime.operators.windowing.EvictingNonKeyedWindowOperatorTest.SumReducer to private openCalled : boolean from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Attribute private reduceFunction : ReduceFunction<T> from class org.apache.flink.streaming.api.functions.windowing.ReduceAllWindowFunction to private reduceFunction : ReduceFunction<T> from class org.apache.flink.streaming.api.functions.windowing.ReduceIterableAllWindowFunction |
From |
To |
|
Move Attribute private openCalled : boolean from class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest.SumReducer to private openCalled : boolean from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Attribute private openCalled : boolean from class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperatorTest.SumReducer to private openCalled : boolean from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Move Attribute private reduceFunction : ReduceFunction<T> from class org.apache.flink.streaming.api.functions.windowing.ReduceWindowFunctionWithWindow to private reduceFunction : ReduceFunction<T> from class org.apache.flink.streaming.api.functions.windowing.ReduceIterableWindowFunction |
From |
To |
|
Move Attribute private closeCalled : AtomicInteger from class org.apache.flink.streaming.runtime.operators.windowing.EvictingNonKeyedWindowOperatorTest.SumReducer to private closeCalled : AtomicInteger from class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperatorTest.RichSumReducer |
From |
To |
|
Change Variable Type operator : WindowOperator<String,Tuple2<String,Integer>,Tuple2<String,Integer>,TimeWindow> to operator : WindowOperator<String,Tuple2<String,Integer>,Tuple2<String,Integer>,Tuple2<String,Integer>,TimeWindow> in method public testTumblingEventTimeWindowsReduce() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest |
From |
To |
|
Change Variable Type context : Context to timestamp : long in method public restoreState(taskState StreamTaskState, recoveryTimestamp long) : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator |
From |
To |
|
Change Variable Type operator : WindowOperator<String,Tuple2<String,Integer>,Tuple2<String,Integer>,GlobalWindow> to operator : WindowOperator<String,Tuple2<String,Integer>,Tuple2<String,Integer>,Tuple2<String,Integer>,GlobalWindow> in method public testContinuousWatermarkTrigger() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest |
From |
To |
|
Change Variable Type inType : TypeInformation<T> to iterTypeInfo : TypeInformation<Iterable<T>> in method public apply(function AllWindowFunction<Iterable<T>,R,W>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.AllWindowedStream |
From |
To |
|
Change Variable Type operator : WindowOperator<String,Tuple2<String,Integer>,Tuple2<String,Integer>,GlobalWindow> to operator : WindowOperator<String,Tuple2<String,Integer>,Tuple2<String,Integer>,Tuple2<String,Integer>,GlobalWindow> in method public testCountTrigger() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperatorTest |
From |
To |
|
Change Variable Type keyWindows : Map<W,Context> to processingTimeTimers : Set<Timer<K,W>> in method public restoreState(taskState StreamTaskState, recoveryTimestamp long) : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator |
From |
To |
|
Change Variable Type inType : TypeInformation<T> to iterTypeInfo : TypeInformation<Iterable<T>> in method public apply(function WindowFunction<Iterable<T>,R,K,W>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Variable Type operator : WindowOperator<K,T,R,W> to operator : WindowOperator<K,T,Iterable<T>,R,W> in method public apply(function WindowFunction<Iterable<T>,R,K,W>, resultType TypeInformation<R>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Variable Type windowFunction : WindowFunction<IN,OUT,KEY,Window> to windowFunction : WindowFunction<Iterable<IN>,OUT,KEY,Window> in method protected createPanes(keySelector KeySelector<IN,KEY>, function Function) : AccumulatingKeyedTimePanes<IN,KEY,OUT> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator |
From |
To |
|
Change Variable Type wf : WindowFunction<T,R,K,TimeWindow> to wf : WindowFunction<Iterable<T>,R,K,TimeWindow> in method private createFastTimeOperatorIfValid(function Function, resultType TypeInformation<R>, functionName String) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Attribute Type windowBufferFactory : WindowBufferFactory<? super IN,? extends WindowBuffer<IN>> to windowStateDescriptor : StateDescriptor<? extends MergingState<IN,ACC>> in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator |
From |
To |
|
Change Attribute Type watermarkTimers : Map<Long,Set<Context>> to watermarkTimers : Set<Timer<K,W>> in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator |
From |
To |
|
Change Attribute Type function : WindowFunction<Type,Result,Key,Window> to function : WindowFunction<Iterable<Type>,Result,Key,Window> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes |
From |
To |
|
Change Attribute Type mockFunction : WindowFunction<String,String,String,TimeWindow> to mockFunction : WindowFunction<Iterable<String>,String,String,TimeWindow> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Attribute Type function : WindowFunction<Type,Result,Key,Window> to function : WindowFunction<Iterable<Type>,Result,Key,Window> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes.WindowFunctionTraversal |
From |
To |
|
Change Attribute Type processingTimeTimers : Map<Long,Set<Context>> to processingTimeTimers : Set<Timer<K,W>> in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator |
From |
To |
|
Change Attribute Type validatingIdentityFunction : WindowFunction<Integer,Integer,Integer,TimeWindow> to validatingIdentityFunction : WindowFunction<Iterable<Integer>,Integer,Integer,TimeWindow> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |