|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitRowNumber(node RowNumberNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type context : PreferredProperties to context : Context in method public visitTableWriter(node TableWriterNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method private pickPlan(possiblePlans List<PlanWithProperties>, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitTopN(node TopNNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitLimit(node LimitNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type context : PreferredProperties to context : Context in method public visitIndexSource(node IndexSourceNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitUnion(node UnionNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitTableCommit(node TableCommitNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method private planTableScan(node TableScanNode, predicate Expression, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitSemiJoin(node SemiJoinNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitTopNRowNumber(node TopNRowNumberNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitSort(node SortNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitValues(node ValuesNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferredProperties : PreferredProperties to context : Context in method public visitIndexJoin(node IndexJoinNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitProject(node ProjectNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitDistinctLimit(node DistinctLimitNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method private planChild(node PlanNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitWindow(node WindowNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitOutput(node OutputNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitMarkDistinct(node MarkDistinctNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method protected visitPlan(node PlanNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitJoin(node JoinNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitAggregation(node AggregationNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitFilter(node FilterNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Change Parameter Type preferred : PreferredProperties to context : Context in method public visitTableScan(node TableScanNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitTableCommit(node TableCommitNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitUnion(node UnionNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method private planTableScan(node TableScanNode, predicate Expression, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method private planChild(node PlanNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitAggregation(node AggregationNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitFilter(node FilterNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitTopNRowNumber(node TopNRowNumberNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitSemiJoin(node SemiJoinNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method protected visitPlan(node PlanNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitTableScan(node TableScanNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitValues(node ValuesNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitSort(node SortNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method private pickPlan(possiblePlans List<PlanWithProperties>, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferredProperties : PreferredProperties to context : Context in method public visitIndexJoin(node IndexJoinNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitProject(node ProjectNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitRowNumber(node RowNumberNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitDistinctLimit(node DistinctLimitNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitWindow(node WindowNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitOutput(node OutputNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitMarkDistinct(node MarkDistinctNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitJoin(node JoinNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitLimit(node LimitNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter preferred : PreferredProperties to context : Context in method public visitTopN(node TopNNode, context Context) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |