| 
                                Change Parameter Type	expectedOutputs : List<Symbol> to expectedOutputs : List<VariableReferenceExpression> in method private createIndexJoinWithExpectedOutputs(expectedOutputs List<VariableReferenceExpression>, type IndexJoinNode.Type, probe PlanNode, index PlanNode, equiJoinClause List<IndexJoinNode.EquiJoinClause>, idAllocator PlanNodeIdAllocator, symbolAllocator SymbolAllocator) : PlanNode in class com.facebook.presto.sql.planner.optimizations.IndexJoinOptimizer.Rewriter | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	symbols : List<Symbol> to variables : List<VariableReferenceExpression> in method private allAggregationsOn(aggregations Map<VariableReferenceExpression,AggregationNode.Aggregation>, variables List<VariableReferenceExpression>) : boolean in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	symbol : Symbol to variable : VariableReferenceExpression in method public setVariableSource(variable VariableReferenceExpression, node PlanNode) : void in class com.facebook.presto.sql.planner.optimizations.joins.JoinGraph.Context | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	testValues : Collection<Symbol> to testValues : Collection<VariableReferenceExpression> in method private containsNone(values Collection<VariableReferenceExpression>, testValues Collection<VariableReferenceExpression>) : boolean in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	symbolMapping : Map<Symbol,Symbol> to variableMapping : Map<VariableReferenceExpression,VariableReferenceExpression> in method public MappedAggregationInfo(aggregationNode AggregationNode, variableMapping Map<VariableReferenceExpression,VariableReferenceExpression>) in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin.MappedAggregationInfo | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	symbolMapping : Map<Symbol,SymbolReference> to variableMapping : Map<VariableReferenceExpression,SymbolReference> in method private inlineOrderByVariables(variableMapping Map<VariableReferenceExpression,SymbolReference>, orderingScheme OrderingScheme) : OrderingScheme in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	values : Collection<Symbol> to values : Collection<VariableReferenceExpression> in method private containsNone(values Collection<VariableReferenceExpression>, testValues Collection<VariableReferenceExpression>) : boolean in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Parameter Type	alreadyCoerced : List<Symbol> to alreadyCoerced : List<VariableReferenceExpression> in method private explicitCoercionSymbols(subPlan PlanBuilder, alreadyCoerced List<VariableReferenceExpression>, uncoerced Iterable<? extends Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner | 
                                From | 
                                To | 
                            
                            
                            
                            
                            
                            
                            
                                 | 
                                Rename Variable	leftSymbols : List<Symbol> to leftVariables : List<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputVariables List<VariableReferenceExpression>, spatialComparison ComparisonExpression, metadata Metadata, splitManager SplitManager, pageSourceManager PageSourceManager, sqlParser SqlParser) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	firstSymbols : Set<Symbol> to firstVariables : Set<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputVariables List<VariableReferenceExpression>, spatialFunction FunctionCall, radius Optional<Expression>, metadata Metadata, splitManager SplitManager, pageSourceManager PageSourceManager, sqlParser SqlParser) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	symbol : Symbol to variable : VariableReferenceExpression in method public visitOutput(node OutputNode, context Void) : Void in class com.facebook.presto.sql.planner.planPrinter.PlanPrinter.Visitor | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	outputSymbol : Symbol to outputVariable : VariableReferenceExpression in method public detailMatches(node PlanNode, stats StatsProvider, session Session, metadata Metadata, symbolAliases SymbolAliases) : MatchResult in class com.facebook.presto.sql.planner.assertions.OutputMatcher | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	symbol : Symbol to variable : VariableReferenceExpression in method protected visitPlan(node PlanNode, context Context) : JoinGraph in class com.facebook.presto.sql.planner.optimizations.joins.JoinGraph.Builder | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	lookupSymbolSchema : List<VariableReferenceExpression> to lookupVariableSchema : List<VariableReferenceExpression> in method public visitIndexSource(node IndexSourceNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	inputs : Set<Symbol> to inputNames : Set<String> in method private allAggregationsOn(aggregations Map<VariableReferenceExpression,AggregationNode.Aggregation>, variables List<VariableReferenceExpression>) : boolean in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	canonicalVariables : List<VariableReferenceExpression> to canonical : List<VariableReferenceExpression> in method public visitOutput(node OutputNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	sourcesSymbolMapping : Map<Symbol,SymbolReference> to sourcesVariableMapping : Map<VariableReferenceExpression,SymbolReference> in method private createAggregationOverNull(referenceAggregation AggregationNode, symbolAllocator SymbolAllocator, idAllocator PlanNodeIdAllocator, lookup Lookup) : Optional<MappedAggregationInfo> in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	symbolIndex : int to variableIndex : int in method private mapExchangeNodeSymbols(node ExchangeNode) : void in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	radiusSymbols : Set<Symbol> to radiusVariables : Set<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputVariables List<VariableReferenceExpression>, spatialComparison ComparisonExpression, metadata Metadata, splitManager SplitManager, pageSourceManager PageSourceManager, sqlParser SqlParser) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	rightSymbols : List<Symbol> to rightVariables : List<VariableReferenceExpression> in method private checkAlignment(joinNode JoinNode, maybeLeftVariables Set<VariableReferenceExpression>, maybeRightVariables Set<VariableReferenceExpression>) : int in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	sourceSymbol : Symbol to sourceVariable : VariableReferenceExpression in method private createAggregationOverNull(referenceAggregation AggregationNode, symbolAllocator SymbolAllocator, idAllocator PlanNodeIdAllocator, lookup Lookup) : Optional<MappedAggregationInfo> in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	leftSymbols : List<Symbol> to leftVariables : List<VariableReferenceExpression> in method private checkAlignment(joinNode JoinNode, maybeLeftVariables Set<VariableReferenceExpression>, maybeRightVariables Set<VariableReferenceExpression>) : int in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	outputSymbol : Symbol to outputVariable : VariableReferenceExpression in method private addProjection(context Context, node PlanNode, variable VariableReferenceExpression, expression Expression) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	outputSymbol : Symbol to outputVariable : VariableReferenceExpression in method private addPartitioningNodes(context Context, node PlanNode, partitionVariable VariableReferenceExpression, kdbTree KdbTree, geometry Expression, radius Optional<Expression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	secondSymbols : Set<Symbol> to secondVariables : Set<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputVariables List<VariableReferenceExpression>, spatialFunction FunctionCall, radius Optional<Expression>, metadata Metadata, splitManager SplitManager, pageSourceManager PageSourceManager, sqlParser SqlParser) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method private planLateralJoin(join Join, leftPlan RelationPlan, lateral Lateral) : RelationPlan in class com.facebook.presto.sql.planner.RelationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	rightSymbols : List<Symbol> to rightVariables : List<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputVariables List<VariableReferenceExpression>, spatialComparison ComparisonExpression, metadata Metadata, splitManager SplitManager, pageSourceManager PageSourceManager, sqlParser SqlParser) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Rename Variable	sourceOutputSymbols : Set<Symbol> to sourceOutputVariables : Set<VariableReferenceExpression> in method public apply(topNNode TopNNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.PushTopNThroughUnion | 
                                From | 
                                To | 
                            
                            
                            
                            
                            
                            
                            
                                 | 
                                Change Variable Type	symbol : Symbol to variable : VariableReferenceExpression in method public visitOutput(node OutputNode, context Void) : Void in class com.facebook.presto.sql.planner.planPrinter.PlanPrinter.Visitor | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	inputs : Set<Symbol> to inputNames : Set<String> in method private allAggregationsOn(aggregations Map<VariableReferenceExpression,AggregationNode.Aggregation>, variables List<VariableReferenceExpression>) : boolean in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughJoin | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	sourcesSymbolMapping : Map<Symbol,SymbolReference> to sourcesVariableMapping : Map<VariableReferenceExpression,SymbolReference> in method private createAggregationOverNull(referenceAggregation AggregationNode, symbolAllocator SymbolAllocator, idAllocator PlanNodeIdAllocator, lookup Lookup) : Optional<MappedAggregationInfo> in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	radiusSymbols : Set<Symbol> to radiusVariables : Set<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputVariables List<VariableReferenceExpression>, spatialComparison ComparisonExpression, metadata Metadata, splitManager SplitManager, pageSourceManager PageSourceManager, sqlParser SqlParser) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	rightSymbols : List<Symbol> to rightVariables : List<VariableReferenceExpression> in method private checkAlignment(joinNode JoinNode, maybeLeftVariables Set<VariableReferenceExpression>, maybeRightVariables Set<VariableReferenceExpression>) : int in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	newTargetOutputs : Set<Symbol> to newTargetOutputs : Set<VariableReferenceExpression> in method protected pullWindowNodeAboveProjects(target WindowNode, projects List<ProjectNode>, context Context) : Optional<WindowNode> in class com.facebook.presto.sql.planner.iterative.rule.GatherAndMergeWindows.ManipulateAdjacentWindowsOverProjects | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	leftSymbols : List<Symbol> to leftVariables : List<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputVariables List<VariableReferenceExpression>, spatialComparison ComparisonExpression, metadata Metadata, splitManager SplitManager, pageSourceManager PageSourceManager, sqlParser SqlParser) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	outputLayout : List<Symbol> to outputLayout : List<VariableReferenceExpression> in method public apply(parent ProjectNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.PushProjectionThroughUnion | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	firstSymbols : Set<Symbol> to firstVariables : Set<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputVariables List<VariableReferenceExpression>, spatialFunction FunctionCall, radius Optional<Expression>, metadata Metadata, splitManager SplitManager, pageSourceManager PageSourceManager, sqlParser SqlParser) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	outputSymbol : Symbol to outputVariable : VariableReferenceExpression in method public detailMatches(node PlanNode, stats StatsProvider, session Session, metadata Metadata, symbolAliases SymbolAliases) : MatchResult in class com.facebook.presto.sql.planner.assertions.OutputMatcher | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	outputColumn : Symbol to outputColumn : VariableReferenceExpression in method private rewriteQuantifiedApplyNode(node ApplyNode, quantifiedComparison QuantifiedComparisonExpression, context RewriteContext<PlanNode>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.TransformQuantifiedComparisonApplyToLateralJoin.Rewriter | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	symbol : Symbol to variable : VariableReferenceExpression in method protected visitPlan(node PlanNode, context Context) : JoinGraph in class com.facebook.presto.sql.planner.optimizations.joins.JoinGraph.Builder | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	newTargetChildOutputs : Set<Symbol> to newTargetChildOutputs : Set<VariableReferenceExpression> in method protected pullWindowNodeAboveProjects(target WindowNode, projects List<ProjectNode>, context Context) : Optional<WindowNode> in class com.facebook.presto.sql.planner.iterative.rule.GatherAndMergeWindows.ManipulateAdjacentWindowsOverProjects | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	aggregationsSymbolMapping : Map<Symbol,Symbol> to aggregationsSymbolMapping : Map<VariableReferenceExpression,VariableReferenceExpression> in method private createAggregationOverNull(referenceAggregation AggregationNode, symbolAllocator SymbolAllocator, idAllocator PlanNodeIdAllocator, lookup Lookup) : Optional<MappedAggregationInfo> in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	sourceSymbol : Symbol to sourceVariable : VariableReferenceExpression in method private createAggregationOverNull(referenceAggregation AggregationNode, symbolAllocator SymbolAllocator, idAllocator PlanNodeIdAllocator, lookup Lookup) : Optional<MappedAggregationInfo> in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	outputSymbol : Symbol to outputVariable : VariableReferenceExpression in method private addProjection(context Context, node PlanNode, variable VariableReferenceExpression, expression Expression) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	leftSymbols : List<Symbol> to leftVariables : List<VariableReferenceExpression> in method private checkAlignment(joinNode JoinNode, maybeLeftVariables Set<VariableReferenceExpression>, maybeRightVariables Set<VariableReferenceExpression>) : int in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	localPropertyColumns : Set<Symbol> to localPropertyColumns : Set<VariableReferenceExpression> in method public deriveProperties(node PlanNode, inputProperties List<StreamProperties>, metadata Metadata, session Session, types TypeProvider, parser SqlParser) : StreamProperties in class com.facebook.presto.sql.planner.optimizations.StreamPropertyDerivations | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	outputSymbol : Symbol to outputVariable : VariableReferenceExpression in method private addPartitioningNodes(context Context, node PlanNode, partitionVariable VariableReferenceExpression, kdbTree KdbTree, geometry Expression, radius Optional<Expression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	secondSymbols : Set<Symbol> to secondVariables : Set<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputVariables List<VariableReferenceExpression>, spatialFunction FunctionCall, radius Optional<Expression>, metadata Metadata, splitManager SplitManager, pageSourceManager PageSourceManager, sqlParser SqlParser) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method private planLateralJoin(join Join, leftPlan RelationPlan, lateral Lateral) : RelationPlan in class com.facebook.presto.sql.planner.RelationPlanner | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	rightSymbols : List<Symbol> to rightVariables : List<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputVariables List<VariableReferenceExpression>, spatialComparison ComparisonExpression, metadata Metadata, splitManager SplitManager, pageSourceManager PageSourceManager, sqlParser SqlParser) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	sourceOutputSymbols : Set<Symbol> to sourceOutputVariables : Set<VariableReferenceExpression> in method public apply(topNNode TopNNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.PushTopNThroughUnion | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	sourceAggregationToOverNullMapping : Map<Symbol,Symbol> to sourceAggregationToOverNullMapping : Map<VariableReferenceExpression,VariableReferenceExpression> in method private coalesceWithNullAggregation(aggregationNode AggregationNode, outerJoin PlanNode, symbolAllocator SymbolAllocator, idAllocator PlanNodeIdAllocator, lookup Lookup) : Optional<PlanNode> in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin | 
                                From | 
                                To | 
                            
                            
                            
                                 | 
                                Change Variable Type	localPropertyColumns : Set<Symbol> to localPropertyColumns : Set<VariableReferenceExpression> in method public deriveProperties(node PlanNode, inputProperties List<ActualProperties>, metadata Metadata, session Session, types TypeProvider, parser SqlParser) : ActualProperties in class com.facebook.presto.sql.planner.optimizations.PropertyDerivations | 
                                From | 
                                To |