|
Change Parameter Type groupIdSymbol : Optional<Symbol> to groupIdVariable : Optional<VariableReferenceExpression> in method public AggregationNode(id PlanNodeId, source PlanNode, aggregations Map<VariableReferenceExpression,Aggregation>, groupingSets GroupingSetDescriptor, preGroupedVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.AggregationNode |
From |
To |
|
Change Parameter Type availableSymbols : Set<Symbol> to availableVariables : Set<VariableReferenceExpression> in method private getPushedDownGroupingSet(aggregation AggregationNode, availableVariables Set<VariableReferenceExpression>, requiredJoinVariables Set<VariableReferenceExpression>) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Change Parameter Type groupingKeys : List<Symbol> to groupingKeys : List<VariableReferenceExpression> in method public GroupingSetDescriptor(groupingKeys List<VariableReferenceExpression>, groupingSetCount int, globalGroupingSets Set<Integer>) in class com.facebook.presto.sql.planner.plan.AggregationNode.GroupingSetDescriptor |
From |
To |
|
Change Parameter Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method private createHashAggregationOperatorFactory(planNodeId PlanNodeId, aggregations Map<VariableReferenceExpression,Aggregation>, globalGroupingSets Set<Integer>, groupbyVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>, source PhysicalOperation, hasDefaultOutput boolean, spillEnabled boolean, isStreamable boolean, unspillMemoryLimit DataSize, context LocalExecutionPlanContext, startOutputChannel int, outputMappings ImmutableMap.Builder<VariableReferenceExpression,Integer>, expectedGroups int, maxPartialAggregationMemorySize Optional<DataSize>, useSystemMemory boolean) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type columns : List<Symbol> to columns : List<VariableReferenceExpression> in method private groupsOnAllColumns(node AggregationNode, columns List<VariableReferenceExpression>) : boolean in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin |
From |
To |
|
Change Parameter Type distinctSymbol : Symbol to distinctVariable : VariableReferenceExpression in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Parameter Type originalColumns : List<Symbol> to originalColumns : List<VariableReferenceExpression> in method private computeCounts(sourceNode UnionNode, originalColumns List<VariableReferenceExpression>, markers List<VariableReferenceExpression>, aggregationOutputs List<VariableReferenceExpression>) : AggregationNode in class com.facebook.presto.sql.planner.optimizations.ImplementIntersectAndExceptAsUnion.Rewriter |
From |
To |
|
Change Parameter Type groupBySymbols : Collection<Symbol> to groupByVariables : Collection<VariableReferenceExpression> in method public groupBy(sourceStats PlanNodeStatsEstimate, groupByVariables Collection<VariableReferenceExpression>, aggregations Map<VariableReferenceExpression,Aggregation>) : PlanNodeStatsEstimate in class com.facebook.presto.cost.AggregationStatsRule |
From |
To |
|
Change Parameter Type partitionSymbols : List<Symbol> to partitionVariables : List<VariableReferenceExpression> in method private canSkipHashGeneration(partitionVariables List<VariableReferenceExpression>) : boolean in class com.facebook.presto.sql.planner.optimizations.HashGenerationOptimizer.Rewriter |
From |
To |
|
Change Parameter Type groupingKeys : List<Symbol> to groupingKeys : List<VariableReferenceExpression> in method public groupingSets(groupingKeys List<VariableReferenceExpression>, groupingSetCount int, globalGroupingSets Set<Integer>) : GroupingSetDescriptor in class com.facebook.presto.sql.planner.plan.AggregationNode |
From |
To |
|
Change Parameter Type distinctSymbols : List<Symbol> to distinctVariables : List<VariableReferenceExpression> in method public MarkDistinctNode(id PlanNodeId, source PlanNode, markerVariable VariableReferenceExpression, distinctVariables List<VariableReferenceExpression>, hashVariable Optional<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.MarkDistinctNode |
From |
To |
|
Change Parameter Type distinctSymbols : List<Symbol> to distinctVariables : List<VariableReferenceExpression> in method public markDistinct(markerVariable VariableReferenceExpression, distinctVariables List<VariableReferenceExpression>, hashVariable VariableReferenceExpression, source PlanNode) : MarkDistinctNode in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder |
From |
To |
|
Change Parameter Type distinctSymbols : List<Symbol> to distinctVariables : List<VariableReferenceExpression> in method public markDistinct(markerVariable VariableReferenceExpression, distinctVariables List<VariableReferenceExpression>, source PlanNode) : MarkDistinctNode in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder |
From |
To |
|
Change Parameter Type symbols : Symbol... to variables : VariableReferenceExpression... in method public singleGroupingSet(variables VariableReferenceExpression...) : AggregationBuilder in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder.AggregationBuilder |
From |
To |
|
Change Parameter Type groupIdSymbol : Optional<Symbol> to groupIdVariable : Optional<VariableReferenceExpression> in method private handleGroupingOperations(subPlan PlanBuilder, node QuerySpecification, groupIdVariable Optional<VariableReferenceExpression>, groupingSets List<Set<FieldId>>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Parameter Type groupBySymbols : List<Symbol> to groupByVariables : List<VariableReferenceExpression> in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Parameter Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method private createAggregationOperatorFactory(planNodeId PlanNodeId, aggregations Map<VariableReferenceExpression,Aggregation>, step Step, startOutputChannel int, outputMappings ImmutableMap.Builder<VariableReferenceExpression,Integer>, source PhysicalOperation, context LocalExecutionPlanContext, useSystemMemory boolean) : AggregationOperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type groupbySymbols : List<Symbol> to groupbyVariables : List<VariableReferenceExpression> in method private createHashAggregationOperatorFactory(planNodeId PlanNodeId, aggregations Map<VariableReferenceExpression,Aggregation>, globalGroupingSets Set<Integer>, groupbyVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>, source PhysicalOperation, hasDefaultOutput boolean, spillEnabled boolean, isStreamable boolean, unspillMemoryLimit DataSize, context LocalExecutionPlanContext, startOutputChannel int, outputMappings ImmutableMap.Builder<VariableReferenceExpression,Integer>, expectedGroups int, maxPartialAggregationMemorySize Optional<DataSize>, useSystemMemory boolean) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type groupingKeys : List<Symbol> to groupingKeys : List<VariableReferenceExpression> in method public singleGroupingSet(groupingKeys List<VariableReferenceExpression>) : GroupingSetDescriptor in class com.facebook.presto.sql.planner.plan.AggregationNode |
From |
To |
|
Change Parameter Type groupIdSymbol : Symbol to groupIdVariable : VariableReferenceExpression in method public GroupIdNode(id PlanNodeId, source PlanNode, groupingSets List<List<VariableReferenceExpression>>, groupingColumns Map<VariableReferenceExpression,VariableReferenceExpression>, aggregationArguments List<VariableReferenceExpression>, groupIdVariable VariableReferenceExpression) in class com.facebook.presto.sql.planner.plan.GroupIdNode |
From |
To |
|
Change Parameter Type preGroupedSymbols : List<Symbol> to preGroupedVariables : List<VariableReferenceExpression> in method public AggregationNode(id PlanNodeId, source PlanNode, aggregations Map<VariableReferenceExpression,Aggregation>, groupingSets GroupingSetDescriptor, preGroupedVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.AggregationNode |
From |
To |
|
Change Parameter Type groupingKeys : List<Symbol> to groupingKeys : List<VariableReferenceExpression> in method private replaceAggregationSource(aggregation AggregationNode, source PlanNode, groupingKeys List<VariableReferenceExpression>) : AggregationNode in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Change Parameter Type groupIdSymbol : Optional<Symbol> to groupIdVariable : Optional<VariableReferenceExpression> in method private createHashAggregationOperatorFactory(planNodeId PlanNodeId, aggregations Map<VariableReferenceExpression,Aggregation>, globalGroupingSets Set<Integer>, groupbyVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>, source PhysicalOperation, hasDefaultOutput boolean, spillEnabled boolean, isStreamable boolean, unspillMemoryLimit DataSize, context LocalExecutionPlanContext, startOutputChannel int, outputMappings ImmutableMap.Builder<VariableReferenceExpression,Integer>, expectedGroups int, maxPartialAggregationMemorySize Optional<DataSize>, useSystemMemory boolean) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type groupingSets : List<List<Symbol>> to groupingSets : List<List<VariableReferenceExpression>> in method public GroupIdNode(id PlanNodeId, source PlanNode, groupingSets List<List<VariableReferenceExpression>>, groupingColumns Map<VariableReferenceExpression,VariableReferenceExpression>, aggregationArguments List<VariableReferenceExpression>, groupIdVariable VariableReferenceExpression) in class com.facebook.presto.sql.planner.plan.GroupIdNode |
From |
To |
|
Change Parameter Type distinctSymbols : List<Symbol> to distinctVariables : List<VariableReferenceExpression> in method public DistinctLimitNode(id PlanNodeId, source PlanNode, limit long, partial boolean, distinctVariables List<VariableReferenceExpression>, hashVariable Optional<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.DistinctLimitNode |
From |
To |
|
Change Parameter Type groupByKeys : Set<Symbol> to groupByKeys : Set<VariableReferenceExpression> in method private createNonDistinctAggregation(aggregateInfo AggregateInfo, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupByKeys Set<VariableReferenceExpression>, groupIdNode GroupIdNode, originalNode MarkDistinctNode, aggregationOutputSymbolsMapBuilder ImmutableMap.Builder<VariableReferenceExpression,VariableReferenceExpression>) : AggregationNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Parameter Type nonDistinctAggregateSymbols : List<Symbol> to nonDistinctAggregateVariables : List<VariableReferenceExpression> in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Parameter Type groupingColumns : Map<Symbol,Symbol> to groupingColumns : Map<VariableReferenceExpression,VariableReferenceExpression> in method public GroupIdNode(id PlanNodeId, source PlanNode, groupingSets List<List<VariableReferenceExpression>>, groupingColumns Map<VariableReferenceExpression,VariableReferenceExpression>, aggregationArguments List<VariableReferenceExpression>, groupIdVariable VariableReferenceExpression) in class com.facebook.presto.sql.planner.plan.GroupIdNode |
From |
To |
|
Change Parameter Type symbols : Symbol... to variables : VariableReferenceExpression... in method public preGroupedVariables(variables VariableReferenceExpression...) : AggregationBuilder in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder.AggregationBuilder |
From |
To |
|
Change Parameter Type actualSymbols : Collection<Symbol> to actualVariables : Collection<VariableReferenceExpression> in method package matches(expectedAliases Collection<String>, actualVariables Collection<VariableReferenceExpression>, symbolAliases SymbolAliases) : boolean in class com.facebook.presto.sql.planner.assertions.AggregationMatcher |
From |
To |
|
Change Parameter Type groupIdSymbol : Optional<Symbol> to groupIdVariable : Optional<VariableReferenceExpression> in method public rewriteGroupingOperation(expression GroupingOperation, groupingSets List<Set<Integer>>, columnReferenceFields Map<NodeRef<Expression>,FieldId>, groupIdVariable Optional<VariableReferenceExpression>) : Expression in class com.facebook.presto.sql.planner.GroupingOperationRewriter |
From |
To |
|
Change Parameter Type aggregationArguments : List<Symbol> to aggregationArguments : List<VariableReferenceExpression> in method public GroupIdNode(id PlanNodeId, source PlanNode, groupingSets List<List<VariableReferenceExpression>>, groupingColumns Map<VariableReferenceExpression,VariableReferenceExpression>, aggregationArguments List<VariableReferenceExpression>, groupIdVariable VariableReferenceExpression) in class com.facebook.presto.sql.planner.plan.GroupIdNode |
From |
To |
|
Change Parameter Type groupSymbol : Symbol to groupVariable : VariableReferenceExpression in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Parameter Type groupBySymbols : List<Symbol> to groupByVariables : List<VariableReferenceExpression> in method public AggregateInfo(groupByVariables List<VariableReferenceExpression>, mask VariableReferenceExpression, aggregations Map<VariableReferenceExpression,Aggregation>, types TypeProvider) in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.AggregateInfo |
From |
To |
|
Rename Variable distinctSymbol : Symbol to distinctVariable : VariableReferenceExpression in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Variable groupSymbol : Symbol to groupVariable : VariableReferenceExpression in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method private checkAllEquatableTypes(aggregateInfo AggregateInfo) : boolean in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Variable distinctSymbols : ImmutableSet.Builder<Symbol> to distinctVariables : ImmutableSet.Builder<VariableReferenceExpression> in method public apply(parent AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.MultipleDistinctAggregationToMarkDistinct |
From |
To |
|
Rename Variable joinLeftChildSymbols : Set<Symbol> to joinLeftChildVariables : Set<VariableReferenceExpression> in method private pushPartialToLeftChild(node AggregationNode, child JoinNode, context Context) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Rename Variable nonDistinctAggregateSymbols : List<Symbol> to nonDistinctAggregateVariables : List<VariableReferenceExpression> in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method private createHashAggregationOperatorFactory(planNodeId PlanNodeId, aggregations Map<VariableReferenceExpression,Aggregation>, globalGroupingSets Set<Integer>, groupbyVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>, source PhysicalOperation, hasDefaultOutput boolean, spillEnabled boolean, isStreamable boolean, unspillMemoryLimit DataSize, context LocalExecutionPlanContext, startOutputChannel int, outputMappings ImmutableMap.Builder<VariableReferenceExpression,Integer>, expectedGroups int, maxPartialAggregationMemorySize Optional<DataSize>, useSystemMemory boolean) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable existingSymbols : Set<Symbol> to existingVariables : Set<VariableReferenceExpression> in method private getPushedDownGroupingSet(aggregation AggregationNode, availableVariables Set<VariableReferenceExpression>, requiredJoinVariables Set<VariableReferenceExpression>) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Rename Variable groupBySymbols : List<Symbol> to groupByVariables : List<VariableReferenceExpression> in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Variable joinRightChildSymbols : Set<Symbol> to joinRightChildVariables : Set<VariableReferenceExpression> in method private pushPartialToRightChild(node AggregationNode, child JoinNode, context Context) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method private createProjectNode(source AggregationNode, aggregateInfo AggregateInfo, distinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, groupByVariables List<VariableReferenceExpression>, aggregationOutputVariablesMap Map<VariableReferenceExpression,VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Variable duplicatedDistinctSymbol : Symbol to duplicatedDistinctVariable : VariableReferenceExpression in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Variable pushDownableSymbols : Set<Symbol> to pushDownableVariables : Set<VariableReferenceExpression> in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Variable groupIdSymbol : Optional<Symbol> to groupIdVariable : Optional<VariableReferenceExpression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Rename Variable allSymbols : Set<Symbol> to allVariables : Set<VariableReferenceExpression> in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Variable symbol : Symbol to symbolName : String in method package matches(expectedAliases Collection<String>, actualVariables Collection<VariableReferenceExpression>, symbolAliases SymbolAliases) : boolean in class com.facebook.presto.sql.planner.assertions.AggregationMatcher |
From |
To |
|
Rename Variable expectedSymbols : List<Symbol> to expectedSymbolNames : List<String> in method package matches(expectedAliases Collection<String>, actualVariables Collection<VariableReferenceExpression>, symbolAliases SymbolAliases) : boolean in class com.facebook.presto.sql.planner.assertions.AggregationMatcher |
From |
To |
|
Rename Variable symbols : Set<Symbol> to variables : Set<VariableReferenceExpression> in method public apply(aggregation AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.SingleDistinctAggregationToGroupBy |
From |
To |
|
Rename Variable newSymbol : Symbol to newVariable : VariableReferenceExpression in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type inputGroupingSetSymbols : List<List<Symbol>> to inputGroupingSetSymbols : List<List<VariableReferenceExpression>> in method public visitGroupId(node GroupIdNode, context Void) : Void in class com.facebook.presto.sql.planner.planPrinter.PlanPrinter.Visitor |
From |
To |
|
Change Variable Type groupingSet : List<Symbol> to groupingSet : List<VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method private createHashAggregationOperatorFactory(planNodeId PlanNodeId, aggregations Map<VariableReferenceExpression,Aggregation>, globalGroupingSets Set<Integer>, groupbyVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>, source PhysicalOperation, hasDefaultOutput boolean, spillEnabled boolean, isStreamable boolean, unspillMemoryLimit DataSize, context LocalExecutionPlanContext, startOutputChannel int, outputMappings ImmutableMap.Builder<VariableReferenceExpression,Integer>, expectedGroups int, maxPartialAggregationMemorySize Optional<DataSize>, useSystemMemory boolean) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type newGroupingMapping : Map<Symbol,Symbol> to newGroupingMapping : Map<VariableReferenceExpression,VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type newGroupingSets : ImmutableList.Builder<List<Symbol>> to newGroupingSets : ImmutableList.Builder<List<VariableReferenceExpression>> in method public visitGroupId(node GroupIdNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type mappings : ImmutableMap.Builder<Symbol,Integer> to mappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method private planGroupByAggregation(node AggregationNode, source PhysicalOperation, spillEnabled boolean, unspillMemoryLimit DataSize, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type groups : List<List<Symbol>> to groups : List<List<VariableReferenceExpression>> in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type argumentMappings : Map<Symbol,Integer> to argumentMappings : Map<VariableReferenceExpression,Integer> in method public visitGroupId(node GroupIdNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type input : Symbol to input : VariableReferenceExpression in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type allSymbols : Set<Symbol> to allVariables : Set<VariableReferenceExpression> in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type partitioningColumns : List<Symbol> to partitioningColumns : List<VariableReferenceExpression> in method public apply(aggregationNode AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughExchange |
From |
To |
|
Change Variable Type aggregationArgumentsBuilder : ImmutableList.Builder<Symbol> to aggregationArgumentsBuilder : ImmutableList.Builder<VariableReferenceExpression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type output : Symbol to output : VariableReferenceExpression in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type markers : Map<Set<Symbol>,VariableReferenceExpression> to markers : Map<Set<VariableReferenceExpression>,VariableReferenceExpression> in method public apply(parent AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.MultipleDistinctAggregationToMarkDistinct |
From |
To |
|
Change Variable Type argument : Symbol to argument : VariableReferenceExpression in method public visitGroupId(node GroupIdNode, inputProperties List<ActualProperties>) : ActualProperties in class com.facebook.presto.sql.planner.optimizations.PropertyDerivations.Visitor |
From |
To |
|
Change Variable Type pushedDownGroupingSet : List<Symbol> to pushedDownGroupingSet : List<VariableReferenceExpression> in method private getPushedDownGroupingSet(aggregation AggregationNode, availableVariables Set<VariableReferenceExpression>, requiredJoinVariables Set<VariableReferenceExpression>) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Change Variable Type groupSymbol : Symbol to groupVariable : VariableReferenceExpression in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type actualGroups : List<List<Symbol>> to actualGroups : List<List<VariableReferenceExpression>> in method public detailMatches(node PlanNode, stats StatsProvider, session Session, metadata Metadata, symbolAliases SymbolAliases) : MatchResult in class com.facebook.presto.sql.planner.assertions.GroupIdMatcher |
From |
To |
|
Change Variable Type groupingKeys : List<Symbol> to groupingKeys : List<VariableReferenceExpression> in method public apply(aggregation AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin |
From |
To |
|
Change Variable Type outputs : ImmutableList.Builder<Symbol> to outputs : ImmutableList.Builder<VariableReferenceExpression> in method public AggregationNode(id PlanNodeId, source PlanNode, aggregations Map<VariableReferenceExpression,Aggregation>, groupingSets GroupingSetDescriptor, preGroupedVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.AggregationNode |
From |
To |
|
Change Variable Type groupBySymbols : List<Symbol> to groupByVariables : List<VariableReferenceExpression> in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method private createProjectNode(source AggregationNode, aggregateInfo AggregateInfo, distinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, groupByVariables List<VariableReferenceExpression>, aggregationOutputVariablesMap Map<VariableReferenceExpression,VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type actualAggregationArguments : List<Symbol> to actualAggregationArguments : List<VariableReferenceExpression> in method public detailMatches(node PlanNode, stats StatsProvider, session Session, metadata Metadata, symbolAliases SymbolAliases) : MatchResult in class com.facebook.presto.sql.planner.assertions.GroupIdMatcher |
From |
To |
|
Change Variable Type duplicatedDistinctSymbol : Symbol to duplicatedDistinctVariable : VariableReferenceExpression in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type pushDownableSymbols : Set<Symbol> to pushDownableVariables : Set<VariableReferenceExpression> in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type preGroupedSymbols : List<Symbol> to preGroupedSymbols : List<VariableReferenceExpression> in method public visitAggregation(node AggregationNode, parentPreferences StreamPreferredProperties) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddLocalExchanges.Rewriter |
From |
To |
|
Change Variable Type redundantVariablesBuilder : ImmutableSet.Builder<String> to redundantVariablesBuilder : ImmutableSet.Builder<VariableReferenceExpression> in method private pruneMarkDistinctVariables(node MarkDistinctNode, localProperties List<LocalProperty<VariableReferenceExpression>>) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.AddLocalExchanges.Rewriter |
From |
To |
|
Change Variable Type aggregationArguments : List<Symbol> to aggregationArguments : List<VariableReferenceExpression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type isDistinct : Symbol to isDistinct : VariableReferenceExpression in method public apply(lateralJoinNode LateralJoinNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.TransformCorrelatedScalarSubquery |
From |
To |
|
Change Variable Type groupingSets : List<List<Symbol>> to groupingSets : List<List<VariableReferenceExpression>> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type expectedInputs : ImmutableSet.Builder<Symbol> to expectedInputs : ImmutableSet.Builder<VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type newAggregationArguments : List<Symbol> to newAggregationArguments : List<VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type groupingSetBuilder : ImmutableList.Builder<List<Symbol>> to groupingSetBuilder : ImmutableList.Builder<List<VariableReferenceExpression>> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method private checkAllEquatableTypes(aggregateInfo AggregateInfo) : boolean in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type outputMapping : ImmutableMap.Builder<Symbol,Integer> to outputMapping : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method public visitTableWriter(node TableWriterNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type groupingSet : List<Symbol> to groupingSet : List<VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type joinLeftChildSymbols : Set<Symbol> to joinLeftChildVariables : Set<VariableReferenceExpression> in method private pushPartialToLeftChild(node AggregationNode, child JoinNode, context Context) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Change Variable Type newGroupingSets : ImmutableList.Builder<List<Symbol>> to newGroupingSets : ImmutableList.Builder<List<VariableReferenceExpression>> in method public visitGroupId(node GroupIdNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type group1 : Set<Symbol> to group1 : Set<VariableReferenceExpression> in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type groupingSetMappings : Map<Symbol,Symbol> to groupingSetMappings : Map<VariableReferenceExpression,VariableReferenceExpression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type outputMapping : ImmutableMap.Builder<Symbol,Integer> to outputMapping : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method public visitTableFinish(node TableFinishNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type output : Symbol to output : VariableReferenceExpression in method public visitGroupId(node GroupIdNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type existingSymbols : Set<Symbol> to existingVariables : Set<VariableReferenceExpression> in method private getPushedDownGroupingSet(aggregation AggregationNode, availableVariables Set<VariableReferenceExpression>, requiredJoinVariables Set<VariableReferenceExpression>) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Change Variable Type joinRightChildSymbols : Set<Symbol> to joinRightChildVariables : Set<VariableReferenceExpression> in method private pushPartialToRightChild(node AggregationNode, child JoinNode, context Context) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Change Variable Type redundantVariables : Set<String> to redundantVariables : Set<VariableReferenceExpression> in method private pruneMarkDistinctVariables(node MarkDistinctNode, localProperties List<LocalProperty<VariableReferenceExpression>>) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.AddLocalExchanges.Rewriter |
From |
To |
|
Change Variable Type remainingSymbols : List<Symbol> to remainingSymbols : List<VariableReferenceExpression> in method private pruneMarkDistinctVariables(node MarkDistinctNode, localProperties List<LocalProperty<VariableReferenceExpression>>) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.AddLocalExchanges.Rewriter |
From |
To |
|
Change Variable Type groupIdSymbol : Optional<Symbol> to groupIdVariable : Optional<VariableReferenceExpression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type group0 : Set<Symbol> to group0 : Set<VariableReferenceExpression> in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type aggregationOutput : Map<Symbol,Integer> to aggregationOutput : Map<VariableReferenceExpression,Integer> in method public visitTableFinish(node TableFinishNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type expectedSymbols : List<Symbol> to expectedSymbolNames : List<String> in method package matches(expectedAliases Collection<String>, actualVariables Collection<VariableReferenceExpression>, symbolAliases SymbolAliases) : boolean in class com.facebook.presto.sql.planner.assertions.AggregationMatcher |
From |
To |
|
Change Variable Type columns : ImmutableList.Builder<Symbol> to columns : ImmutableList.Builder<VariableReferenceExpression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type newSymbol : Symbol to newVariable : VariableReferenceExpression in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type mapping : Map.Entry<Symbol,Symbol> to mapping : Map.Entry<VariableReferenceExpression,VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, context Void) : Void in class com.facebook.presto.sql.planner.planPrinter.PlanPrinter.Visitor |
From |
To |
|
Change Variable Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method private planGlobalAggregation(node AggregationNode, source PhysicalOperation, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type distinctSymbol : Symbol to distinctVariable : VariableReferenceExpression in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type setMapping : Map.Entry<Symbol,Symbol> to setMapping : Map.Entry<VariableReferenceExpression,VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, inputProperties List<StreamProperties>) : StreamProperties in class com.facebook.presto.sql.planner.optimizations.StreamPropertyDerivations.Visitor |
From |
To |
|
Change Variable Type groupingSet : List<Symbol> to groupingSet : List<VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type distinctSymbols : ImmutableSet.Builder<Symbol> to distinctVariables : ImmutableSet.Builder<VariableReferenceExpression> in method public apply(parent AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.MultipleDistinctAggregationToMarkDistinct |
From |
To |
|
Change Variable Type groupingKeys : ImmutableList.Builder<Symbol> to groupingKeys : ImmutableList.Builder<VariableReferenceExpression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type intersection : Set<Symbol> to intersection : Set<VariableReferenceExpression> in method public getCommonGroupingColumns() : Set<VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.GroupIdNode |
From |
To |
|
Change Variable Type groupingSet : List<Symbol> to groupingSet : List<VariableReferenceExpression> in method private pushPartialToLeftChild(node AggregationNode, child JoinNode, context Context) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Change Variable Type inputs : Set<Symbol> to inputs : Set<VariableReferenceExpression> in method public apply(parent AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.MultipleDistinctAggregationToMarkDistinct |
From |
To |
|
Change Variable Type output : Symbol to output : VariableReferenceExpression in method public visitGroupId(node GroupIdNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type groupingKeys : List<Symbol> to groupingKeys : List<VariableReferenceExpression> in method public visitAggregation(node AggregationNode, parentPreferences StreamPreferredProperties) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.AddLocalExchanges.Rewriter |
From |
To |
|
Change Variable Type symbol : Symbol to symbolName : String in method package matches(expectedAliases Collection<String>, actualVariables Collection<VariableReferenceExpression>, symbolAliases SymbolAliases) : boolean in class com.facebook.presto.sql.planner.assertions.AggregationMatcher |
From |
To |
|
Change Variable Type argument : Symbol to argument : VariableReferenceExpression in method public visitGroupId(node GroupIdNode, inputProperties List<StreamProperties>) : StreamProperties in class com.facebook.presto.sql.planner.optimizations.StreamPropertyDerivations.Visitor |
From |
To |
|
Change Variable Type symbols : Set<Symbol> to variables : Set<VariableReferenceExpression> in method public apply(aggregation AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.SingleDistinctAggregationToGroupBy |
From |
To |
|
Change Variable Type setMapping : Map.Entry<Symbol,Symbol> to setMapping : Map.Entry<VariableReferenceExpression,VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, inputProperties List<ActualProperties>) : ActualProperties in class com.facebook.presto.sql.planner.optimizations.PropertyDerivations.Visitor |
From |
To |
|
Change Variable Type newGroupingSet : ImmutableList.Builder<Symbol> to newGroupingSet : ImmutableList.Builder<VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type newGroupingMappings : Map<Symbol,Symbol> to newGroupingMappings : Map<VariableReferenceExpression,VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type nonDistinctAggregateSymbols : List<Symbol> to nonDistinctAggregateVariables : List<VariableReferenceExpression> in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type groupingSet : List<Symbol> to groupingSet : List<VariableReferenceExpression> in method private getPushedDownGroupingSet(aggregation AggregationNode, availableVariables Set<VariableReferenceExpression>, requiredJoinVariables Set<VariableReferenceExpression>) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Change Variable Type groupingSet : List<Symbol> to groupingSet : List<VariableReferenceExpression> in method private pushPartialToRightChild(node AggregationNode, child JoinNode, context Context) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Change Variable Type newGroupingSet : ImmutableList.Builder<Symbol> to newGroupingSet : ImmutableList.Builder<VariableReferenceExpression> in method public visitGroupId(node GroupIdNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type groupByKeys : Set<Symbol> to groupByKeys : Set<VariableReferenceExpression> in method public visitMarkDistinct(node MarkDistinctNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type output : Symbol to output : VariableReferenceExpression in method public visitGroupId(node GroupIdNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Rename Parameter distinctSymbols : List<Symbol> to distinctVariables : List<VariableReferenceExpression> in method public DistinctLimitNode(id PlanNodeId, source PlanNode, limit long, partial boolean, distinctVariables List<VariableReferenceExpression>, hashVariable Optional<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.DistinctLimitNode |
From |
To |
|
Rename Parameter groupIdSymbol : Optional<Symbol> to groupIdVariable : Optional<VariableReferenceExpression> in method private handleGroupingOperations(subPlan PlanBuilder, node QuerySpecification, groupIdVariable Optional<VariableReferenceExpression>, groupingSets List<Set<FieldId>>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Rename Parameter groupBySymbols : List<Symbol> to groupByVariables : List<VariableReferenceExpression> in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Parameter nonDistinctAggregateSymbols : List<Symbol> to nonDistinctAggregateVariables : List<VariableReferenceExpression> in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Parameter groupBySymbols : Collection<Symbol> to groupByVariables : Collection<VariableReferenceExpression> in method public groupBy(sourceStats PlanNodeStatsEstimate, groupByVariables Collection<VariableReferenceExpression>, aggregations Map<VariableReferenceExpression,Aggregation>) : PlanNodeStatsEstimate in class com.facebook.presto.cost.AggregationStatsRule |
From |
To |
|
Rename Parameter partitionSymbols : List<Symbol> to partitionVariables : List<VariableReferenceExpression> in method private canSkipHashGeneration(partitionVariables List<VariableReferenceExpression>) : boolean in class com.facebook.presto.sql.planner.optimizations.HashGenerationOptimizer.Rewriter |
From |
To |
|
Rename Parameter actualSymbols : Collection<Symbol> to actualVariables : Collection<VariableReferenceExpression> in method package matches(expectedAliases Collection<String>, actualVariables Collection<VariableReferenceExpression>, symbolAliases SymbolAliases) : boolean in class com.facebook.presto.sql.planner.assertions.AggregationMatcher |
From |
To |
|
Rename Parameter distinctSymbols : List<Symbol> to distinctVariables : List<VariableReferenceExpression> in method public MarkDistinctNode(id PlanNodeId, source PlanNode, markerVariable VariableReferenceExpression, distinctVariables List<VariableReferenceExpression>, hashVariable Optional<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.MarkDistinctNode |
From |
To |
|
Rename Parameter distinctSymbols : List<Symbol> to distinctVariables : List<VariableReferenceExpression> in method public markDistinct(markerVariable VariableReferenceExpression, distinctVariables List<VariableReferenceExpression>, hashVariable VariableReferenceExpression, source PlanNode) : MarkDistinctNode in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder |
From |
To |
|
Rename Parameter groupIdSymbol : Optional<Symbol> to groupIdVariable : Optional<VariableReferenceExpression> in method private createHashAggregationOperatorFactory(planNodeId PlanNodeId, aggregations Map<VariableReferenceExpression,Aggregation>, globalGroupingSets Set<Integer>, groupbyVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>, source PhysicalOperation, hasDefaultOutput boolean, spillEnabled boolean, isStreamable boolean, unspillMemoryLimit DataSize, context LocalExecutionPlanContext, startOutputChannel int, outputMappings ImmutableMap.Builder<VariableReferenceExpression,Integer>, expectedGroups int, maxPartialAggregationMemorySize Optional<DataSize>, useSystemMemory boolean) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Parameter groupBySymbols : List<Symbol> to groupByVariables : List<VariableReferenceExpression> in method public AggregateInfo(groupByVariables List<VariableReferenceExpression>, mask VariableReferenceExpression, aggregations Map<VariableReferenceExpression,Aggregation>, types TypeProvider) in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.AggregateInfo |
From |
To |
|
Rename Parameter distinctSymbols : List<Symbol> to distinctVariables : List<VariableReferenceExpression> in method public markDistinct(markerVariable VariableReferenceExpression, distinctVariables List<VariableReferenceExpression>, source PlanNode) : MarkDistinctNode in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder |
From |
To |
|
Rename Parameter symbols : Symbol... to variables : VariableReferenceExpression... in method public singleGroupingSet(variables VariableReferenceExpression...) : AggregationBuilder in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder.AggregationBuilder |
From |
To |
|
Rename Parameter groupSymbol : Symbol to groupVariable : VariableReferenceExpression in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Parameter groupIdSymbol : Optional<Symbol> to groupIdVariable : Optional<VariableReferenceExpression> in method public AggregationNode(id PlanNodeId, source PlanNode, aggregations Map<VariableReferenceExpression,Aggregation>, groupingSets GroupingSetDescriptor, preGroupedVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.AggregationNode |
From |
To |
|
Rename Parameter preGroupedSymbols : List<Symbol> to preGroupedVariables : List<VariableReferenceExpression> in method public AggregationNode(id PlanNodeId, source PlanNode, aggregations Map<VariableReferenceExpression,Aggregation>, groupingSets GroupingSetDescriptor, preGroupedVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.AggregationNode |
From |
To |
|
Rename Parameter availableSymbols : Set<Symbol> to availableVariables : Set<VariableReferenceExpression> in method private getPushedDownGroupingSet(aggregation AggregationNode, availableVariables Set<VariableReferenceExpression>, requiredJoinVariables Set<VariableReferenceExpression>) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin |
From |
To |
|
Rename Parameter groupbySymbols : List<Symbol> to groupbyVariables : List<VariableReferenceExpression> in method private createHashAggregationOperatorFactory(planNodeId PlanNodeId, aggregations Map<VariableReferenceExpression,Aggregation>, globalGroupingSets Set<Integer>, groupbyVariables List<VariableReferenceExpression>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdVariable Optional<VariableReferenceExpression>, source PhysicalOperation, hasDefaultOutput boolean, spillEnabled boolean, isStreamable boolean, unspillMemoryLimit DataSize, context LocalExecutionPlanContext, startOutputChannel int, outputMappings ImmutableMap.Builder<VariableReferenceExpression,Integer>, expectedGroups int, maxPartialAggregationMemorySize Optional<DataSize>, useSystemMemory boolean) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Parameter distinctSymbol : Symbol to distinctVariable : VariableReferenceExpression in method private createGroupIdNode(groupByVariables List<VariableReferenceExpression>, nonDistinctAggregateVariables List<VariableReferenceExpression>, distinctVariable VariableReferenceExpression, duplicatedDistinctVariable VariableReferenceExpression, groupVariable VariableReferenceExpression, allVariables Set<VariableReferenceExpression>, source PlanNode) : GroupIdNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Rename Parameter groupIdSymbol : Symbol to groupIdVariable : VariableReferenceExpression in method public GroupIdNode(id PlanNodeId, source PlanNode, groupingSets List<List<VariableReferenceExpression>>, groupingColumns Map<VariableReferenceExpression,VariableReferenceExpression>, aggregationArguments List<VariableReferenceExpression>, groupIdVariable VariableReferenceExpression) in class com.facebook.presto.sql.planner.plan.GroupIdNode |
From |
To |
|
Rename Parameter symbols : Symbol... to variables : VariableReferenceExpression... in method public preGroupedVariables(variables VariableReferenceExpression...) : AggregationBuilder in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder.AggregationBuilder |
From |
To |
|
Rename Parameter groupIdSymbol : Optional<Symbol> to groupIdVariable : Optional<VariableReferenceExpression> in method public rewriteGroupingOperation(expression GroupingOperation, groupingSets List<Set<Integer>>, columnReferenceFields Map<NodeRef<Expression>,FieldId>, groupIdVariable Optional<VariableReferenceExpression>) : Expression in class com.facebook.presto.sql.planner.GroupingOperationRewriter |
From |
To |