|
Rename Method public mapWindow(function WindowFunction<T,R,W>) : DataStream<R> renamed to public apply(function AllWindowFunction<T,R,W>, resultType TypeInformation<R>) : DataStream<R> in class org.apache.flink.streaming.api.datastream.AllWindowedStream |
From |
To |
|
Rename Method public evaluate(window W, values Iterable<T>, out Collector<T>) : void renamed to public apply(k K, window W, values Iterable<T>, out Collector<T>) : void in class org.apache.flink.streaming.api.functions.windowing.ReduceWindowFunction |
From |
To |
|
Rename Method public evaluate(integer Integer, window TimeWindow, values Iterable<Integer>, out Collector<Integer>) : void renamed to public apply(integer Integer, window TimeWindow, values Iterable<Integer>, out Collector<Integer>) : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest.FailingFunction |
From |
To |
|
Rename Method public evaluate(k K, window W, values Iterable<T>, out Collector<Tuple2<W,T>>) : void renamed to public apply(k K, window W, values Iterable<T>, out Collector<Tuple2<W,T>>) : void in class org.apache.flink.streaming.api.functions.windowing.ReduceWindowFunctionWithWindow |
From |
To |
|
Rename Method public evaluate(key Long, window Window, values Iterable<Tuple2<Long,Long>>, out Collector<Tuple2<Long,Long>>) : void renamed to public apply(key Long, window Window, values Iterable<Tuple2<Long,Long>>, out Collector<Tuple2<Long,Long>>) : void in class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.SummingWindowFunction |
From |
To |
|
Rename Method public mapWindow(function KeyedWindowFunction<T,R,K,W>) : DataStream<R> renamed to public apply(function WindowFunction<T,R,K,W>, resultType TypeInformation<R>) : DataStream<R> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Parameter Type function : WindowFunction<T,R,W> to function : AllWindowFunction<T,R,W> in method public apply(function AllWindowFunction<T,R,W>, resultType TypeInformation<R>) : DataStream<R> in class org.apache.flink.streaming.api.datastream.AllWindowedStream |
From |
To |
|
Change Parameter Type function : KeyedWindowFunction<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 input : KeyedDataStream<T,K> to input : KeyedStream<T,K> in method public WindowedStream(input KeyedStream<T,K>, windowAssigner WindowAssigner<? super T,W>) in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Parameter Type function : KeyedWindowFunction<T,R,K,W> to function : WindowFunction<T,R,K,W> in method public apply(function WindowFunction<T,R,K,W>, resultType TypeInformation<R>) : DataStream<R> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Parameter Type windowFunction : WindowFunction<IN,OUT,W> to windowFunction : AllWindowFunction<IN,OUT,W> in method public EvictingNonKeyedWindowOperator(windowAssigner WindowAssigner<? super IN,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 function : KeyedWindowFunction<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>, windowLength long, windowSlide long) in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator |
From |
To |
|
Change Parameter Type function : KeyedWindowFunction<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>) in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes.WindowFunctionTraversal |
From |
To |
|
Change Parameter Type windowFunction : WindowFunction<IN,OUT,W> to windowFunction : AllWindowFunction<IN,OUT,W> in method public NonKeyedWindowOperator(windowAssigner WindowAssigner<? super IN,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 windowFunction : KeyedWindowFunction<IN,OUT,K,W> to windowFunction : WindowFunction<IN,OUT,K,W> in method public EvictingWindowOperator(windowAssigner WindowAssigner<? super IN,W>, keySelector KeySelector<IN,K>, windowBufferFactory WindowBufferFactory<? super IN,? extends EvictingWindowBuffer<IN>>, windowFunction WindowFunction<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 windowFunction : KeyedWindowFunction<IN,OUT,K,W> to windowFunction : WindowFunction<IN,OUT,K,W> in method public WindowOperator(windowAssigner WindowAssigner<? super IN,W>, keySelector KeySelector<IN,K>, windowBufferFactory WindowBufferFactory<? super IN,? extends WindowBuffer<IN>>, windowFunction WindowFunction<IN,OUT,K,W>, trigger Trigger<? super IN,? super W>) in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator |
From |
To |
|
Change Return Type NonParallelWindowDataStream<T,W> to AllWindowedStream<T,W> in method public windowAll(assigner WindowAssigner<? super T,W>) : AllWindowedStream<T,W> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type NonParallelWindowDataStream<T,TimeWindow> to AllWindowedStream<T,TimeWindow> in method public timeWindowAll(size AbstractTime, slide AbstractTime) : AllWindowedStream<T,TimeWindow> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type KeyedWindowDataStream<T,KEY,W> to WindowedStream<T,KEY,W> in method public window(assigner WindowAssigner<? super T,W>) : WindowedStream<T,KEY,W> in class org.apache.flink.streaming.api.datastream.KeyedStream |
From |
To |
|
Change Return Type NonParallelWindowDataStream<T,TimeWindow> to AllWindowedStream<T,TimeWindow> in method public timeWindowAll(size AbstractTime) : AllWindowedStream<T,TimeWindow> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type KeyedDataStream<T,Tuple> to KeyedStream<T,Tuple> in method public keyBy(fields String...) : KeyedStream<T,Tuple> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type KeyedDataStream<T,Tuple> to KeyedStream<T,Tuple> in method private keyBy(keys Keys<T>) : KeyedStream<T,Tuple> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type KeyedWindowDataStream<T,K,W> to WindowedStream<T,K,W> in method public evictor(evictor Evictor<? super T,? super W>) : WindowedStream<T,K,W> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Return Type NonParallelWindowDataStream<T,W> to AllWindowedStream<T,W> in method public evictor(evictor Evictor<? super T,? super W>) : AllWindowedStream<T,W> in class org.apache.flink.streaming.api.datastream.AllWindowedStream |
From |
To |
|
Change Return Type KeyedDataStream<T,Tuple> to KeyedStream<T,Tuple> in method public keyBy(fields int...) : KeyedStream<T,Tuple> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type KeyedWindowDataStream<T,KEY,TimeWindow> to WindowedStream<T,KEY,TimeWindow> in method public timeWindow(size AbstractTime, slide AbstractTime) : WindowedStream<T,KEY,TimeWindow> in class org.apache.flink.streaming.api.datastream.KeyedStream |
From |
To |
|
Change Return Type KeyedWindowDataStream<T,K,W> to WindowedStream<T,K,W> in method public trigger(trigger Trigger<? super T,? super W>) : WindowedStream<T,K,W> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Return Type KeyedDataStream<T,K> to KeyedStream<T,K> in method public keyBy(key KeySelector<T,K>) : KeyedStream<T,K> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type KeyedWindowDataStream<T,KEY,TimeWindow> to WindowedStream<T,KEY,TimeWindow> in method public timeWindow(size AbstractTime) : WindowedStream<T,KEY,TimeWindow> in class org.apache.flink.streaming.api.datastream.KeyedStream |
From |
To |
|
Change Return Type NonParallelWindowDataStream<T,W> to AllWindowedStream<T,W> in method public trigger(trigger Trigger<? super T,? super W>) : AllWindowedStream<T,W> in class org.apache.flink.streaming.api.datastream.AllWindowedStream |
From |
To |
|
Change Variable Type failingFunction : KeyedWindowFunction<Integer,Integer,Integer,TimeWindow> to failingFunction : WindowFunction<Integer,Integer,Integer,TimeWindow> in method public testPropagateExceptionsFromClose() : void in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingAlignedProcessingTimeWindowOperatorTest |
From |
To |
|
Change Variable Type windowFunction : KeyedWindowFunction<IN,OUT,KEY,Window> to windowFunction : WindowFunction<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 keyedStream : KeyedDataStream<Integer,Integer> to keyedStream : KeyedStream<Integer,Integer> in method public apiTest() : void in class org.apache.flink.streaming.api.state.StatefulOperatorTest |
From |
To |
|
Change Variable Type wf : KeyedWindowFunction<T,R,K,TimeWindow> to wf : WindowFunction<T,R,K,TimeWindow> in method private createFastTimeOperatorIfValid(function Function, resultType TypeInformation<R>, functionName String) : DataStream<R> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Attribute Type input : KeyedDataStream<T,K> to input : KeyedStream<T,K> in class org.apache.flink.streaming.api.datastream.WindowedStream |
From |
To |
|
Change Attribute Type validatingIdentityFunction : KeyedWindowFunction<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 mockFunction : KeyedWindowFunction<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 function : KeyedWindowFunction<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 : KeyedWindowFunction<Type,Result,Key,Window> to function : WindowFunction<Type,Result,Key,Window> in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes |
From |
To |