|
Change Parameter Type context : PactTaskContext<ReduceFunction<T>,T> to context : TaskContext<ReduceFunction<T>,T> in method public setup(context TaskContext<ReduceFunction<T>,T>) : void in class org.apache.flink.runtime.operators.ReduceDriver |
From |
To |
|
Change Parameter Type context : PactTaskContext<MapPartitionFunction<IT,OT>,OT> to context : TaskContext<MapPartitionFunction<IT,OT>,OT> in method public setup(context TaskContext<MapPartitionFunction<IT,OT>,OT>) : void in class org.apache.flink.runtime.operators.MapPartitionDriver |
From |
To |
|
Change Parameter Type driver : PactDriver to driver : Driver in method public testDriverInternal(driver Driver, stubClass Class) : void in class org.apache.flink.runtime.operators.testutils.UnaryOperatorTestBase |
From |
To |
|
Change Parameter Type driver : PactDriver to driver : Driver in method public testDriver(driver Driver, stubClass Class) : void in class org.apache.flink.runtime.operators.testutils.DriverTestBase |
From |
To |
|
Change Parameter Type referenceHolder : RegularPactTask<?,?> to referenceHolder : BatchTask<?,?> in method public decrementReferenceIfHeld(referenceHolder BatchTask<?,?>) : boolean in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization |
From |
To |
|
Change Parameter Type context : PactTaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> to context : TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> in method public setup(context TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT>) : void in class org.apache.flink.runtime.operators.JoinDriver |
From |
To |
|
Change Parameter Type driver : Class<? extends PactDriver> to driver : Class<? extends Driver> in method public setDriver(driver Class<? extends Driver>) : void in class org.apache.flink.runtime.operators.util.TaskConfig |
From |
To |
|
Change Parameter Type context : PactTaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> to context : TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> in method public setup(context TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT>) : void in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver |
From |
To |
|
Change Parameter Type referenceHolder : RegularPactTask<?,?> to referenceHolder : BatchTask<?,?> in method public decrementReference(referenceHolder BatchTask<?,?>) : boolean in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization |
From |
To |
|
Change Parameter Type context : PactTaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> to context : TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> in method public setup(context TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT>) : void in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver |
From |
To |
|
Change Parameter Type context : PactTaskContext<CoGroupFunction<IT1,IT2,OT>,OT> to context : TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> in method public setup(context TaskContext<CoGroupFunction<IT1,IT2,OT>,OT>) : void in class org.apache.flink.runtime.operators.CoGroupRawDriver |
From |
To |
|
Change Parameter Type context : PactTaskContext<CoGroupFunction<IT1,IT2,OT>,OT> to context : TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> in method public setup(context TaskContext<CoGroupFunction<IT1,IT2,OT>,OT>) : void in class org.apache.flink.runtime.operators.CoGroupDriver |
From |
To |
|
Change Parameter Type driver : ResettablePactDriver to driver : ResettableDriver in method public testResettableDriver(driver ResettableDriver, stubClass Class, iterations int) : void in class org.apache.flink.runtime.operators.testutils.DriverTestBase |
From |
To |
|
Change Parameter Type context : PactTaskContext<AbstractRichFunction,T> to context : TaskContext<AbstractRichFunction,T> in method public setup(context TaskContext<AbstractRichFunction,T>) : void in class org.apache.flink.runtime.operators.NoOpDriver |
From |
To |
|
Change Parameter Type driver : PactDriver to driver : Driver in method public testDriver(driver Driver, stubClass Class) : void in class org.apache.flink.runtime.operators.testutils.UnaryOperatorTestBase |
From |
To |
|
Change Parameter Type driver : ResettablePactDriver to driver : ResettableDriver in method public testResettableDriver(driver ResettableDriver, stubClass Class, iterations int) : void in class org.apache.flink.runtime.operators.testutils.BinaryOperatorTestBase |
From |
To |
|
Change Parameter Type driverClass : Class<? extends PactDriver> to driverClass : Class<? extends Driver> in method private DriverStrategy(driverClass Class<? extends Driver>, pushChainDriverClass Class<? extends ChainedDriver>, firstDam DamBehavior, secondDam DamBehavior, numComparator int) in class org.apache.flink.runtime.operators.DriverStrategy |
From |
To |
|
Change Parameter Type driverClass : Class<? extends PactDriver> to driverClass : Class<? extends Driver> in method private DriverStrategy(driverClass Class<? extends Driver>, pushChainDriverClass Class<? extends ChainedDriver>, dam DamBehavior, numComparator int) in class org.apache.flink.runtime.operators.DriverStrategy |
From |
To |
|
Change Parameter Type driver : PactDriver to driver : Driver in method public testDriverInternal(driver Driver, stubClass Class) : void in class org.apache.flink.runtime.operators.testutils.DriverTestBase |
From |
To |
|
Change Parameter Type referenceHolder : RegularPactTask<?,?> to referenceHolder : BatchTask<?,?> in method private decrementReferenceInternal(referenceHolder BatchTask<?,?>, errorIfNoReference boolean) : boolean in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization |
From |
To |
|
Change Parameter Type context : PactTaskContext<FlatMapFunction<IT,OT>,OT> to context : TaskContext<FlatMapFunction<IT,OT>,OT> in method public setup(context TaskContext<FlatMapFunction<IT,OT>,OT>) : void in class org.apache.flink.runtime.operators.FlatMapDriver |
From |
To |
|
Change Parameter Type driver : ResettablePactDriver to driver : ResettableDriver in method public testResettableDriver(driver ResettableDriver, stubClass Class, iterations int) : void in class org.apache.flink.runtime.operators.testutils.UnaryOperatorTestBase |
From |
To |
|
Change Parameter Type context : PactTaskContext<GroupCombineFunction<IN,OUT>,OUT> to context : TaskContext<GroupCombineFunction<IN,OUT>,OUT> in method public setup(context TaskContext<GroupCombineFunction<IN,OUT>,OUT>) : void in class org.apache.flink.runtime.operators.AllGroupCombineDriver |
From |
To |
|
Change Parameter Type driver : PactDriver to driver : Driver in method public testDriverInternal(driver Driver, stubClass Class) : void in class org.apache.flink.runtime.operators.testutils.BinaryOperatorTestBase |
From |
To |
|
Change Parameter Type context : PactTaskContext<ReduceFunction<T>,T> to context : TaskContext<ReduceFunction<T>,T> in method public setup(context TaskContext<ReduceFunction<T>,T>) : void in class org.apache.flink.runtime.operators.ReduceCombineDriver |
From |
To |
|
Change Parameter Type context : PactTaskContext<CoGroupFunction<IT1,IT2,OT>,OT> to context : TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> in method public setup(context TaskContext<CoGroupFunction<IT1,IT2,OT>,OT>) : void in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver |
From |
To |
|
Change Parameter Type context : PactTaskContext<GroupReduceFunction<IT,OT>,OT> to context : TaskContext<GroupReduceFunction<IT,OT>,OT> in method public setup(context TaskContext<GroupReduceFunction<IT,OT>,OT>) : void in class org.apache.flink.runtime.operators.AllGroupReduceDriver |
From |
To |
|
Change Parameter Type context : PactTaskContext<GenericCollectorMap<IT,OT>,OT> to context : TaskContext<GenericCollectorMap<IT,OT>,OT> in method public setup(context TaskContext<GenericCollectorMap<IT,OT>,OT>) : void in class org.apache.flink.runtime.operators.CollectorMapDriver |
From |
To |
|
Change Parameter Type context : PactTaskContext<S,OT> to context : TaskContext<S,OT> in method public setup(context TaskContext<S,OT>) : void in class org.apache.flink.runtime.operators.Driver |
From |
To |
|
Change Parameter Type context : PactTaskContext<CoGroupFunction<IT1,IT2,OT>,OT> to context : TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> in method public setup(context TaskContext<CoGroupFunction<IT1,IT2,OT>,OT>) : void in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver |
From |
To |
|
Change Parameter Type referenceHolder : RegularPactTask<?,?> to referenceHolder : BatchTask<?,?> in method public materializeVariable(reader MutableReader<?>, serializerFactory TypeSerializerFactory<?>, referenceHolder BatchTask<?,?>) : void in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization |
From |
To |
|
Change Parameter Type referenceHolder : RegularPactTask<?,?> to referenceHolder : BatchTask<?,?> in method public releaseReference(name String, superstep int, referenceHolder BatchTask<?,?>) : void in class org.apache.flink.runtime.broadcast.BroadcastVariableManager |
From |
To |
|
Change Parameter Type referenceHolder : RegularPactTask<?,?> to referenceHolder : BatchTask<?,?> in method public releaseReference(key BroadcastVariableKey, referenceHolder BatchTask<?,?>) : void in class org.apache.flink.runtime.broadcast.BroadcastVariableManager |
From |
To |
|
Change Parameter Type driver : PactDriver to driver : Driver in method public testDriver(driver Driver, stubClass Class) : void in class org.apache.flink.runtime.operators.testutils.BinaryOperatorTestBase |
From |
To |
|
Change Parameter Type context : PactTaskContext<GroupReduceFunction<IT,OT>,OT> to context : TaskContext<GroupReduceFunction<IT,OT>,OT> in method public setup(context TaskContext<GroupReduceFunction<IT,OT>,OT>) : void in class org.apache.flink.runtime.operators.GroupReduceDriver |
From |
To |
|
Change Parameter Type holder : RegularPactTask<?,?> to holder : BatchTask<?,?> in method public materializeBroadcastVariable(name String, superstep int, holder BatchTask<?,?>, reader MutableReader<?>, serializerFactory TypeSerializerFactory<T>) : BroadcastVariableMaterialization<T,?> in class org.apache.flink.runtime.broadcast.BroadcastVariableManager |
From |
To |
|
Change Parameter Type context : PactTaskContext<Function,T> to context : TaskContext<Function,T> in method public setup(context TaskContext<Function,T>) : void in class org.apache.flink.runtime.operators.UnionWithTempOperator |
From |
To |
|
Change Parameter Type context : PactTaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> to context : TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> in method public setup(context TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT>) : void in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver |
From |
To |
|
Change Parameter Type context : PactTaskContext<MapFunction<IT,OT>,OT> to context : TaskContext<MapFunction<IT,OT>,OT> in method public setup(context TaskContext<MapFunction<IT,OT>,OT>) : void in class org.apache.flink.runtime.operators.MapDriver |
From |
To |
|
Change Parameter Type context : PactTaskContext<ReduceFunction<T>,T> to context : TaskContext<ReduceFunction<T>,T> in method public setup(context TaskContext<ReduceFunction<T>,T>) : void in class org.apache.flink.runtime.operators.AllReduceDriver |
From |
To |
|
Change Parameter Type driver : Class<? extends PactDriver> to driver : Class<? extends Driver> in method public registerTask(task AbstractInvokable, driver Class<? extends Driver>, stubClass Class<? extends RichFunction>) : void in class org.apache.flink.runtime.operators.testutils.TaskTestBase |
From |
To |
|
Change Parameter Type context : PactTaskContext<CrossFunction<T1,T2,OT>,OT> to context : TaskContext<CrossFunction<T1,T2,OT>,OT> in method public setup(context TaskContext<CrossFunction<T1,T2,OT>,OT>) : void in class org.apache.flink.runtime.operators.CrossDriver |
From |
To |
|
Change Parameter Type referenceHolder : RegularPactTask<?,?> to referenceHolder : BatchTask<?,?> in method public releaseAllReferencesFromTask(referenceHolder BatchTask<?,?>) : void in class org.apache.flink.runtime.broadcast.BroadcastVariableManager |
From |
To |
|
Change Parameter Type context : PactTaskContext<GroupCombineFunction<IN,OUT>,OUT> to context : TaskContext<GroupCombineFunction<IN,OUT>,OUT> in method public setup(context TaskContext<GroupCombineFunction<IN,OUT>,OUT>) : void in class org.apache.flink.runtime.operators.GroupReduceCombineDriver |
From |
To |
|
Change Variable Type iterativeTaskContext : AbstractIterativePactTask<?,?> to iterativeTaskContext : AbstractIterativeTask<?,?> in method public initialize() : void in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver |
From |
To |
|
Change Variable Type resDriver : ResettablePactDriver<?,?> to resDriver : ResettableDriver<?,?> in method protected initialize() : void in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask |
From |
To |
|
Change Variable Type resDriver : ResettablePactDriver<?,?> to resDriver : ResettableDriver<?,?> in method public testDriverInternal(driver Driver, stubClass Class) : void in class org.apache.flink.runtime.operators.testutils.UnaryOperatorTestBase |
From |
To |
|
Change Variable Type resDriver : ResettablePactDriver<?,?> to resDriver : ResettableDriver<?,?> in method public testDriverInternal(driver Driver, stubClass Class) : void in class org.apache.flink.runtime.operators.testutils.DriverTestBase |
From |
To |
|
Change Variable Type resDriver : ResettablePactDriver<?,?> to resDriver : ResettableDriver<?,?> in method private reinstantiateDriver() : void in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask |
From |
To |
|
Change Variable Type iterativeTaskContext : AbstractIterativePactTask<?,?> to iterativeTaskContext : AbstractIterativeTask<?,?> in method public initialize() : void in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver |
From |
To |
|
Change Variable Type resDriver : ResettablePactDriver<?,?> to resDriver : ResettableDriver<?,?> in method protected closeLocalStrategiesAndCaches() : void in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask |
From |
To |
|
Change Variable Type resDriver : ResettablePactDriver<?,?> to resDriver : ResettableDriver<?,?> in method protected run() : void in class org.apache.flink.runtime.operators.BatchTask |
From |
To |
|
Change Variable Type iterativeTaskContext : AbstractIterativePactTask<?,?> to iterativeTaskContext : AbstractIterativeTask<?,?> in method public initialize() : void in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver |
From |
To |
|
Change Variable Type resDriver : ResettablePactDriver<?,?> to resDriver : ResettableDriver<?,?> in method public testDriverInternal(driver Driver, stubClass Class) : void in class org.apache.flink.runtime.operators.testutils.BinaryOperatorTestBase |
From |
To |
|
Change Variable Type iterativeTaskContext : AbstractIterativePactTask<?,?> to iterativeTaskContext : AbstractIterativeTask<?,?> in method public initialize() : void in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver |
From |
To |
|
Change Variable Type testTask : RegularPactTask<GenericCollectorMap<Record,Record>,Record> to testTask : BatchTask<GenericCollectorMap<Record,Record>,Record> in method public testMapTask() : void in class org.apache.flink.runtime.operators.chaining.ChainTaskTest |
From |
To |
|
Change Variable Type driverClass : Class<? extends PactDriver<S,OT>> to driverClass : Class<? extends Driver<S,OT>> in method public TezTask(config TezTaskConfig, runtimeUdfContext RuntimeUDFContext, availableMemory long) in class org.apache.flink.tez.runtime.TezTask |
From |
To |
|
Change Variable Type driverClass : Class<? extends PactDriver<S,OT>> to driverClass : Class<? extends Driver<S,OT>> in method public registerInputOutput() : void in class org.apache.flink.runtime.operators.BatchTask |
From |
To |
|
Change Variable Type pdClazz : Class<PactDriver<S,OT>> to pdClazz : Class<Driver<S,OT>> in method public getDriver() : Class<? extends Driver<S,OT>> in class org.apache.flink.runtime.operators.util.TaskConfig |
From |
To |
|
Change Variable Type testTask : RegularPactTask<GenericCollectorMap<Record,Record>,Record> to testTask : BatchTask<GenericCollectorMap<Record,Record>,Record> in method public testFailingMapTask() : void in class org.apache.flink.runtime.operators.chaining.ChainTaskTest |
From |
To |
|
Change Variable Type driverClass : Class<? extends PactDriver<S,OT>> to driverClass : Class<? extends Driver<S,OT>> in method private reinstantiateDriver() : void in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask |
From |
To |
|
Change Variable Type driver : PactDriver<S,OT> to driver : Driver<S,OT> in method public run(inputs Map<String,LogicalInput>, outputs Map<String,LogicalOutput>) : void in class org.apache.flink.tez.runtime.RegularProcessor |
From |
To |
|
Change Variable Type driverClass : Class<? extends PactDriver<S,OT>> to driverClass : Class<? extends Driver<S,OT>> in method public run(inputs Map<String,LogicalInput>, outputs Map<String,LogicalOutput>) : void in class org.apache.flink.tez.runtime.RegularProcessor |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> to taskContext : TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<CrossFunction<T1,T2,OT>,OT> to taskContext : TaskContext<CrossFunction<T1,T2,OT>,OT> in class org.apache.flink.runtime.operators.CrossDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<Function,T> to taskContext : TaskContext<Function,T> in class org.apache.flink.runtime.operators.UnionWithTempOperator |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> to taskContext : TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> in class org.apache.flink.runtime.operators.JoinDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<CoGroupFunction<IT1,IT2,OT>,OT> to taskContext : TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> in class org.apache.flink.runtime.operators.CoGroupRawDriver |
From |
To |
|
Change Attribute Type driver : PactDriver<S,OT> to driver : Driver<S,OT> in class org.apache.flink.tez.runtime.TezTask |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<MapFunction<IT,OT>,OT> to taskContext : TaskContext<MapFunction<IT,OT>,OT> in class org.apache.flink.runtime.operators.MapDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<CoGroupFunction<IT1,IT2,OT>,OT> to taskContext : TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<ReduceFunction<T>,T> to taskContext : TaskContext<ReduceFunction<T>,T> in class org.apache.flink.runtime.operators.ReduceDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<ReduceFunction<T>,T> to taskContext : TaskContext<ReduceFunction<T>,T> in class org.apache.flink.runtime.operators.AllReduceDriver |
From |
To |
|
Change Attribute Type driver : PactDriver<S,OT> to driver : Driver<S,OT> in class org.apache.flink.runtime.operators.BatchTask |
From |
To |
|
Change Attribute Type driverClass : Class<? extends PactDriver<?,?>> to driverClass : Class<? extends Driver<?,?>> in class org.apache.flink.runtime.operators.DriverStrategy |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<FlatMapFunction<IT,OT>,OT> to taskContext : TaskContext<FlatMapFunction<IT,OT>,OT> in class org.apache.flink.runtime.operators.FlatMapDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<GroupCombineFunction<IN,OUT>,OUT> to taskContext : TaskContext<GroupCombineFunction<IN,OUT>,OUT> in class org.apache.flink.runtime.operators.GroupReduceCombineDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<GroupReduceFunction<IT,OT>,OT> to taskContext : TaskContext<GroupReduceFunction<IT,OT>,OT> in class org.apache.flink.runtime.operators.GroupReduceDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<AbstractRichFunction,T> to taskContext : TaskContext<AbstractRichFunction,T> in class org.apache.flink.runtime.operators.NoOpDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> to taskContext : TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver |
From |
To |
|
Change Attribute Type references : Set<RegularPactTask<?,?>> to references : Set<BatchTask<?,?>> in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization |
From |
To |
|
Change Attribute Type driver : PactDriver<S,Record> to driver : Driver<S,Record> in class org.apache.flink.runtime.operators.testutils.DriverTestBase |
From |
To |
|
Change Attribute Type driver : PactDriver<S,OUT> to driver : Driver<S,OUT> in class org.apache.flink.runtime.operators.testutils.UnaryOperatorTestBase |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<GenericCollectorMap<IT,OT>,OT> to taskContext : TaskContext<GenericCollectorMap<IT,OT>,OT> in class org.apache.flink.runtime.operators.CollectorMapDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<CoGroupFunction<IT1,IT2,OT>,OT> to taskContext : TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> in class org.apache.flink.runtime.operators.CoGroupDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<CoGroupFunction<IT1,IT2,OT>,OT> to taskContext : TaskContext<CoGroupFunction<IT1,IT2,OT>,OT> in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<GroupCombineFunction<IN,OUT>,OUT> to taskContext : TaskContext<GroupCombineFunction<IN,OUT>,OUT> in class org.apache.flink.runtime.operators.AllGroupCombineDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<MapPartitionFunction<IT,OT>,OT> to taskContext : TaskContext<MapPartitionFunction<IT,OT>,OT> in class org.apache.flink.runtime.operators.MapPartitionDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<GroupReduceFunction<IT,OT>,OT> to taskContext : TaskContext<GroupReduceFunction<IT,OT>,OT> in class org.apache.flink.runtime.operators.AllGroupReduceDriver |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<ReduceFunction<T>,T> to taskContext : TaskContext<ReduceFunction<T>,T> in class org.apache.flink.runtime.operators.ReduceCombineDriver |
From |
To |
|
Change Attribute Type driver : PactDriver<S,IN> to driver : Driver<S,IN> in class org.apache.flink.runtime.operators.testutils.BinaryOperatorTestBase |
From |
To |
|
Change Attribute Type taskContext : PactTaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> to taskContext : TaskContext<FlatJoinFunction<IT1,IT2,OT>,OT> in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver |
From |
To |