|
Change Parameter Type function : WindowFunction<Iterable<T>,R,K,W> to function : WindowFunction<T,R,K,W> in method public apply(function WindowFunction<T,R,K,W>, resultType TypeInformation<R>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Parameter Type input : T to input : Iterable<T> in method public apply(window W, input Iterable<T>, out Collector<T>) : void in class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction |
From |
To |
|
Change Parameter Type function : WindowFunction<Iterable<T>,R,K,W> to function : WindowFunction<T,R,K,W> in method public apply(function WindowFunction<T,R,K,W>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Parameter Type function : AllWindowFunction<Iterable<T>,R,W> to function : AllWindowFunction<T,R,W> in method public apply(function AllWindowFunction<T,R,W>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.AllWindowedStream |
From |
To |
|
Change Parameter Type windowFunction : AllWindowFunction<Iterable<IN>,OUT,W> to windowFunction : AllWindowFunction<IN,OUT,W> in method public EvictingNonKeyedWindowOperator(windowAssigner WindowAssigner<? super IN,W>, windowSerializer TypeSerializer<W>, windowBufferFactory WindowBufferFactory<? super IN,? extends EvictingWindowBuffer<IN>>, windowFunction AllWindowFunction<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 : WindowFunction<ACC,OUT,K,W> to windowFunction : InternalWindowFunction<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 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 function : WindowFunction<Iterable<Type>,Result,Key,Window> to function : WindowFunction<Type,Result,Key,Window> in method public AccumulatingKeyedTimePanes(keySelector KeySelector<Type,Key>, function WindowFunction<Type,Result,Key,Window>) in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes |
From |
To |
|
Change Parameter Type function : WindowFunction<Iterable<IN>,OUT,KEY,TimeWindow> to function : WindowFunction<IN,OUT,KEY,TimeWindow> in method public AccumulatingProcessingTimeWindowOperator(function WindowFunction<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 |
|
Change Parameter Type function : WindowFunction<Iterable<Type>,Result,Key,Window> to function : WindowFunction<Type,Result,Key,Window> in method package WindowFunctionTraversal(function WindowFunction<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<Iterable<T>,R,W> to function : AllWindowFunction<T,R,W> in method public apply(function AllWindowFunction<T,R,W>, resultType TypeInformation<R>) : SingleOutputStreamOperator<R,?> in class org.apache.flink.streaming.api.datastream.AllWindowedStream |
From |
To |
|
Change Parameter Type windowFunction : AllWindowFunction<Iterable<IN>,OUT,W> to windowFunction : AllWindowFunction<IN,OUT,W> in method public NonKeyedWindowOperator(windowAssigner WindowAssigner<? super IN,W>, windowSerializer TypeSerializer<W>, windowBufferFactory WindowBufferFactory<? super IN,? extends WindowBuffer<IN>>, windowFunction AllWindowFunction<IN,OUT,W>, trigger Trigger<? super IN,? super W>) in class org.apache.flink.streaming.runtime.operators.windowing.NonKeyedWindowOperator |
From |
To |
|
Change Parameter Type input : T to input : Iterable<T> in method public apply(k K, window W, input Iterable<T>, out Collector<T>) : void in class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction |
From |
To |
|
Change Parameter Type windowFunction : WindowFunction<Iterable<IN>,OUT,K,W> to windowFunction : InternalWindowFunction<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 InternalWindowFunction<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 Attribute Type mockFunction : WindowFunction<Iterable<String>,String,String,TimeWindow> to mockFunction : WindowFunction<String,String,String,TimeWindow> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Attribute Type validatingIdentityFunction : WindowFunction<Iterable<Integer>,Integer,Integer,TimeWindow> to validatingIdentityFunction : WindowFunction<Integer,Integer,Integer,TimeWindow> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Attribute Type function : WindowFunction<Iterable<Type>,Result,Key,Window> to function : WindowFunction<Type,Result,Key,Window> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes.WindowFunctionTraversal |
From |
To |
|
Change Attribute Type function : WindowFunction<Iterable<Type>,Result,Key,Window> to function : WindowFunction<Type,Result,Key,Window> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes |
From |
To |