6d27491a7af2c60fa883c697b8d214c66933fa1b
Files Diff
- Added: 4
- Removed: 3
- Renamed: 0
- Modified: 19
Refactorings reported:
Refactoring Name | Occurences | ||
---|---|---|---|
Change Parameter Type | 3 | ||
Change Parameter Type columns : Collection<Symbol> to columns : Iterable<Symbol> in method public isPartitionedOn(columns Iterable<Symbol>) : boolean in class com.facebook.presto.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties | From | To | |
Change Parameter Type probeTypes : List<Type> to joinType : JoinType in method public LookupJoinOperator(operatorContext OperatorContext, types List<Type>, joinType JoinType, lookupSourceFuture ListenableFuture<LookupSource>, joinProbeFactory JoinProbeFactory, onClose Runnable) in class com.facebook.presto.operator.LookupJoinOperator | From | To | |
Change Parameter Type joinPosition : long to joinPosition : int in method private encodePartitionedJoinPosition(partition int, joinPosition int) : long in class com.facebook.presto.operator.PartitionedLookupSource | From | To | |
Move Method | 3 | ||
Move Method public getLookupSource(operatorContext OperatorContext) : ListenableFuture<LookupSource> from class com.facebook.presto.operator.ParallelLookupSourceSupplier to public getLookupSource() : ListenableFuture<LookupSource> from class com.facebook.presto.operator.SettableLookupSourceSupplier | From | To | |
Move Method public retain() : void from class com.facebook.presto.operator.SettableLookupSourceSupplier to public retain() : void from class com.facebook.presto.operator.ReferenceCount | From | To | |
Move Method public release() : void from class com.facebook.presto.operator.SettableLookupSourceSupplier to public release() : void from class com.facebook.presto.operator.ReferenceCount | From | To | |
Move Attribute | 9 | ||
Move Attribute private closed : boolean from class com.facebook.presto.operator.LookupOuterOperator.OuterPositionTracker to private closed : boolean from class com.facebook.presto.operator.LookupOuterOperator | From | To | |
Move Attribute private types : List<Type> from class com.facebook.presto.operator.ParallelHashBuilder.ParallelHashCollectOperatorFactory to private types : List<Type> from class com.facebook.presto.operator.PartitionedLookupSourceSupplier | From | To | |
Move Attribute private closed : boolean from class com.facebook.presto.operator.HashBuilderOperator.HashBuilderOperatorFactory to private closed : boolean from class com.facebook.presto.operator.LookupOuterOperator | From | To | |
Move Attribute private types : List<Type> from class com.facebook.presto.operator.ParallelHashBuilder.ParallelHashCollectOperator to private types : List<Type> from class com.facebook.presto.operator.PartitionedLookupSourceSupplier | From | To | |
Move Attribute private taskContext : TaskContext from class com.facebook.presto.operator.SharedLookupSource to private taskContext : TaskContext from class com.facebook.presto.operator.index.IndexLookupSourceSupplier | From | To | |
Move Attribute private closed : boolean from class com.facebook.presto.operator.LookupOuterOperator.LookupOuterOperatorFactory to private closed : boolean from class com.facebook.presto.operator.LookupOuterOperator | From | To | |
Move Attribute private closed : boolean from class com.facebook.presto.operator.LookupOuterOperator.OuterPositionIterator to private closed : boolean from class com.facebook.presto.operator.LookupOuterOperator | From | To | |
Move Attribute private closed : boolean from class com.facebook.presto.operator.ParallelHashBuilder.ParallelHashBuilderOperatorFactory to private closed : boolean from class com.facebook.presto.operator.LookupOuterOperator | From | To | |
Move Attribute private types : List<Type> from class com.facebook.presto.operator.LookupJoinOperatorFactory to private types : List<Type> from class com.facebook.presto.operator.PartitionedLookupSourceSupplier | From | To | |
Extract Class | 3 | ||
Extract Class com.facebook.presto.operator.PartitionedLookupSourceSupplier from class com.facebook.presto.operator.ParallelHashBuilder.ParallelHashCollectOperator | From | To | |
Extract Class com.facebook.presto.operator.PartitionedLookupSourceSupplier from class com.facebook.presto.operator.ParallelHashBuilder.ParallelHashCollectOperatorFactory | From | To | |
Extract Class com.facebook.presto.operator.ReferenceCount from class com.facebook.presto.operator.SettableLookupSourceSupplier | From | To | |
Move And Rename Class | 2 | ||
Move And Rename Class com.facebook.presto.operator.ParallelHashBuilder.ParallelHashCollectOperator moved and renamed to com.facebook.presto.operator.ParallelHashBuildOperator | From | To | |
Move And Rename Class com.facebook.presto.operator.ParallelHashBuilder.ParallelHashCollectOperatorFactory moved and renamed to com.facebook.presto.operator.ParallelHashBuildOperator.ParallelHashBuildOperatorFactory | From | To | |
Move Class | 1 | ||
Move Class com.facebook.presto.operator.LookupOuterOperator.OuterLookupSource moved to com.facebook.presto.operator.OuterLookupSource | From | To | |
Change Variable Type | 3 | ||
Change Variable Type preferredPartitionColumns : Optional<Set<Symbol>> to preferredPartitionColumns : Optional<List<Symbol>> in method public visitUnion(node UnionNode, preferredProperties StreamPreferredProperties) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddLocalExchanges.Rewriter | From | To | |
Change Variable Type collectOperatorFactory : OperatorFactory to sinkOperatorFactory : LocalExchangeSinkOperatorFactory in method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder) : LookupSourceSupplier in class com.facebook.presto.operator.TestHashJoinOperator | From | To | |
Change Variable Type requiredPartitionColumns : Optional<Set<Symbol>> to requiredPartitionColumns : Optional<List<Symbol>> in method private enforce(planWithProperties PlanWithProperties, requiredProperties StreamPreferredProperties) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddLocalExchanges.Rewriter | From | To | |
Extract Variable | 4 | ||
Extract Variable operatorFactory : OperatorFactory in method private createLookupJoinSource(node JoinNode, buildNode PlanNode, buildSymbols List<Symbol>, buildHashSymbol Optional<Symbol>, context LocalExecutionPlanContext) : LookupSourceSupplier from class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor | From | To | |
Extract Variable availableSymbols : ImmutableSet<Symbol> in method public constrainTo(symbols Iterable<Symbol>) : StreamPreferredProperties from class com.facebook.presto.sql.planner.optimizations.StreamPreferredProperties | From | To | |
Extract Variable buildPreference : StreamPreferredProperties in method public visitJoin(node JoinNode, parentPreferences StreamPreferredProperties) : PlanWithProperties from class com.facebook.presto.sql.planner.optimizations.AddLocalExchanges.Rewriter | From | To | |
Extract Variable lookupSource : LookupSource in method public finish() : void from class com.facebook.presto.operator.HashBuilderOperator | From | To | |
Inline Variable | 1 | ||
Inline Variable lookupSource : LookupSource in method public appendTo(partitionedJoinPosition long, pageBuilder PageBuilder, outputChannelOffset int) : void from class com.facebook.presto.operator.PartitionedLookupSource | From | To | |
Extract Method | 4 | ||
Extract Method private decodePartition(partitionedJoinPosition long) : int extracted from public appendTo(partitionedJoinPosition long, pageBuilder PageBuilder, outputChannelOffset int) : void in class com.facebook.presto.operator.PartitionedLookupSource | From | To | |
Extract Method private processRawHash(rawHash long) : int extracted from public getPartition(position int, page Page) : int in class com.facebook.presto.operator.exchange.LocalPartitionGenerator | From | To | |
Extract Method private decodePartition(partitionedJoinPosition long) : int extracted from public getNextJoinPosition(partitionedJoinPosition long) : long in class com.facebook.presto.operator.PartitionedLookupSource | From | To | |
Extract Method public getRawHash(position int, page Page) : long extracted from public getPartition(position int, page Page) : int in class com.facebook.presto.operator.exchange.LocalPartitionGenerator | From | To | |
Rename Variable | 1 | ||
Rename Variable collectOperatorFactory : OperatorFactory to sinkOperatorFactory : LocalExchangeSinkOperatorFactory in method private buildHash(parallelBuild boolean, taskContext TaskContext, hashChannels List<Integer>, buildPages RowPagesBuilder) : LookupSourceSupplier in class com.facebook.presto.operator.TestHashJoinOperator | From | To | |
Change Return Type | 2 | ||
Change Return Type Optional<Set<Symbol>> to Optional<List<Symbol>> in method public getPartitioningColumns() : Optional<List<Symbol>> in class com.facebook.presto.sql.planner.optimizations.StreamPreferredProperties | From | To | |
Change Return Type Optional<Set<Symbol>> to Optional<List<Symbol>> in method public getPartitioningColumns() : Optional<List<Symbol>> in class com.facebook.presto.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties | From | To | |
Rename Attribute | 1 | ||
Rename Attribute partitionFutures : List<SettableFuture<PagesIndex>> to preComputedHashChannel : Optional<Integer> in class com.facebook.presto.operator.ParallelHashBuildOperator.ParallelHashBuildOperatorFactory | From | To | |
Change Attribute Type | 4 | ||
Change Attribute Type partitioningColumns : Optional<Set<Symbol>> to partitioningColumns : Optional<List<Symbol>> in class com.facebook.presto.sql.planner.optimizations.StreamPreferredProperties | From | To | |
Change Attribute Type partitioningColumns : Optional<Set<Symbol>> to partitioningColumns : Optional<List<Symbol>> in class com.facebook.presto.sql.planner.optimizations.StreamPropertyDerivations.StreamProperties | From | To | |
Change Attribute Type lookupSourceFuture : SettableFuture<SharedLookupSource> to lookupSourceFuture : SettableFuture<LookupSource> in class com.facebook.presto.operator.SettableLookupSourceSupplier | From | To | |
Change Attribute Type partitionFutures : List<SettableFuture<PagesIndex>> to preComputedHashChannel : Optional<Integer> in class com.facebook.presto.operator.ParallelHashBuildOperator.ParallelHashBuildOperatorFactory | From | To | |
Rename Parameter | 3 | ||
Rename Parameter probeTypes : List<Type> to types : List<Type> in method public LookupJoinOperator(operatorContext OperatorContext, types List<Type>, joinType JoinType, lookupSourceFuture ListenableFuture<LookupSource>, joinProbeFactory JoinProbeFactory, onClose Runnable) in class com.facebook.presto.operator.LookupJoinOperator | From | To | |
Rename Parameter probeTypes : List<Type> to joinType : JoinType in method public LookupJoinOperator(operatorContext OperatorContext, types List<Type>, joinType JoinType, lookupSourceFuture ListenableFuture<LookupSource>, joinProbeFactory JoinProbeFactory, onClose Runnable) in class com.facebook.presto.operator.LookupJoinOperator | From | To | |
Rename Parameter hashChannel : Optional<Integer> to preComputedHashChannel : Optional<Integer> in method public ParallelHashBuildOperatorFactory(operatorId int, planNodeId PlanNodeId, types List<Type>, hashChannels List<Integer>, preComputedHashChannel Optional<Integer>, outer boolean, expectedPositions int, partitionCount int) in class com.facebook.presto.operator.ParallelHashBuildOperator.ParallelHashBuildOperatorFactory | From | To |