|
Change Parameter Type destroy : Consumer<T> to outerFactoryCount : int in method private internalJoinBridgeDataManager(probeExecutionStrategy PipelineExecutionStrategy, buildExecutionStrategy PipelineExecutionStrategy, joinBridgeProvider Function<Lifespan,T>, probeFactoryCount int, outerFactoryCount int) : InternalJoinBridgeDataManager<T> in class com.facebook.presto.operator.JoinBridgeManager |
From |
To |
|
Change Parameter Type lookupSourceFactory : JoinBridgeDataManager<LookupSourceFactory> to lookupSourceFactory : JoinBridgeManager<LookupSourceFactory> in method public probeOuterJoin(operatorId int, planNodeId PlanNodeId, lookupSourceFactory JoinBridgeManager<LookupSourceFactory>, probeTypes List<Type>, probeJoinChannel List<Integer>, probeHashChannel OptionalInt, probeOutputChannels Optional<List<Integer>>, totalOperatorsCount OptionalInt, partitioningSpillerFactory PartitioningSpillerFactory) : OperatorFactory in class com.facebook.presto.operator.LookupJoinOperators |
From |
To |
|
Change Parameter Type nestedLoopJoinPagesBridgeManager : JoinBridgeDataManager<NestedLoopJoinPagesBridge> to nestedLoopJoinPagesBridgeManager : JoinBridgeManager<NestedLoopJoinPagesBridge> in method public NestedLoopBuildOperatorFactory(operatorId int, planNodeId PlanNodeId, nestedLoopJoinPagesBridgeManager JoinBridgeManager<NestedLoopJoinPagesBridge>) in class com.facebook.presto.operator.NestedLoopBuildOperator.NestedLoopBuildOperatorFactory |
From |
To |
|
Change Parameter Type lookupSourceFactory : JoinBridgeDataManager<LookupSourceFactory> to lookupSourceFactory : JoinBridgeManager<LookupSourceFactory> in method public fullOuterJoin(operatorId int, planNodeId PlanNodeId, lookupSourceFactory JoinBridgeManager<LookupSourceFactory>, probeTypes List<Type>, probeJoinChannel List<Integer>, probeHashChannel OptionalInt, probeOutputChannels Optional<List<Integer>>, totalOperatorsCount OptionalInt, partitioningSpillerFactory PartitioningSpillerFactory) : OperatorFactory in class com.facebook.presto.operator.LookupJoinOperators |
From |
To |
|
Change Parameter Type lookupSourceFactory : JoinBridgeDataManager<LookupSourceFactory> to lookupSourceFactory : JoinBridgeManager<LookupSourceFactory> in method public HashBuilderOperatorFactory(operatorId int, planNodeId PlanNodeId, lookupSourceFactory JoinBridgeManager<LookupSourceFactory>, outputChannels List<Integer>, hashChannels List<Integer>, preComputedHashChannel OptionalInt, filterFunctionFactory Optional<JoinFilterFunctionFactory>, sortChannel Optional<Integer>, searchFunctionFactories List<JoinFilterFunctionFactory>, expectedPositions int, pagesIndexFactory PagesIndex.Factory, spillEnabled boolean, singleStreamSpillerFactory SingleStreamSpillerFactory) in class com.facebook.presto.operator.HashBuilderOperator.HashBuilderOperatorFactory |
From |
To |
|
Change Parameter Type lookupSourceFactory : JoinBridgeDataManager<LookupSourceFactory> to lookupSourceFactory : JoinBridgeManager<LookupSourceFactory> in method public innerJoin(operatorId int, planNodeId PlanNodeId, lookupSourceFactory JoinBridgeManager<LookupSourceFactory>, probeTypes List<Type>, probeJoinChannel List<Integer>, probeHashChannel OptionalInt, probeOutputChannels Optional<List<Integer>>, totalOperatorsCount OptionalInt, partitioningSpillerFactory PartitioningSpillerFactory) : OperatorFactory in class com.facebook.presto.operator.LookupJoinOperators |
From |
To |
|
Change Parameter Type lookupSourceFactory : JoinBridgeDataManager<LookupSourceFactory> to lookupSourceFactory : JoinBridgeManager<LookupSourceFactory> in method private createJoinOperatorFactory(operatorId int, planNodeId PlanNodeId, lookupSourceFactory JoinBridgeManager<LookupSourceFactory>, probeTypes List<Type>, probeJoinChannel List<Integer>, probeHashChannel OptionalInt, probeOutputChannels List<Integer>, joinType JoinType, totalOperatorsCount OptionalInt, partitioningSpillerFactory PartitioningSpillerFactory) : OperatorFactory in class com.facebook.presto.operator.LookupJoinOperators |
From |
To |
|
Change Parameter Type lookupSourceFactory : JoinBridgeDataManager<LookupSourceFactory> to lookupSourceFactory : JoinBridgeManager<LookupSourceFactory> in method private createLookupJoin(node JoinNode, probeSource PhysicalOperation, probeSymbols List<Symbol>, probeHashSymbol Optional<Symbol>, lookupSourceFactory JoinBridgeManager<LookupSourceFactory>, context LocalExecutionPlanContext) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type lookupSourceFactoryManager : JoinBridgeDataManager<LookupSourceFactory> to lookupSourceFactoryManager : JoinBridgeManager<LookupSourceFactory> in method public LookupJoinOperatorFactory(operatorId int, planNodeId PlanNodeId, lookupSourceFactoryManager JoinBridgeManager<LookupSourceFactory>, probeTypes List<Type>, probeOutputTypes List<Type>, buildOutputTypes List<Type>, joinType JoinType, joinProbeFactory JoinProbeFactory, totalOperatorsCount OptionalInt, probeJoinChannels List<Integer>, probeHashChannel OptionalInt, partitioningSpillerFactory PartitioningSpillerFactory) in class com.facebook.presto.operator.LookupJoinOperatorFactory |
From |
To |
|
Change Parameter Type lookupSourceFactoryManager : JoinBridgeDataManager<LookupSourceFactory> to lookupSourceFactoryManager : JoinBridgeManager<LookupSourceFactory> in method private innerJoinOperatorFactory(lookupSourceFactoryManager JoinBridgeManager<LookupSourceFactory>, probePages RowPagesBuilder, partitioningSpillerFactory PartitioningSpillerFactory) : OperatorFactory in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Change Parameter Type lookupSourceFactory : JoinBridgeDataManager<LookupSourceFactory> to lookupSourceFactory : JoinBridgeManager<LookupSourceFactory> in method public lookupOuterJoin(operatorId int, planNodeId PlanNodeId, lookupSourceFactory JoinBridgeManager<LookupSourceFactory>, probeTypes List<Type>, probeJoinChannel List<Integer>, probeHashChannel OptionalInt, probeOutputChannels Optional<List<Integer>>, totalOperatorsCount OptionalInt, partitioningSpillerFactory PartitioningSpillerFactory) : OperatorFactory in class com.facebook.presto.operator.LookupJoinOperators |
From |
To |
|
Change Parameter Type lookupSourceFactoryManager : JoinBridgeDataManager<LookupSourceFactory> to lookupSourceFactoryManager : JoinBridgeManager<LookupSourceFactory> in method private probeOuterJoinOperatorFactory(lookupSourceFactoryManager JoinBridgeManager<LookupSourceFactory>, probePages RowPagesBuilder) : OperatorFactory in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Change Parameter Type sharedWrapper : BiFunction<T,Runnable,T> to probeFactoryCount : int in method private internalJoinBridgeDataManager(probeExecutionStrategy PipelineExecutionStrategy, buildExecutionStrategy PipelineExecutionStrategy, joinBridgeProvider Function<Lifespan,T>, probeFactoryCount int, outerFactoryCount int) : InternalJoinBridgeDataManager<T> in class com.facebook.presto.operator.JoinBridgeManager |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testInnerJoinWithNullOnBothSides(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testMemoryLimit(parallelBuild boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testOuterJoinWithNullOnBothSidesAndFilterFunction(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testProbeOuterJoinWithFilterFunction(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testYield() : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testProbeOuterJoinWithEmptyLookupSource(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testInnerJoinWithEmptyLookupSource(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testOuterJoinWithNullProbeAndFilterFunction(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testOuterJoinWithNullBuild(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testInnerJoinWithNullBuild(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testInnerJoin(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testOuterJoinWithNullBuildAndFilterFunction(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testProbeOuterJoin(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testInnerJoinWithNonEmptyLookupSourceAndEmptyProbe(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testOuterJoinWithNullOnBothSides(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testOuterJoinWithNullProbe(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testInnerJoinWithNullProbe(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testLookupOuterJoinWithEmptyLookupSource(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Inline Method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder, filterFunction Optional<InternalJoinFilterFunction>) : JoinBridgeDataManager<LookupSourceFactory> inlined to public testFullOuterJoinWithEmptyLookupSource(parallelBuild boolean, probeHashEnabled boolean, buildHashEnabled boolean) : void in class com.facebook.presto.operator.TestHashJoinOperator |
From |
To |
|
Rename Parameter sharedWrapper : BiFunction<T,Runnable,T> to probeFactoryCount : int in method private internalJoinBridgeDataManager(probeExecutionStrategy PipelineExecutionStrategy, buildExecutionStrategy PipelineExecutionStrategy, joinBridgeProvider Function<Lifespan,T>, probeFactoryCount int, outerFactoryCount int) : InternalJoinBridgeDataManager<T> in class com.facebook.presto.operator.JoinBridgeManager |
From |
To |
|
Rename Parameter lookupSourceFactoryProvider : Function<Lifespan,T> to joinBridgeProvider : Function<Lifespan,T> in method private internalJoinBridgeDataManager(probeExecutionStrategy PipelineExecutionStrategy, buildExecutionStrategy PipelineExecutionStrategy, joinBridgeProvider Function<Lifespan,T>, probeFactoryCount int, outerFactoryCount int) : InternalJoinBridgeDataManager<T> in class com.facebook.presto.operator.JoinBridgeManager |
From |
To |
|
Rename Parameter lookupSourceExecutionStrategy : PipelineExecutionStrategy to buildExecutionStrategy : PipelineExecutionStrategy in method private internalJoinBridgeDataManager(probeExecutionStrategy PipelineExecutionStrategy, buildExecutionStrategy PipelineExecutionStrategy, joinBridgeProvider Function<Lifespan,T>, probeFactoryCount int, outerFactoryCount int) : InternalJoinBridgeDataManager<T> in class com.facebook.presto.operator.JoinBridgeManager |
From |
To |
|
Rename Parameter destroy : Consumer<T> to outerFactoryCount : int in method private internalJoinBridgeDataManager(probeExecutionStrategy PipelineExecutionStrategy, buildExecutionStrategy PipelineExecutionStrategy, joinBridgeProvider Function<Lifespan,T>, probeFactoryCount int, outerFactoryCount int) : InternalJoinBridgeDataManager<T> in class com.facebook.presto.operator.JoinBridgeManager |
From |
To |