|
Inline Method public getUnaryOperatorReturnType(function Function, baseClass Class<?>, hasIterable boolean, hasCollector boolean, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getGroupCombineReturnTypes(combineInterface GroupCombineFunction<IN,OUT>, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Inline Method public getUnaryOperatorReturnType(function Function, baseClass Class<?>, hasIterable boolean, hasCollector boolean, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getFlatMapReturnTypes(flatMapInterface FlatMapFunction<IN,OUT>, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Inline Method public getBinaryOperatorReturnType(function Function, baseClass Class<?>, hasIterables boolean, hasCollector boolean, in1Type TypeInformation<IN1>, in2Type TypeInformation<IN2>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getJoinReturnTypes(joinInterface JoinFunction<IN1,IN2,OUT>, in1Type TypeInformation<IN1>, in2Type TypeInformation<IN2>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Inline Method public getBinaryOperatorReturnType(function Function, baseClass Class<?>, hasIterables boolean, hasCollector boolean, in1Type TypeInformation<IN1>, in2Type TypeInformation<IN2>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getCrossReturnTypes(crossInterface CrossFunction<IN1,IN2,OUT>, in1Type TypeInformation<IN1>, in2Type TypeInformation<IN2>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Inline Method public getUnaryOperatorReturnType(function Function, baseClass Class<?>, hasIterable boolean, hasCollector boolean, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getKeySelectorTypes(selectorInterface KeySelector<IN,OUT>, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Inline Method public getUnaryOperatorReturnType(function Function, baseClass Class<?>, hasIterable boolean, hasCollector boolean, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getGroupReduceReturnTypes(groupReduceInterface GroupReduceFunction<IN,OUT>, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Inline Method public getUnaryOperatorReturnType(function Function, baseClass Class<?>, hasIterable boolean, hasCollector boolean, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getMapPartitionReturnTypes(mapPartitionInterface MapPartitionFunction<IN,OUT>, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Inline Method public getBinaryOperatorReturnType(function Function, baseClass Class<?>, hasIterables boolean, hasCollector boolean, in1Type TypeInformation<IN1>, in2Type TypeInformation<IN2>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getCoGroupReturnTypes(coGroupInterface CoGroupFunction<IN1,IN2,OUT>, in1Type TypeInformation<IN1>, in2Type TypeInformation<IN2>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Inline Method public getBinaryOperatorReturnType(function Function, baseClass Class<?>, hasIterables boolean, hasCollector boolean, in1Type TypeInformation<IN1>, in2Type TypeInformation<IN2>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getFlatJoinReturnTypes(joinInterface FlatJoinFunction<IN1,IN2,OUT>, in1Type TypeInformation<IN1>, in2Type TypeInformation<IN2>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Inline Method public getUnaryOperatorReturnType(function Function, baseClass Class<?>, hasIterable boolean, hasCollector boolean, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getMapReturnTypes(mapInterface MapFunction<IN,OUT>, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Inline Method public getUnaryOperatorReturnType(function Function, baseClass Class<?>, hasIterable boolean, hasCollector boolean, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> inlined to public getFoldReturnTypes(foldInterface FoldFunction<IN,OUT>, inType TypeInformation<IN>, functionName String, allowMissing boolean) : TypeInformation<OUT> in class org.apache.flink.api.java.typeutils.TypeExtractor |
From |
To |
|
Change Variable Type window1 : DataStream<Tuple2<String,Integer>> to window1 : DataStream<String> in method public testAggregateWithEvictorAndProcessFunction() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type transform : OneInputTransformation<Tuple2<String,Integer>,Tuple2<String,Integer>> to transform : OneInputTransformation<Tuple3<String,String,Integer>,Integer> in method public testAggregateProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type transform : OneInputTransformation<Tuple2<String,Integer>,Tuple2<String,Integer>> to transform : OneInputTransformation<Tuple3<String,String,Integer>,Integer> in method public testAggregateEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type transform : OneInputTransformation<Tuple2<String,Integer>,Tuple3<String,String,Integer>> to transform : OneInputTransformation<Tuple3<String,String,Integer>,String> in method public testAggregateWithProcessWindowFunctionProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type source : DataStream<Tuple2<String,Integer>> to source : DataStream<Tuple3<String,String,Integer>> in method public testAggregateWithWindowFunctionEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type winOperator : WindowOperator<String,Tuple2<String,Integer>,?,?,?> to winOperator : WindowOperator<String,Tuple3<String,String,Integer>,?,?,?> in method public testAggregateWithWindowFunctionProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type source : DataStream<Tuple2<String,Integer>> to source : DataStream<Tuple3<String,String,Integer>> in method public testAggregateWithEvictor() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type window : DataStream<Tuple3<String,String,Integer>> to window : DataStream<String> in method public testAggregateWithWindowFunctionEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type window1 : DataStream<Tuple2<String,Integer>> to window1 : DataStream<Integer> in method public testAggregateProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type operator : OneInputStreamOperator<Tuple2<String,Integer>,Tuple3<String,String,Integer>> to operator : OneInputStreamOperator<Tuple3<String,String,Integer>,String> in method public testAggregateWithWindowFunctionProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type window1 : DataStream<Tuple2<String,Integer>> to window1 : DataStream<Integer> in method public testAggregateWithEvictor() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type operator : OneInputStreamOperator<Tuple2<String,Integer>,Tuple3<String,String,Integer>> to operator : OneInputStreamOperator<Integer,String> in method public testMergingWindowsWithEvictor() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type operator : OneInputStreamOperator<Tuple2<String,Integer>,Tuple2<String,Integer>> to operator : OneInputStreamOperator<Tuple3<String,String,Integer>,Integer> in method public testAggregateWithEvictor() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type winOperator : WindowOperator<String,Tuple2<String,Integer>,?,?,?> to winOperator : WindowOperator<String,Tuple3<String,String,Integer>,?,?,?> in method public testAggregateWithWindowFunctionEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type source : DataStream<Tuple2<String,Integer>> to source : DataStream<Tuple3<String,String,Integer>> in method public testAggregateWithProcessWindowFunctionEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type transform : OneInputTransformation<Tuple2<String,Integer>,Tuple3<String,String,Integer>> to transform : OneInputTransformation<Integer,String> in method public testMergingWindowsWithEvictor() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type winOperator : WindowOperator<String,Tuple2<String,Integer>,?,?,?> to winOperator : WindowOperator<String,Tuple3<String,String,Integer>,?,?,?> in method public testAggregateWithEvictor() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type window : DataStream<Tuple3<String,String,Integer>> to window : DataStream<String> in method public testAggregateWithProcessWindowFunctionProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type window : DataStream<Tuple3<String,String,Integer>> to window : DataStream<String> in method public testAggregateWithWindowFunctionProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type window1 : DataStream<Tuple3<String,String,Integer>> to window1 : DataStream<String> in method public testMergingWindowsWithEvictor() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type source : DataStream<Tuple2<String,Integer>> to source : DataStream<Tuple3<String,String,Integer>> in method public testAggregateEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type winOperator : WindowOperator<String,Tuple2<String,Integer>,?,?,?> to winOperator : WindowOperator<String,Tuple3<String,String,Integer>,?,?,?> in method public testAggregateWithEvictorAndProcessFunction() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type window1 : DataStream<Tuple2<String,Integer>> to window1 : DataStream<Integer> in method public testAggregateEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type transform : OneInputTransformation<Tuple2<String,Integer>,Tuple2<String,Integer>> to transform : OneInputTransformation<Tuple3<String,String,Integer>,String> in method public testAggregateWithEvictorAndProcessFunction() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type winOperator : WindowOperator<String,Tuple2<String,Integer>,?,?,?> to winOperator : WindowOperator<String,Tuple3<String,String,Integer>,?,?,?> in method public testAggregateEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type operator : OneInputStreamOperator<Tuple2<String,Integer>,Tuple2<String,Integer>> to operator : OneInputStreamOperator<Tuple3<String,String,Integer>,String> in method public testAggregateWithEvictorAndProcessFunction() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type transform : OneInputTransformation<Tuple2<String,Integer>,Tuple3<String,String,Integer>> to transform : OneInputTransformation<Tuple3<String,String,Integer>,String> in method public testAggregateWithWindowFunctionProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type winOperator : WindowOperator<String,Tuple2<String,Integer>,?,?,?> to winOperator : WindowOperator<String,Tuple3<String,String,Integer>,?,?,?> in method public testAggregateProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type operator : OneInputStreamOperator<Tuple2<String,Integer>,Tuple2<String,Integer>> to operator : OneInputStreamOperator<Tuple3<String,String,Integer>,Integer> in method public testAggregateEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type source : DataStream<Tuple2<String,Integer>> to source : DataStream<Tuple3<String,String,Integer>> in method public testAggregateProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type transform : OneInputTransformation<Tuple2<String,Integer>,Tuple3<String,String,Integer>> to transform : OneInputTransformation<Tuple3<String,String,Integer>,String> in method public testAggregateWithWindowFunctionEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type winOperator : WindowOperator<String,Tuple2<String,Integer>,?,?,?> to winOperator : WindowOperator<String,Tuple3<String,String,Integer>,?,?,?> in method public testAggregateWithProcessWindowFunctionProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type operator : OneInputStreamOperator<Tuple2<String,Integer>,Tuple3<String,String,Integer>> to operator : OneInputStreamOperator<Tuple3<String,String,Integer>,String> in method public testAggregateWithProcessWindowFunctionProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type operator : OneInputStreamOperator<Tuple2<String,Integer>,Tuple3<String,String,Integer>> to operator : OneInputStreamOperator<Tuple3<String,String,Integer>,String> in method public testAggregateWithProcessWindowFunctionEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type operator : OneInputStreamOperator<Tuple2<String,Integer>,Tuple2<String,Integer>> to operator : OneInputStreamOperator<Tuple3<String,String,Integer>,Integer> in method public testAggregateProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type window : DataStream<Tuple3<String,String,Integer>> to window : DataStream<String> in method public testAggregateWithProcessWindowFunctionEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type source : DataStream<Tuple2<String,Integer>> to source : DataStream<Tuple3<String,String,Integer>> in method public testAggregateWithWindowFunctionProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type winOperator : WindowOperator<String,Tuple2<String,Integer>,?,?,?> to winOperator : WindowOperator<String,Tuple3<String,String,Integer>,?,?,?> in method public testAggregateWithProcessWindowFunctionEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type source : DataStream<Tuple2<String,Integer>> to source : DataStream<Tuple3<String,String,Integer>> in method public testAggregateWithProcessWindowFunctionProcessingTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type winOperator : WindowOperator<String,Tuple2<String,Integer>,?,?,?> to winOperator : WindowOperator<String,Integer,?,?,?> in method public testMergingWindowsWithEvictor() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type operator : OneInputStreamOperator<Tuple2<String,Integer>,Tuple3<String,String,Integer>> to operator : OneInputStreamOperator<Tuple3<String,String,Integer>,String> in method public testAggregateWithWindowFunctionEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type transform : OneInputTransformation<Tuple2<String,Integer>,Tuple3<String,String,Integer>> to transform : OneInputTransformation<Tuple3<String,String,Integer>,String> in method public testAggregateWithProcessWindowFunctionEventTime() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type source : DataStream<Tuple2<String,Integer>> to source : DataStream<Tuple3<String,String,Integer>> in method public testAggregateWithEvictorAndProcessFunction() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |
|
Change Variable Type transform : OneInputTransformation<Tuple2<String,Integer>,Tuple2<String,Integer>> to transform : OneInputTransformation<Tuple3<String,String,Integer>,Integer> in method public testAggregateWithEvictor() : void in class org.apache.flink.streaming.runtime.operators.windowing.WindowTranslationTest |
From |
To |