|
Change Parameter Type prePartitionedInputs : Set<Symbol> to prePartitionedInputs : Set<VariableReferenceExpression> in method public WindowNode(id PlanNodeId, source PlanNode, specification Specification, windowFunctions Map<VariableReferenceExpression,Function>, hashVariable Optional<VariableReferenceExpression>, prePartitionedInputs Set<VariableReferenceExpression>, preSortedOrderPrefix int) in class com.facebook.presto.sql.planner.plan.WindowNode |
From |
To |
|
Change Parameter Type partitionBy : List<Symbol> to partitionBy : List<VariableReferenceExpression> in method public Specification(partitionBy List<VariableReferenceExpression>, orderingScheme Optional<OrderingScheme>) in class com.facebook.presto.sql.planner.plan.WindowNode.Specification |
From |
To |
|
Change Parameter Type partitionBy : List<Symbol> to partitionBy : List<VariableReferenceExpression> in method public rowNumber(partitionBy List<VariableReferenceExpression>, maxRowCountPerPartition Optional<Integer>, rowNumberSymbol Symbol, rownNumberVariable VariableReferenceExpression, source PlanNode) : RowNumberNode in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder |
From |
To |
|
Change Parameter Type variables : List<VariableReferenceExpression> to variables : Collection<VariableReferenceExpression> in method private getChannelsForVariables(variables Collection<VariableReferenceExpression>, layout Map<Symbol,Integer>) : List<Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner |
From |
To |
|
Change Parameter Type partitionBy : List<Symbol> to partitionBy : List<VariableReferenceExpression> in method public RowNumberNode(id PlanNodeId, source PlanNode, partitionBy List<VariableReferenceExpression>, rowNumberVariable VariableReferenceExpression, maxRowCountPerPartition Optional<Integer>, hashVariable Optional<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.RowNumberNode |
From |
To |
|
Rename Variable partitionBySymbols : ImmutableList.Builder<Symbol> to partitionByVariables : ImmutableList.Builder<VariableReferenceExpression> in method private window(subPlan PlanBuilder, windowFunctions List<FunctionCall>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Rename Variable symbol1 : Symbol to variable1 : VariableReferenceExpression in method private comparePartitionBy(o1 WindowNode, o2 WindowNode) : int in class com.facebook.presto.sql.planner.iterative.rule.GatherAndMergeWindows.SwapAdjacentWindowsBySpecifications |
From |
To |
|
Rename Variable symbol2 : Symbol to variable2 : VariableReferenceExpression in method private comparePartitionBy(o1 WindowNode, o2 WindowNode) : int in class com.facebook.presto.sql.planner.iterative.rule.GatherAndMergeWindows.SwapAdjacentWindowsBySpecifications |
From |
To |
|
Rename Variable groupBySymbol : Symbol to groupByVariable : VariableReferenceExpression in method public doCalculate(node RowNumberNode, statsProvider StatsProvider, lookup Lookup, session Session, types TypeProvider) : Optional<PlanNodeStatsEstimate> in class com.facebook.presto.cost.RowNumberStatsRule |
From |
To |
|
Change Variable Type prePartitionedInputs : Set<Symbol> to prePartitionedInputs : Set<VariableReferenceExpression> in method public testSerializationRoundtrip() : void in class com.facebook.presto.sql.planner.plan.TestWindowNode |
From |
To |
|
Change Variable Type symbol1 : Symbol to variable1 : VariableReferenceExpression in method private comparePartitionBy(o1 WindowNode, o2 WindowNode) : int in class com.facebook.presto.sql.planner.iterative.rule.GatherAndMergeWindows.SwapAdjacentWindowsBySpecifications |
From |
To |
|
Change Variable Type symbol2 : Symbol to variable2 : VariableReferenceExpression in method private comparePartitionBy(o1 WindowNode, o2 WindowNode) : int in class com.facebook.presto.sql.planner.iterative.rule.GatherAndMergeWindows.SwapAdjacentWindowsBySpecifications |
From |
To |
|
Change Variable Type notPrePartitioned : List<Symbol> to notPrePartitioned : List<VariableReferenceExpression> in method public visitWindow(node WindowNode, context Void) : Void in class com.facebook.presto.sql.planner.planPrinter.PlanPrinter.Visitor |
From |
To |
|
Change Variable Type iterator1 : Iterator<Symbol> to iterator1 : Iterator<VariableReferenceExpression> in method private comparePartitionBy(o1 WindowNode, o2 WindowNode) : int in class com.facebook.presto.sql.planner.iterative.rule.GatherAndMergeWindows.SwapAdjacentWindowsBySpecifications |
From |
To |
|
Change Variable Type partitionBySymbols : ImmutableList.Builder<Symbol> to partitionByVariables : ImmutableList.Builder<VariableReferenceExpression> in method private window(subPlan PlanBuilder, windowFunctions List<FunctionCall>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type groupBySymbol : Symbol to groupByVariable : VariableReferenceExpression in method public doCalculate(node RowNumberNode, statsProvider StatsProvider, lookup Lookup, session Session, types TypeProvider) : Optional<PlanNodeStatsEstimate> in class com.facebook.presto.cost.RowNumberStatsRule |
From |
To |
|
Change Variable Type prePartitionedInputs : Set<Symbol> to prePartitionedInputs : Set<VariableReferenceExpression> in method public visitWindow(node WindowNode, parentPreferences StreamPreferredProperties) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddLocalExchanges.Rewriter |
From |
To |
|
Change Variable Type unPartitionedInputs : Set<Symbol> to unPartitionedInputs : Set<VariableReferenceExpression> in method public visitWindow(node WindowNode, parentPreferences StreamPreferredProperties) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddLocalExchanges.Rewriter |
From |
To |
|
Change Variable Type prePartitioned : List<Symbol> to prePartitioned : List<VariableReferenceExpression> in method public visitWindow(node WindowNode, context Void) : Void in class com.facebook.presto.sql.planner.planPrinter.PlanPrinter.Visitor |
From |
To |
|
Change Variable Type iterator2 : Iterator<Symbol> to iterator2 : Iterator<VariableReferenceExpression> in method private comparePartitionBy(o1 WindowNode, o2 WindowNode) : int in class com.facebook.presto.sql.planner.iterative.rule.GatherAndMergeWindows.SwapAdjacentWindowsBySpecifications |
From |
To |
|
Rename Parameter rightSymbols : List<VariableReferenceExpression> to rightVariables : List<VariableReferenceExpression> in method private planPartitionedJoin(node JoinNode, leftVariables List<VariableReferenceExpression>, rightVariables List<VariableReferenceExpression>) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter leftSymbols : List<VariableReferenceExpression> to leftVariables : List<VariableReferenceExpression> in method private planPartitionedJoin(node JoinNode, leftVariables List<VariableReferenceExpression>, rightVariables List<VariableReferenceExpression>) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter rightSymbols : List<VariableReferenceExpression> to rightVariables : List<VariableReferenceExpression> in method private planPartitionedJoin(node JoinNode, leftVariables List<VariableReferenceExpression>, rightVariables List<VariableReferenceExpression>, left PlanWithProperties) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |
|
Rename Parameter leftSymbols : List<VariableReferenceExpression> to leftVariables : List<VariableReferenceExpression> in method private planPartitionedJoin(node JoinNode, leftVariables List<VariableReferenceExpression>, rightVariables List<VariableReferenceExpression>, left PlanWithProperties) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddExchanges.Rewriter |
From |
To |