|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public PartitionedOutputFactory(partitionFunction PartitionFunction, partitionChannels List<Integer>, partitionConstants List<Optional<NullableValue>>, nullChannel OptionalInt, outputBuffer OutputBuffer, maxMemory DataSize) in class com.facebook.presto.operator.PartitionedOutputOperator.PartitionedOutputFactory |
From |
To |
|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public PagePartitioner(partitionFunction PartitionFunction, partitionChannels List<Integer>, partitionConstants List<Optional<NullableValue>>, nullChannel OptionalInt, outputBuffer OutputBuffer, sourceTypes List<Type>, maxMemory DataSize) in class com.facebook.presto.operator.PartitionedOutputOperator.PagePartitioner |
From |
To |
|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public PartitionedOutputOperator(operatorContext OperatorContext, sourceTypes List<Type>, pagePreprocessor Function<Page,Page>, partitionFunction PartitionFunction, partitionChannels List<Integer>, partitionConstants List<Optional<NullableValue>>, nullChannel OptionalInt, outputBuffer OutputBuffer, maxMemory DataSize) in class com.facebook.presto.operator.PartitionedOutputOperator |
From |
To |
|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public TaskOutputFactory(outputBuffer OutputBuffer) in class com.facebook.presto.operator.TaskOutputOperator.TaskOutputFactory |
From |
To |
|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public createSqlTaskExecution(taskStateMachine TaskStateMachine, taskContext TaskContext, outputBuffer OutputBuffer, fragment PlanFragment, sources List<TaskSource>, planner LocalExecutionPlanner, taskExecutor TaskExecutor, notificationExecutor Executor, queryMonitor QueryMonitor) : SqlTaskExecution in class com.facebook.presto.execution.SqlTaskExecution |
From |
To |
|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public PartitionedOutputOperatorFactory(operatorId int, planNodeId PlanNodeId, sourceTypes List<Type>, pagePreprocessor Function<Page,Page>, partitionFunction PartitionFunction, partitionChannels List<Integer>, partitionConstants List<Optional<NullableValue>>, nullChannel OptionalInt, outputBuffer OutputBuffer, maxMemory DataSize) in class com.facebook.presto.operator.PartitionedOutputOperator.PartitionedOutputOperatorFactory |
From |
To |
|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method private SqlTaskExecution(taskStateMachine TaskStateMachine, taskContext TaskContext, outputBuffer OutputBuffer, fragment PlanFragment, planner LocalExecutionPlanner, taskExecutor TaskExecutor, queryMonitor QueryMonitor, notificationExecutor Executor) in class com.facebook.presto.execution.SqlTaskExecution |
From |
To |
|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public TaskOutputOperatorFactory(operatorId int, planNodeId PlanNodeId, outputBuffer OutputBuffer, pagePreprocessor Function<Page,Page>) in class com.facebook.presto.operator.TaskOutputOperator.TaskOutputOperatorFactory |
From |
To |
|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public TaskOutputOperator(operatorContext OperatorContext, outputBuffer OutputBuffer, pagePreprocessor Function<Page,Page>) in class com.facebook.presto.operator.TaskOutputOperator |
From |
To |
|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public plan(session Session, plan PlanNode, types Map<Symbol,Type>, partitioningScheme PartitioningScheme, outputBuffer OutputBuffer) : LocalExecutionPlan in class com.facebook.presto.sql.planner.LocalExecutionPlanner |
From |
To |
|
Change Parameter Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public create(session Session, queryContext QueryContext, taskStateMachine TaskStateMachine, outputBuffer OutputBuffer, fragment PlanFragment, sources List<TaskSource>) : SqlTaskExecution in class com.facebook.presto.execution.SqlTaskExecutionFactory |
From |
To |
|
Rename Attribute sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.execution.MockRemoteTaskFactory.MockRemoteTask |
From |
To |
|
Rename Attribute sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.PartitionedOutputOperator.PartitionedOutputOperatorFactory |
From |
To |
|
Rename Attribute sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.TaskOutputOperator.TaskOutputOperatorFactory |
From |
To |
|
Rename Attribute sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.execution.SqlTask |
From |
To |
|
Rename Attribute sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.TaskOutputOperator.TaskOutputFactory |
From |
To |
|
Rename Attribute sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.PartitionedOutputOperator.PartitionedOutputFactory |
From |
To |
|
Rename Attribute sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.execution.SqlTaskExecution |
From |
To |
|
Rename Attribute sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.PartitionedOutputOperator.PagePartitioner |
From |
To |
|
Rename Attribute sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.TaskOutputOperator |
From |
To |
|
Change Attribute Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.PartitionedOutputOperator.PartitionedOutputOperatorFactory |
From |
To |
|
Change Attribute Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.TaskOutputOperator.TaskOutputOperatorFactory |
From |
To |
|
Change Attribute Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.execution.SqlTask |
From |
To |
|
Change Attribute Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.PartitionedOutputOperator.PartitionedOutputFactory |
From |
To |
|
Change Attribute Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.TaskOutputOperator.TaskOutputFactory |
From |
To |
|
Change Attribute Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.execution.SqlTaskExecution |
From |
To |
|
Change Attribute Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.PartitionedOutputOperator.PagePartitioner |
From |
To |
|
Change Attribute Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.operator.TaskOutputOperator |
From |
To |
|
Change Attribute Type sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in class com.facebook.presto.execution.MockRemoteTaskFactory.MockRemoteTask |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public PagePartitioner(partitionFunction PartitionFunction, partitionChannels List<Integer>, partitionConstants List<Optional<NullableValue>>, nullChannel OptionalInt, outputBuffer OutputBuffer, sourceTypes List<Type>, maxMemory DataSize) in class com.facebook.presto.operator.PartitionedOutputOperator.PagePartitioner |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public createSqlTaskExecution(taskStateMachine TaskStateMachine, taskContext TaskContext, outputBuffer OutputBuffer, fragment PlanFragment, sources List<TaskSource>, planner LocalExecutionPlanner, taskExecutor TaskExecutor, notificationExecutor Executor, queryMonitor QueryMonitor) : SqlTaskExecution in class com.facebook.presto.execution.SqlTaskExecution |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public TaskOutputFactory(outputBuffer OutputBuffer) in class com.facebook.presto.operator.TaskOutputOperator.TaskOutputFactory |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public PartitionedOutputOperator(operatorContext OperatorContext, sourceTypes List<Type>, pagePreprocessor Function<Page,Page>, partitionFunction PartitionFunction, partitionChannels List<Integer>, partitionConstants List<Optional<NullableValue>>, nullChannel OptionalInt, outputBuffer OutputBuffer, maxMemory DataSize) in class com.facebook.presto.operator.PartitionedOutputOperator |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public PartitionedOutputOperatorFactory(operatorId int, planNodeId PlanNodeId, sourceTypes List<Type>, pagePreprocessor Function<Page,Page>, partitionFunction PartitionFunction, partitionChannels List<Integer>, partitionConstants List<Optional<NullableValue>>, nullChannel OptionalInt, outputBuffer OutputBuffer, maxMemory DataSize) in class com.facebook.presto.operator.PartitionedOutputOperator.PartitionedOutputOperatorFactory |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method private SqlTaskExecution(taskStateMachine TaskStateMachine, taskContext TaskContext, outputBuffer OutputBuffer, fragment PlanFragment, planner LocalExecutionPlanner, taskExecutor TaskExecutor, queryMonitor QueryMonitor, notificationExecutor Executor) in class com.facebook.presto.execution.SqlTaskExecution |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public TaskOutputOperator(operatorContext OperatorContext, outputBuffer OutputBuffer, pagePreprocessor Function<Page,Page>) in class com.facebook.presto.operator.TaskOutputOperator |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public TaskOutputOperatorFactory(operatorId int, planNodeId PlanNodeId, outputBuffer OutputBuffer, pagePreprocessor Function<Page,Page>) in class com.facebook.presto.operator.TaskOutputOperator.TaskOutputOperatorFactory |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public plan(session Session, plan PlanNode, types Map<Symbol,Type>, partitioningScheme PartitioningScheme, outputBuffer OutputBuffer) : LocalExecutionPlan in class com.facebook.presto.sql.planner.LocalExecutionPlanner |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public create(session Session, queryContext QueryContext, taskStateMachine TaskStateMachine, outputBuffer OutputBuffer, fragment PlanFragment, sources List<TaskSource>) : SqlTaskExecution in class com.facebook.presto.execution.SqlTaskExecutionFactory |
From |
To |
|
Rename Parameter sharedBuffer : SharedBuffer to outputBuffer : OutputBuffer in method public PartitionedOutputFactory(partitionFunction PartitionFunction, partitionChannels List<Integer>, partitionConstants List<Optional<NullableValue>>, nullChannel OptionalInt, outputBuffer OutputBuffer, maxMemory DataSize) in class com.facebook.presto.operator.PartitionedOutputOperator.PartitionedOutputFactory |
From |
To |