|
Change Parameter Type plan : StageExecutionPlan to plan : SubPlan 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) in class com.facebook.presto.execution.scheduler.SqlQueryScheduler |
From |
To |
|
Change Parameter Type tableScanPlan : StageExecutionPlan to tableScanPlan : SubPlan in method private createSqlStageExecution(tableScanPlan SubPlan, nodeTaskMap NodeTaskMap) : SqlStageExecution in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Parameter Type root : SubPlan to fragment : PlanFragment in method public createSplitSources(fragment PlanFragment, session Session) : Map<PlanNodeId,SplitSource> in class com.facebook.presto.sql.planner.SplitSourceFactory |
From |
To |
|
Change Parameter Type plan : StageExecutionPlan to plan : SubPlan in method private createStages(parent ExchangeLocationsConsumer, nextStageId AtomicInteger, 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 |
|
Change Parameter Type plan : StageExecutionPlan to plan : SubPlan in method public createSqlQueryScheduler(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) : SqlQueryScheduler in class com.facebook.presto.execution.scheduler.SqlQueryScheduler |
From |
To |
|
Change Parameter Type splitManager : SplitManager to splitSourceProvider : SplitSourceProvider in method public SplitSourceFactory(splitSourceProvider SplitSourceProvider) in class com.facebook.presto.sql.planner.SplitSourceFactory |
From |
To |
|
Change Variable Type subStagePlan : StageExecutionPlan to subStagePlan : SubPlan in method private createStages(parent ExchangeLocationsConsumer, nextStageId AtomicInteger, 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 |
|
Change Variable Type plan : StageExecutionPlan to plan : SubPlan in method public testScheduleSlowSplitSource() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type secondPlan : StageExecutionPlan to secondPlan : SubPlan in method public testBlockCausesFullSchedule() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type plan : StageExecutionPlan to plan : SubPlan in method public testScheduleNoSplits() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type plan : StageExecutionPlan to plan : SubPlan in method public testNoNodes() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type firstPlan : StageExecutionPlan to firstPlan : SubPlan in method public testBlockCausesFullSchedule() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type secondPlan : StageExecutionPlan to secondPlan : SubPlan in method public testBalancedSplitAssignment() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type plan : StageExecutionPlan to plan : SubPlan in method public testScheduleSplitsBatched() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type plan : StageExecutionPlan to plan : SubPlan in method public testScheduleSplitsOneAtATime() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type plan : StageExecutionPlan to plan : SubPlan in method public testScheduleSplitsBlock() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |
|
Change Variable Type firstPlan : StageExecutionPlan to firstPlan : SubPlan in method public testBalancedSplitAssignment() : void in class com.facebook.presto.execution.scheduler.TestSourcePartitionedScheduler |
From |
To |