e2608cdf87298d61dbe9cf45166a38689938d3cc
Files Diff
- Added: 0
- Removed: 0
- Renamed: 0
- Modified: 3
Refactorings reported:
Refactoring Name | Occurences | ||
---|---|---|---|
Change Parameter Type | 1 | ||
Change Parameter Type stageId : StageId to subPlan : SubPlan in method private buildStageInfo(subPlan SubPlan, stageInfos Map<StageId,StageInfo>) : StageInfo in class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Move Method | 1 | ||
Move Method public withBucketToPartition(bucketToPartition Optional<int[]>) : SubPlan from class com.facebook.presto.sql.planner.SubPlan to public withBucketToPartition(bucketToPartition Optional<int[]>) : StreamingSubPlan from class com.facebook.presto.execution.scheduler.SqlQueryScheduler.StreamingSubPlan | From | To | |
Rename Variable | 2 | ||
Rename Variable parent : StageInfo to stageInfo : StageInfo in method private buildStageInfo(subPlan SubPlan, stageInfos Map<StageId,StageInfo>) : StageInfo in class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Rename Variable scheduler : StageScheduler to stage : SqlStageExecution in method private schedule(stages Collection<SqlStageExecution>) : void in class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Change Return Type | 1 | ||
Change Return Type SubPlan to StreamingSubPlan in method public withBucketToPartition(bucketToPartition Optional<int[]>) : StreamingSubPlan in class com.facebook.presto.execution.scheduler.SqlQueryScheduler.StreamingSubPlan | From | To | |
Change Variable Type | 1 | ||
Change Variable Type scheduler : StageScheduler to stage : SqlStageExecution in method private schedule(stages Collection<SqlStageExecution>) : void in class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Inline Variable | 1 | ||
Inline Variable rootStage : SqlStageExecution in method private SqlQueryScheduler(queryStateMachine QueryStateMachine, locationFactory LocationFactory, plan SubPlan, nodePartitioningManager NodePartitioningManager, nodeScheduler NodeScheduler, remoteTaskFactory RemoteTaskFactory, splitSourceFactory SplitSourceFactory, session Session, summarizeTaskInfo boolean, splitBatchSize int, queryExecutor ExecutorService, schedulerExecutor ScheduledExecutorService, failureDetector FailureDetector, rootOutputBuffers OutputBuffers, nodeTaskMap NodeTaskMap, executionPolicy ExecutionPolicy, schedulerStats SplitSchedulerStats) from class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Extract Method | 2 | ||
Extract Method private getStageId(fragmentId PlanFragmentId) : StageId extracted from private createStages(parent ExchangeLocationsConsumer, locationFactory LocationFactory, plan SubPlan, nodeScheduler NodeScheduler, remoteTaskFactory RemoteTaskFactory, splitSourceFactory SplitSourceFactory, 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> in class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Extract Method private createStreamingLinkedStages(parent ExchangeLocationsConsumer, locationFactory LocationFactory, plan StreamingSubPlan, nodeScheduler NodeScheduler, remoteTaskFactory RemoteTaskFactory, splitSourceFactory SplitSourceFactory, 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> extracted from private createStages(parent ExchangeLocationsConsumer, locationFactory LocationFactory, plan SubPlan, nodeScheduler NodeScheduler, remoteTaskFactory RemoteTaskFactory, splitSourceFactory SplitSourceFactory, 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> in class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Rename Parameter | 2 | ||
Rename Parameter stageId : StageId to subPlan : SubPlan in method private buildStageInfo(subPlan SubPlan, stageInfos Map<StageId,StageInfo>) : StageInfo in class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To | |
Rename Parameter parent : ExchangeLocationsConsumer to locationsConsumer : ExchangeLocationsConsumer in method private createStages(locationsConsumer ExchangeLocationsConsumer, locationFactory LocationFactory, section StreamingPlanSection, bucketToPartition Optional<int[]>, outputBuffers OutputBuffers, nodeScheduler NodeScheduler, remoteTaskFactory RemoteTaskFactory, splitSourceFactory SplitSourceFactory, session Session, splitBatchSize int, nodePartitioningManager NodePartitioningManager, queryExecutor ExecutorService, schedulerExecutor ScheduledExecutorService, failureDetector FailureDetector, nodeTaskMap NodeTaskMap, stageSchedulers ImmutableMap.Builder<StageId,StageScheduler>, stageLinkages ImmutableMap.Builder<StageId,StageLinkage>) : List<SqlStageExecution> in class com.facebook.presto.execution.scheduler.SqlQueryScheduler | From | To |