|
Change Parameter Type keySelector : KeySelector<T,?> to keySelector : KeySelector<T,K> in method public groupBy(keySelector KeySelector<T,K>) : GroupedDataStream<T,K> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Parameter Type values : Iterable<Tuple2<K,Long>> to values : Iterable<Tuple2<Long,Long>> in method public evaluate(key Long, values Iterable<Tuple2<Long,Long>>, out Collector<Tuple2<Long,Long>>) : void in class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.SummingWindowFunction |
From |
To |
|
Change Parameter Type out : Collector<Tuple2<K,Long>> to out : Collector<Tuple2<Long,Long>> in method public evaluate(key Long, values Iterable<Tuple2<Long,Long>>, out Collector<Tuple2<Long,Long>>) : void in class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.SummingWindowFunction |
From |
To |
|
Change Parameter Type key : K to key : Long in method public evaluate(key Long, values Iterable<Tuple2<Long,Long>>, out Collector<Tuple2<Long,Long>>) : void in class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.SummingWindowFunction |
From |
To |
|
Change Parameter Type key : KeySelector<T,?> to key : KeySelector<T,K> in method public keyBy(key KeySelector<T,K>) : KeyedDataStream<T,K> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Parameter Type partitioner : KeySelector<Integer,Serializable> to partitioner : KeySelector<Integer,? extends Serializable> in method private createOperatorWithContext(output List<String>, partitioner KeySelector<Integer,? extends Serializable>, serializedState byte[]) : StreamMap<Integer,String> in class org.apache.flink.streaming.api.state.StatefulOperatorTest |
From |
To |
|
Change Parameter Type function : KeyedWindowFunction<Key,Type,Result> to function : KeyedWindowFunction<Type,Result,Key> in method public AccumulatingKeyedTimePanes(keySelector KeySelector<Type,Key>, function KeyedWindowFunction<Type,Result,Key>) in class org.apache.flink.streaming.runtime.operators.windows.AccumulatingKeyedTimePanes |
From |
To |
|
Change Parameter Type keySelector : KeySelector<T,?> to keySelector : KeySelector<T,K> in method public KeyedDataStream(dataStream DataStream<T>, keySelector KeySelector<T,K>) in class org.apache.flink.streaming.api.datastream.KeyedDataStream |
From |
To |
|
Change Parameter Type function : KeyedWindowFunction<Key,Type,Result> to function : KeyedWindowFunction<Type,Result,Key> in method package WindowFunctionTraversal(function KeyedWindowFunction<Type,Result,Key>, out Collector<Result>) in class org.apache.flink.streaming.runtime.operators.windows.AccumulatingKeyedTimePanes.WindowFunctionTraversal |
From |
To |
|
Change Parameter Type keySelector : KeySelector<OUT,?> to keySelector : KeySelector<OUT,KEY> in method public GroupedDataStream(dataStream DataStream<OUT>, keySelector KeySelector<OUT,KEY>) in class org.apache.flink.streaming.api.datastream.GroupedDataStream |
From |
To |
|
Change Parameter Type function : KeyedWindowFunction<KEY,IN,OUT> to function : KeyedWindowFunction<IN,OUT,KEY> in method public AccumulatingProcessingTimeWindowOperator(function KeyedWindowFunction<IN,OUT,KEY>, keySelector KeySelector<IN,KEY>, windowLength long, windowSlide long) in class org.apache.flink.streaming.runtime.operators.windows.AccumulatingProcessingTimeWindowOperator |
From |
To |
|
Change Return Type KeySelector<T,?> to KeySelector<T,K> in method public getKeySelector() : KeySelector<T,K> in class org.apache.flink.streaming.api.datastream.KeyedDataStream |
From |
To |
|
Change Return Type KeyedDataStream<T> to KeyedDataStream<T,Tuple> in method public keyBy(fields String...) : KeyedDataStream<T,Tuple> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type GroupedDataStream<T> to GroupedDataStream<T,Tuple> in method public groupBy(fields int...) : GroupedDataStream<T,Tuple> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type KeyedDataStream<T> to KeyedDataStream<T,Tuple> in method public keyBy(fields int...) : KeyedDataStream<T,Tuple> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type GroupedDataStream<T> to GroupedDataStream<T,Tuple> in method public groupBy(fields String...) : GroupedDataStream<T,Tuple> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type KeyedDataStream<T> to KeyedDataStream<T,Tuple> in method private keyBy(keys Keys<T>) : KeyedDataStream<T,Tuple> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type GroupedDataStream<T> to GroupedDataStream<T,Tuple> in method private groupBy(keys Keys<T>) : GroupedDataStream<T,Tuple> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type KeyedDataStream<T> to KeyedDataStream<T,K> in method public keyBy(key KeySelector<T,K>) : KeyedDataStream<T,K> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type GroupedDataStream<T> to GroupedDataStream<T,K> in method public groupBy(keySelector KeySelector<T,K>) : GroupedDataStream<T,K> in class org.apache.flink.streaming.api.datastream.DataStream |
From |
To |
|
Change Return Type KeySelector<X,?> to KeySelector<X,Tuple> in method public getSelectorForKeys(keys Keys<X>, typeInfo TypeInformation<X>, executionConfig ExecutionConfig) : KeySelector<X,Tuple> in class org.apache.flink.streaming.util.keys.KeySelectorUtil |
From |
To |
|
Change Variable Type value : Tuple2<K,Long> to value : Tuple2<Long,Long> in method public evaluate(key Long, values Iterable<Tuple2<Long,Long>>, out Collector<Tuple2<Long,Long>>) : void in class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.SummingWindowFunction |
From |
To |
|
Change Variable Type keyedStream : KeyedDataStream<Integer> to keyedStream : KeyedDataStream<Integer,Integer> in method public apiTest() : void in class org.apache.flink.streaming.api.state.StatefulOperatorTest |
From |
To |
|
Change Variable Type windowFunction : KeyedWindowFunction<KEY,IN,OUT> to windowFunction : KeyedWindowFunction<IN,OUT,KEY> in method protected createPanes(keySelector KeySelector<IN,KEY>, function Function) : AccumulatingKeyedTimePanes<IN,KEY,OUT> in class org.apache.flink.streaming.runtime.operators.windows.AccumulatingProcessingTimeWindowOperator |
From |
To |