| 
                                Change Parameter Type	aggregations : Map<Symbol,Aggregation> to aggregations : Map<VariableReferenceExpression,Aggregation> in method public StatisticAggregations(aggregations Map<VariableReferenceExpression,Aggregation>, groupingVariables List<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.StatisticAggregations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	descriptor : StatisticAggregationsDescriptor<Symbol> to descriptor : StatisticAggregationsDescriptor<VariableReferenceExpression> in method public StatisticsWriterNode(id PlanNodeId, source PlanNode, target WriteStatisticsTarget, rowCountVariable VariableReferenceExpression, rowCountEnabled boolean, descriptor StatisticAggregationsDescriptor<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.StatisticsWriterNode | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	statisticsAggregationDescriptor : Optional<StatisticAggregationsDescriptor<Symbol>> to statisticsAggregationDescriptor : Optional<StatisticAggregationsDescriptor<VariableReferenceExpression>> in method public TableFinishNode(id PlanNodeId, source PlanNode, target WriterTarget, rowCountVariable VariableReferenceExpression, statisticsAggregation Optional<StatisticAggregations>, statisticsAggregationDescriptor Optional<StatisticAggregationsDescriptor<VariableReferenceExpression>>) in class com.facebook.presto.sql.planner.plan.TableFinishNode | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	statisticsAggregationDescriptor : Optional<StatisticAggregationsDescriptor<Symbol>> to statisticsAggregationDescriptor : Optional<StatisticAggregationsDescriptor<VariableReferenceExpression>> in method public TableWriterNode(id PlanNodeId, source PlanNode, target WriterTarget, rowCountSymbol Symbol, fragmentSymbol Symbol, tableCommitContextSymbol Symbol, columns List<Symbol>, columnNames List<String>, partitioningScheme Optional<PartitioningScheme>, statisticsAggregation Optional<StatisticAggregations>, statisticsAggregationDescriptor Optional<StatisticAggregationsDescriptor<VariableReferenceExpression>>) in class com.facebook.presto.sql.planner.plan.TableWriterNode | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	mappings : Map<Symbol,Symbol> to mappings : Map<VariableReferenceExpression,VariableReferenceExpression> in method public Parts(partialAggregation StatisticAggregations, finalAggregation StatisticAggregations, mappings Map<VariableReferenceExpression,VariableReferenceExpression>) in class com.facebook.presto.sql.planner.plan.StatisticAggregations.Parts | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	descriptor : StatisticAggregationsDescriptor<Symbol> to descriptor : StatisticAggregationsDescriptor<VariableReferenceExpression> in method private map(descriptor StatisticAggregationsDescriptor<VariableReferenceExpression>) : StatisticAggregationsDescriptor<VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.SymbolMapper | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	columnToSymbolMap : Map<String,Symbol> to columnToVariableMap : Map<String,VariableReferenceExpression> in method public createStatisticsAggregation(statisticsMetadata TableStatisticsMetadata, columnToVariableMap Map<String,VariableReferenceExpression>) : TableStatisticAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	input : Symbol to input : VariableReferenceExpression in method private createColumnAggregation(statisticType ColumnStatisticType, input VariableReferenceExpression) : ColumnStatisticsAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	descriptor : StatisticAggregationsDescriptor<Symbol> to descriptor : StatisticAggregationsDescriptor<VariableReferenceExpression> in method private TableStatisticAggregation(aggregations StatisticAggregations, descriptor StatisticAggregationsDescriptor<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner.TableStatisticAggregation | 
                                From | 
                                To | 
                            
                            
                            
                            
                            
                            
                            
                                 | 
                                Rename Variable	groupingSymbols : List<Symbol> to groupingVariables : List<VariableReferenceExpression> in method public createStatisticsAggregation(statisticsMetadata TableStatisticsMetadata, columnToVariableMap Map<String,VariableReferenceExpression>) : TableStatisticAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	columnNameToSymbol : ImmutableMap.Builder<String,Symbol> to columnNameToVariable : ImmutableMap.Builder<String,VariableReferenceExpression> in method private createAnalyzePlan(analysis Analysis, analyzeStatement Analyze) : RelationPlan in class com.facebook.presto.sql.planner.LogicalPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	symbol : Symbol to variable : VariableReferenceExpression in method private createAnalyzePlan(analysis Analysis, analyzeStatement Analyze) : RelationPlan in class com.facebook.presto.sql.planner.LogicalPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	partialSymbol : Symbol to partialVariable : VariableReferenceExpression in method public createPartialAggregations(symbolAllocator SymbolAllocator, functionManager FunctionManager) : Parts in class com.facebook.presto.sql.planner.plan.StatisticAggregations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	symbol : Symbol to variable : VariableReferenceExpression in method public createStatisticsAggregation(statisticsMetadata TableStatisticsMetadata, columnToVariableMap Map<String,VariableReferenceExpression>) : TableStatisticAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	columnToSymbolMap : Map<String,Symbol> to columnToVariableMap : Map<String,VariableReferenceExpression> in method private createTableWriterPlan(analysis Analysis, plan RelationPlan, target WriterTarget, columnNames List<String>, writeTableLayout Optional<NewTableLayout>, statisticsMetadata TableStatisticsMetadata) : RelationPlan in class com.facebook.presto.sql.planner.LogicalPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	inputSymbol : Symbol to inputVariable : VariableReferenceExpression in method public createStatisticsAggregation(statisticsMetadata TableStatisticsMetadata, columnToVariableMap Map<String,VariableReferenceExpression>) : TableStatisticAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                            
                            
                            
                            
                                 | 
                                Change Return Type	Optional<StatisticAggregationsDescriptor<Symbol>> to Optional<StatisticAggregationsDescriptor<VariableReferenceExpression>> in method public getStatisticsAggregationDescriptor() : Optional<StatisticAggregationsDescriptor<VariableReferenceExpression>> in class com.facebook.presto.sql.planner.plan.TableFinishNode | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Return Type	Map<Symbol,Aggregation> to Map<VariableReferenceExpression,Aggregation> in method public getAggregations() : Map<VariableReferenceExpression,Aggregation> in class com.facebook.presto.sql.planner.plan.StatisticAggregations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Return Type	StatisticAggregationsDescriptor<Symbol> to StatisticAggregationsDescriptor<VariableReferenceExpression> in method public getDescriptor() : StatisticAggregationsDescriptor<VariableReferenceExpression> in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner.TableStatisticAggregation | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Return Type	Optional<StatisticAggregationsDescriptor<Symbol>> to Optional<StatisticAggregationsDescriptor<VariableReferenceExpression>> in method public getStatisticsAggregationDescriptor() : Optional<StatisticAggregationsDescriptor<VariableReferenceExpression>> in class com.facebook.presto.sql.planner.plan.TableWriterNode | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Return Type	StatisticAggregationsDescriptor<Symbol> to StatisticAggregationsDescriptor<VariableReferenceExpression> in method public getDescriptor() : StatisticAggregationsDescriptor<VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.StatisticsWriterNode | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Return Type	Map<Symbol,Symbol> to Map<VariableReferenceExpression,VariableReferenceExpression> in method public getMappings() : Map<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.StatisticAggregations.Parts | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Return Type	StatisticAggregationsDescriptor<Symbol> to StatisticAggregationsDescriptor<VariableReferenceExpression> in method private map(descriptor StatisticAggregationsDescriptor<VariableReferenceExpression>) : StatisticAggregationsDescriptor<VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.SymbolMapper | 
                                From | 
                                To | 
                            
                            
                            
                            
                            
                            
                            
                                 | 
                                Change Variable Type	finalAggregation : ImmutableMap.Builder<Symbol,Aggregation> to finalAggregation : ImmutableMap.Builder<VariableReferenceExpression,Aggregation> in method public createPartialAggregations(symbolAllocator SymbolAllocator, functionManager FunctionManager) : Parts in class com.facebook.presto.sql.planner.plan.StatisticAggregations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	descriptor : StatisticAggregationsDescriptor<Symbol> to descriptor : StatisticAggregationsDescriptor<VariableReferenceExpression> in method public visitStatisticsWriterNode(node StatisticsWriterNode, boundSymbols Set<Symbol>) : Void in class com.facebook.presto.sql.planner.sanity.ValidateDependenciesChecker.Visitor | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	entry : Map.Entry<Symbol,Aggregation> to entry : Map.Entry<VariableReferenceExpression,Aggregation> in method public createPartialAggregations(symbolAllocator SymbolAllocator, functionManager FunctionManager) : Parts in class com.facebook.presto.sql.planner.plan.StatisticAggregations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	descriptor : StatisticAggregationsDescriptor.Builder<Symbol> to descriptor : StatisticAggregationsDescriptor.Builder<VariableReferenceExpression> in method public createStatisticsAggregation(statisticsMetadata TableStatisticsMetadata, columnToVariableMap Map<String,VariableReferenceExpression>) : TableStatisticAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	mappings : ImmutableMap.Builder<Symbol,Symbol> to mappings : ImmutableMap.Builder<VariableReferenceExpression,VariableReferenceExpression> in method public createPartialAggregations(symbolAllocator SymbolAllocator, functionManager FunctionManager) : Parts in class com.facebook.presto.sql.planner.plan.StatisticAggregations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	columnNameToSymbol : ImmutableMap.Builder<String,Symbol> to columnNameToVariable : ImmutableMap.Builder<String,VariableReferenceExpression> in method private createAnalyzePlan(analysis Analysis, analyzeStatement Analyze) : RelationPlan in class com.facebook.presto.sql.planner.LogicalPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	partialSymbol : Symbol to partialVariable : VariableReferenceExpression in method public createPartialAggregations(symbolAllocator SymbolAllocator, functionManager FunctionManager) : Parts in class com.facebook.presto.sql.planner.plan.StatisticAggregations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	aggregations : Map<Symbol,Aggregation> to aggregations : Map<VariableReferenceExpression,Aggregation> in method private map(statisticAggregations StatisticAggregations) : StatisticAggregations in class com.facebook.presto.sql.planner.optimizations.SymbolMapper | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	symbol : Symbol to variable : VariableReferenceExpression in method private createAnalyzePlan(analysis Analysis, analyzeStatement Analyze) : RelationPlan in class com.facebook.presto.sql.planner.LogicalPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	columnToSymbolMap : Map<String,Symbol> to columnToVariableMap : Map<String,VariableReferenceExpression> in method private createTableWriterPlan(analysis Analysis, plan RelationPlan, target WriterTarget, columnNames List<String>, writeTableLayout Optional<NewTableLayout>, statisticsMetadata TableStatisticsMetadata) : RelationPlan in class com.facebook.presto.sql.planner.LogicalPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	symbol : Symbol to variable : VariableReferenceExpression in method public createStatisticsAggregation(statisticsMetadata TableStatisticsMetadata, columnToVariableMap Map<String,VariableReferenceExpression>) : TableStatisticAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	partialAggregation : ImmutableMap.Builder<Symbol,Aggregation> to partialAggregation : ImmutableMap.Builder<VariableReferenceExpression,Aggregation> in method public createPartialAggregations(symbolAllocator SymbolAllocator, functionManager FunctionManager) : Parts in class com.facebook.presto.sql.planner.plan.StatisticAggregations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	inputSymbol : Symbol to inputVariable : VariableReferenceExpression in method public createStatisticsAggregation(statisticsMetadata TableStatisticsMetadata, columnToVariableMap Map<String,VariableReferenceExpression>) : TableStatisticAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	groupingSymbols : List<Symbol> to groupingVariables : List<VariableReferenceExpression> in method public createStatisticsAggregation(statisticsMetadata TableStatisticsMetadata, columnToVariableMap Map<String,VariableReferenceExpression>) : TableStatisticAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	aggregations : ImmutableMap.Builder<Symbol,AggregationNode.Aggregation> to aggregations : ImmutableMap.Builder<VariableReferenceExpression,AggregationNode.Aggregation> in method public createStatisticsAggregation(statisticsMetadata TableStatisticsMetadata, columnToVariableMap Map<String,VariableReferenceExpression>) : TableStatisticAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                            
                            
                            
                            
                                 | 
                                Change Attribute Type	statisticsAggregationDescriptor : Optional<StatisticAggregationsDescriptor<Symbol>> to statisticsAggregationDescriptor : Optional<StatisticAggregationsDescriptor<VariableReferenceExpression>> in class com.facebook.presto.sql.planner.plan.TableWriterNode | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Attribute Type	mappings : Map<Symbol,Symbol> to mappings : Map<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.StatisticAggregations.Parts | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Attribute Type	groupingSymbols : List<Symbol> to groupingVariables : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.StatisticAggregations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Attribute Type	aggregations : Map<Symbol,Aggregation> to aggregations : Map<VariableReferenceExpression,Aggregation> in class com.facebook.presto.sql.planner.plan.StatisticAggregations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Attribute Type	descriptor : StatisticAggregationsDescriptor<Symbol> to descriptor : StatisticAggregationsDescriptor<VariableReferenceExpression> in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner.TableStatisticAggregation | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Attribute Type	statisticsAggregationDescriptor : Optional<StatisticAggregationsDescriptor<Symbol>> to statisticsAggregationDescriptor : Optional<StatisticAggregationsDescriptor<VariableReferenceExpression>> in class com.facebook.presto.sql.planner.plan.TableFinishNode | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Attribute Type	descriptor : StatisticAggregationsDescriptor<Symbol> to descriptor : StatisticAggregationsDescriptor<VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.StatisticsWriterNode | 
                                From | 
                                To | 
                            
                            
                            
                            
                            
                            
                            
                                 | 
                                Rename Parameter	groupBySymbols : List<Symbol> to groupbySymbols : List<Symbol> in method private createHashAggregationOperatorFactory(planNodeId PlanNodeId, aggregations Map<Symbol,Aggregation>, globalGroupingSets Set<Integer>, groupbySymbols List<Symbol>, step Step, hashVariable Optional<VariableReferenceExpression>, groupIdSymbol Optional<Symbol>, source PhysicalOperation, hasDefaultOutput boolean, spillEnabled boolean, isStreamable boolean, unspillMemoryLimit DataSize, context LocalExecutionPlanContext, startOutputChannel int, outputMappings ImmutableMap.Builder<Symbol,Integer>, expectedGroups int, maxPartialAggregationMemorySize Optional<DataSize>, useSystemMemory boolean) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Parameter	columnToSymbolMap : Map<String,Symbol> to columnToVariableMap : Map<String,VariableReferenceExpression> in method public createStatisticsAggregation(statisticsMetadata TableStatisticsMetadata, columnToVariableMap Map<String,VariableReferenceExpression>) : TableStatisticAggregation in class com.facebook.presto.sql.planner.StatisticsAggregationPlanner | 
                                From | 
                                To |