|
Rename Method public simpleSourcePartitionedScheduler(stage SqlStageExecution, partitionedNode PlanNodeId, splitSource SplitSource, splitPlacementPolicy SplitPlacementPolicy, splitBatchSize int) : SourcePartitionedScheduler renamed to public newSourcePartitionedSchedulerAsStageScheduler(stage SqlStageExecution, partitionedNode PlanNodeId, splitSource SplitSource, splitPlacementPolicy SplitPlacementPolicy, splitBatchSize int) : StageScheduler in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Rename Method public managedSourcePartitionedScheduler(stage SqlStageExecution, partitionedNode PlanNodeId, splitSource SplitSource, splitPlacementPolicy SplitPlacementPolicy, splitBatchSize int) : SourcePartitionedScheduler renamed to public newSourcePartitionedSchedulerAsSourceScheduler(stage SqlStageExecution, partitionedNode PlanNodeId, splitSource SplitSource, splitPlacementPolicy SplitPlacementPolicy, splitBatchSize int) : SourceScheduler in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Rename Variable sourcePartitionedSchedulers : ArrayList<SourcePartitionedScheduler> to sourceSchedulers : ArrayList<SourceScheduler> in method public FixedSourcePartitionedScheduler(stage SqlStageExecution, splitSources Map<PlanNodeId,SplitSource>, pipelineExecutionStrategy PipelineExecutionStrategy, schedulingOrder List<PlanNodeId>, partitioning NodePartitionMap, splitBatchSize int, concurrentLifespans OptionalInt, nodeSelector NodeSelector, partitionHandles List<ConnectorPartitionHandle>) in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |
|
Rename Variable sourcePartitionedScheduler : SourcePartitionedScheduler to sourceScheduler : SourceScheduler in method public close() : void in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |
|
Rename Variable sourcePartitionedScheduler : SourcePartitionedScheduler to sourceScheduler : SourceScheduler in method public schedule() : ScheduleResult in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |
|
Rename Variable sourcePartitionedScheduler : SourcePartitionedScheduler to sourceScheduler : SourceScheduler in method public FixedSourcePartitionedScheduler(stage SqlStageExecution, splitSources Map<PlanNodeId,SplitSource>, pipelineExecutionStrategy PipelineExecutionStrategy, schedulingOrder List<PlanNodeId>, partitioning NodePartitionMap, splitBatchSize int, concurrentLifespans OptionalInt, nodeSelector NodeSelector, partitionHandles List<ConnectorPartitionHandle>) in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |
|
Change Return Type SourcePartitionedScheduler to SourceScheduler in method public newSourcePartitionedSchedulerAsSourceScheduler(stage SqlStageExecution, partitionedNode PlanNodeId, splitSource SplitSource, splitPlacementPolicy SplitPlacementPolicy, splitBatchSize int) : SourceScheduler in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Change Return Type SourcePartitionedScheduler to StageScheduler in method private getSourcePartitionedScheduler(plan StageExecutionPlan, stage SqlStageExecution, nodeManager InternalNodeManager, nodeTaskMap NodeTaskMap, splitBatchSize int) : StageScheduler in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Return Type SourcePartitionedScheduler to StageScheduler in method public newSourcePartitionedSchedulerAsStageScheduler(stage SqlStageExecution, partitionedNode PlanNodeId, splitSource SplitSource, splitPlacementPolicy SplitPlacementPolicy, splitBatchSize int) : StageScheduler in class com.facebook.presto.execution.scheduler.SourcePartitionedScheduler |
From |
To |
|
Change Variable Type firstScheduler : SourcePartitionedScheduler to firstScheduler : StageScheduler in method public testBlockCausesFullSchedule() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type sourcePartitionedScheduler : SourcePartitionedScheduler to sourceScheduler : SourceScheduler in method public FixedSourcePartitionedScheduler(stage SqlStageExecution, splitSources Map<PlanNodeId,SplitSource>, pipelineExecutionStrategy PipelineExecutionStrategy, schedulingOrder List<PlanNodeId>, partitioning NodePartitionMap, splitBatchSize int, concurrentLifespans OptionalInt, nodeSelector NodeSelector, partitionHandles List<ConnectorPartitionHandle>) in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |
|
Change Variable Type sourcePartitionedScheduler : SourcePartitionedScheduler to sourceScheduler : SourceScheduler in method public close() : void in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |
|
Change Variable Type secondScheduler : SourcePartitionedScheduler to secondScheduler : StageScheduler in method public testBalancedSplitAssignment() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type sourcePartitionedScheduler : SourcePartitionedScheduler to sourceScheduler : SourceScheduler in method public schedule() : ScheduleResult in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |
|
Change Variable Type scheduler : SourcePartitionedScheduler to scheduler : StageScheduler in method public testScheduleSplitsBatched() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type firstScheduler : SourcePartitionedScheduler to firstScheduler : StageScheduler in method public testBalancedSplitAssignment() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type scheduler : SourcePartitionedScheduler to scheduler : StageScheduler in method public testScheduleSplitsBlock() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type scheduler : SourcePartitionedScheduler to scheduler : StageScheduler in method public testScheduleNoSplits() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type sourcePartitionedSchedulers : ArrayList<SourcePartitionedScheduler> to sourceSchedulers : ArrayList<SourceScheduler> in method public FixedSourcePartitionedScheduler(stage SqlStageExecution, splitSources Map<PlanNodeId,SplitSource>, pipelineExecutionStrategy PipelineExecutionStrategy, schedulingOrder List<PlanNodeId>, partitioning NodePartitionMap, splitBatchSize int, concurrentLifespans OptionalInt, nodeSelector NodeSelector, partitionHandles List<ConnectorPartitionHandle>) in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |
|
Change Variable Type scheduler : SourcePartitionedScheduler to scheduler : StageScheduler in method public testScheduleSplitsOneAtATime() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type secondScheduler : SourcePartitionedScheduler to secondScheduler : StageScheduler in method public testBlockCausesFullSchedule() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type scheduler : SourcePartitionedScheduler to scheduler : StageScheduler in method public testScheduleSlowSplitSource() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type schedulerIterator : Iterator<SourcePartitionedScheduler> to schedulerIterator : Iterator<SourceScheduler> in method public schedule() : ScheduleResult in class com.facebook.presto.execution.scheduler.FixedSourcePartitionedScheduler |
From |
To |