ec00d5b1bccf1a43eeaf2340ebc6b0e109f36838
Files Diff
- Added: 3
- Removed: 0
- Renamed: 0
- Modified: 7
Refactorings reported:
Refactoring Name | Occurences | ||
---|---|---|---|
Rename Class | 1 | ||
Rename Class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler.LifespanScheduler renamed to com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler.FixedLifespanScheduler | From | To | |
Extract Variable | 3 | ||
Extract Variable bucketNodeMap : BucketNodeMap in method private createStages(parent ExchangeLocationsConsumer, nextStageId AtomicInteger, locationFactory LocationFactory, plan StageExecutionPlan, nodeScheduler NodeScheduler, remoteTaskFactory RemoteTaskFactory, session Session, splitBatchSize int, partitioningCache Function<PartitioningHandle,NodePartitionMap>, nodePartitioningManager NodePartitioningManager, queryExecutor ExecutorService, schedulerExecutor ScheduledExecutorService, failureDetector FailureDetector, nodeTaskMap NodeTaskMap, stageSchedulers ImmutableMap.Builder<StageId,StageScheduler>, stageLinkages ImmutableMap.Builder<StageId,StageLinkage>) : List<SqlStageExecution> from class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Extract Variable groupedExecutionForStage : boolean in method private createStages(parent ExchangeLocationsConsumer, nextStageId AtomicInteger, locationFactory LocationFactory, plan StageExecutionPlan, nodeScheduler NodeScheduler, remoteTaskFactory RemoteTaskFactory, session Session, splitBatchSize int, partitioningCache Function<PartitioningHandle,NodePartitionMap>, nodePartitioningManager NodePartitioningManager, queryExecutor ExecutorService, schedulerExecutor ScheduledExecutorService, failureDetector FailureDetector, nodeTaskMap NodeTaskMap, stageSchedulers ImmutableMap.Builder<StageId,StageScheduler>, stageLinkages ImmutableMap.Builder<StageId,StageLinkage>) : List<SqlStageExecution> from class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Extract Variable stageNodeList : List<Node> in method private createStages(parent ExchangeLocationsConsumer, nextStageId AtomicInteger, locationFactory LocationFactory, plan StageExecutionPlan, nodeScheduler NodeScheduler, remoteTaskFactory RemoteTaskFactory, session Session, splitBatchSize int, partitioningCache Function<PartitioningHandle,NodePartitionMap>, nodePartitioningManager NodePartitioningManager, queryExecutor ExecutorService, schedulerExecutor ScheduledExecutorService, failureDetector FailureDetector, nodeTaskMap NodeTaskMap, stageSchedulers ImmutableMap.Builder<StageId,StageScheduler>, stageLinkages ImmutableMap.Builder<StageId,StageLinkage>) : List<SqlStageExecution> from class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Extract Interface | 1 | ||
Extract Interface com.facebook.presto.execution.scheduler.group.LifespanScheduler from classes [com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler.FixedLifespanScheduler] | From | To | |
Extract Method | 1 | ||
Extract Method private getSplitToBucket(session Session, partitioningHandle PartitioningHandle) : ToIntFunction<Split> extracted from public getNodePartitioningMap(session Session, partitioningHandle PartitioningHandle) : NodePartitionMap in class com.facebook.presto.sql.planner.NodePartitioningManager | From | To |