|
Change Parameter Type symbolToColumnMap : Map<Symbol,ColumnMetadata> to variableToColumnMap : Map<VariableReferenceExpression,ColumnMetadata> in method private createTemporaryTableScan(tableHandle TableHandle, outputSymbols List<Symbol>, outputVariables List<VariableReferenceExpression>, variableToColumnMap Map<VariableReferenceExpression,ColumnMetadata>, expectedPartitioningMetadata PartitioningMetadata) : TableScanNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Parameter Type assignment : Entry<Symbol,Expression> to assignment : Entry<VariableReferenceExpression,Expression> in method public put(assignment Entry<VariableReferenceExpression,Expression>) : Builder in class com.facebook.presto.sql.planner.plan.Assignments.Builder |
From |
To |
|
Change Parameter Type inPredicateOutputSymbol : Symbol to inPredicateOutputVariable : VariableReferenceExpression in method private apply(apply ApplyNode, inPredicate InPredicate, inPredicateOutputVariable VariableReferenceExpression, lookup Lookup, idAllocator PlanNodeIdAllocator, symbolAllocator SymbolAllocator) : Result in class com.facebook.presto.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin |
From |
To |
|
Change Parameter Type symbol : Symbol to variable : VariableReferenceExpression in method public put(variable VariableReferenceExpression, expression Expression) : Builder in class com.facebook.presto.sql.planner.plan.Assignments.Builder |
From |
To |
|
Change Parameter Type projectionFilter : Predicate<Symbol> to projectionFilter : Predicate<VariableReferenceExpression> in method private buildProjectedJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneJoinColumns |
From |
To |
|
Change Parameter Type symbols : Iterable<Symbol> to variables : Iterable<VariableReferenceExpression> in method public putIdentities(variables Iterable<VariableReferenceExpression>) : Builder in class com.facebook.presto.sql.planner.plan.Assignments.Builder |
From |
To |
|
Change Parameter Type predicate : Predicate<Symbol> to predicate : Predicate<VariableReferenceExpression> in method public filter(predicate Predicate<VariableReferenceExpression>) : Assignments in class com.facebook.presto.sql.planner.plan.Assignments |
From |
To |
|
Change Parameter Type symbols : Iterable<Symbol> to variables : Iterable<VariableReferenceExpression> in method public identity(variables Iterable<VariableReferenceExpression>) : Assignments in class com.facebook.presto.sql.planner.plan.Assignments |
From |
To |
|
Change Parameter Type optionalSymbol : Optional<Symbol> to optionalVariable : Optional<VariableReferenceExpression> in method private toExpression(optionalVariable Optional<VariableReferenceExpression>, defaultExpression Expression) : Expression in class com.facebook.presto.sql.planner.iterative.rule.ExtractSpatialJoins |
From |
To |
|
Change Parameter Type projectionTopN : Predicate<Symbol> to projectionTopN : Predicate<VariableReferenceExpression> in method private buildProjectedTopN(planBuilder PlanBuilder, projectionTopN Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneTopNColumns |
From |
To |
|
Change Parameter Type projectionFilter : Predicate<Symbol> to projectionFilter : Predicate<VariableReferenceExpression> in method private buildProjectedIndexSource(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneIndexSourceColumns |
From |
To |
|
Change Parameter Type assignments : Optional<Map<Symbol,Expression>> to assignments : Optional<Map<VariableReferenceExpression,Expression>> in method public JoinGraph(nodes List<PlanNode>, edges Multimap<PlanNodeId,Edge>, rootId PlanNodeId, filters List<Expression>, assignments Optional<Map<VariableReferenceExpression,Expression>>) in class com.facebook.presto.sql.planner.optimizations.joins.JoinGraph |
From |
To |
|
Change Parameter Type nonNull : Symbol to nonNull : VariableReferenceExpression in method private rewriteScalarAggregation(lateralJoinNode LateralJoinNode, scalarAggregation AggregationNode, scalarAggregationSource PlanNode, joinExpression Optional<Expression>, nonNull VariableReferenceExpression) : PlanNode in class com.facebook.presto.sql.planner.optimizations.ScalarAggregationToJoinRewriter |
From |
To |
|
Change Parameter Type assignments : Map<Symbol,Expression> to assignments : Map<VariableReferenceExpression,Expression> in method public putAll(assignments Map<VariableReferenceExpression,Expression>) : Builder in class com.facebook.presto.sql.planner.plan.Assignments.Builder |
From |
To |
|
Change Parameter Type alreadyCoerced : Iterable<Symbol> to alreadyCoerced : List<Symbol> in method private explicitCoercionSymbols(subPlan PlanBuilder, alreadyCoerced List<Symbol>, uncoerced Iterable<? extends Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Parameter Type assignments : Map<Symbol,Expression> to assignments : Map<VariableReferenceExpression,Expression> in method public withAssignments(assignments Map<VariableReferenceExpression,Expression>) : JoinGraph in class com.facebook.presto.sql.planner.optimizations.joins.JoinGraph |
From |
To |
|
Change Parameter Type constants : Map<Symbol,Expression> to constants : Map<VariableReferenceExpression,Expression> in method private PartitioningVariableAssignments(variables List<VariableReferenceExpression>, constants Map<VariableReferenceExpression,Expression>) in class com.facebook.presto.sql.planner.PlanFragmenter.PartitioningVariableAssignments |
From |
To |
|
Change Parameter Type inPredicateOutputSymbol : Symbol to inPredicateOutputVariable : VariableReferenceExpression in method private buildInPredicateEquivalent(apply ApplyNode, inPredicate InPredicate, inPredicateOutputVariable VariableReferenceExpression, decorrelated Decorrelated, idAllocator PlanNodeIdAllocator, symbolAllocator SymbolAllocator) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin |
From |
To |
|
Change Parameter Type symbol : Symbol to variable : VariableReferenceExpression in method private projectNode(source PlanNode, variable VariableReferenceExpression, expression Expression) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestEliminateCrossJoins |
From |
To |
|
Change Parameter Type assignments : Map<Symbol,Expression> to assignments : Map<VariableReferenceExpression,Expression> in method public copyOf(assignments Map<VariableReferenceExpression,Expression>) : Assignments in class com.facebook.presto.sql.planner.plan.Assignments |
From |
To |
|
Change Parameter Type symbolToColumnMap : Map<Symbol,ColumnMetadata> to variableToColumnMap : Map<VariableReferenceExpression,ColumnMetadata> in method private createTemporaryTableWrite(tableHandle TableHandle, variableToColumnMap Map<VariableReferenceExpression,ColumnMetadata>, outputs List<VariableReferenceExpression>, inputs List<List<VariableReferenceExpression>>, sources List<PlanNode>, constantExpressions Map<VariableReferenceExpression,Expression>, partitioningMetadata PartitioningMetadata) : TableFinishNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Parameter Type outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method private visitScanFilterAndProject(context LocalExecutionPlanContext, planNodeId PlanNodeId, sourceNode PlanNode, filterExpression Optional<RowExpression>, assignments Assignments, outputVariables List<VariableReferenceExpression>) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type output : Symbol to output : VariableReferenceExpression in method public isIdentity(output VariableReferenceExpression) : boolean in class com.facebook.presto.sql.planner.plan.Assignments |
From |
To |
|
Change Parameter Type constantExpressions : Map<Symbol,Expression> to constantExpressions : Map<VariableReferenceExpression,Expression> in method private createTemporaryTableWrite(tableHandle TableHandle, variableToColumnMap Map<VariableReferenceExpression,ColumnMetadata>, outputs List<VariableReferenceExpression>, inputs List<List<VariableReferenceExpression>>, sources List<PlanNode>, constantExpressions Map<VariableReferenceExpression,Expression>, partitioningMetadata PartitioningMetadata) : TableFinishNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Parameter Type projectionFilter : Predicate<Symbol> to projectionFilter : Predicate<VariableReferenceExpression> in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Parameter Type projectionFilter : Predicate<Symbol> to projectionFilter : Predicate<VariableReferenceExpression> in method private buildProjectedCrossJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneCrossJoinColumns |
From |
To |
|
Change Parameter Type sourceFilter : Predicate<Symbol> to sourceFilter : Predicate<VariableReferenceExpression> in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Parameter Type projectionFilter : Predicate<Symbol> to projectionFilter : Predicate<VariableReferenceExpression> in method private buildProjectedAggregation(planBuilder PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneAggregationColumns |
From |
To |
|
Change Parameter Type assignments : Map<Symbol,Expression> to assignments : Map<VariableReferenceExpression,Expression> in method public Assignments(assignments Map<VariableReferenceExpression,Expression>) in class com.facebook.presto.sql.planner.plan.Assignments |
From |
To |
|
Change Parameter Type symbols : Symbol... to variables : VariableReferenceExpression... in method public identity(variables VariableReferenceExpression...) : Assignments in class com.facebook.presto.sql.planner.plan.Assignments |
From |
To |
|
Change Parameter Type symbols : Collection<Symbol> to variables : Collection<VariableReferenceExpression> in method public filter(variables Collection<VariableReferenceExpression>) : Assignments in class com.facebook.presto.sql.planner.plan.Assignments |
From |
To |
|
Change Parameter Type inputs : List<List<Symbol>> to inputs : List<List<VariableReferenceExpression>> in method private createTemporaryTableWrite(tableHandle TableHandle, variableToColumnMap Map<VariableReferenceExpression,ColumnMetadata>, outputs List<VariableReferenceExpression>, inputs List<List<VariableReferenceExpression>>, sources List<PlanNode>, constantExpressions Map<VariableReferenceExpression,Expression>, partitioningMetadata PartitioningMetadata) : TableFinishNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Parameter Type consumer : BiConsumer<Symbol,Expression> to consumer : BiConsumer<VariableReferenceExpression,Expression> in method public forEach(consumer BiConsumer<VariableReferenceExpression,Expression>) : void in class com.facebook.presto.sql.planner.plan.Assignments |
From |
To |
|
Change Parameter Type projections : Map<Symbol,SymbolReference> to projections : Map<VariableReferenceExpression,SymbolReference> in method private appendMarkers(source PlanNode, markerIndex int, markers List<VariableReferenceExpression>, projections Map<VariableReferenceExpression,SymbolReference>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.ImplementIntersectAndExceptAsUnion.Rewriter |
From |
To |
|
Change Parameter Type symbol : Symbol to variable : VariableReferenceExpression in method public of(variable VariableReferenceExpression, expression Expression) : Assignments in class com.facebook.presto.sql.planner.plan.Assignments |
From |
To |
|
Change Parameter Type projectionFilter : Predicate<Symbol> to projectionFilter : Predicate<VariableReferenceExpression> in method private buildProjectedSemiJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneSemiJoinColumns |
From |
To |
|
Change Parameter Type projectionFilter : Predicate<Symbol> to projectionFilter : Predicate<VariableReferenceExpression> in method private buildProjectedFilter(planBuilder PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneFilterColumns |
From |
To |
|
Change Parameter Type symbol : Symbol to variable : 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 Parameter Type symbols : List<Symbol> to symbols : Collection<Symbol> in method public toVariableReferences(symbols Collection<Symbol>) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.SymbolAllocator |
From |
To |
|
Change Parameter Type projectionFilter : Predicate<Symbol> to projectionFilter : Predicate<VariableReferenceExpression> in method private buildProjectedLimit(planBuilder PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneLimitColumns |
From |
To |
|
Change Parameter Type nonNullableAggregationSourceSymbol : Symbol to nonNull : VariableReferenceExpression in method private createAggregationNode(scalarAggregation AggregationNode, leftOuterJoin JoinNode, nonNull VariableReferenceExpression) : Optional<AggregationNode> in class com.facebook.presto.sql.planner.optimizations.ScalarAggregationToJoinRewriter |
From |
To |
|
Change Parameter Type outputs : List<Symbol> to outputs : List<VariableReferenceExpression> in method private createTemporaryTableWrite(tableHandle TableHandle, variableToColumnMap Map<VariableReferenceExpression,ColumnMetadata>, outputs List<VariableReferenceExpression>, inputs List<List<VariableReferenceExpression>>, sources List<PlanNode>, constantExpressions Map<VariableReferenceExpression,Expression>, partitioningMetadata PartitioningMetadata) : TableFinishNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method private project(subPlan PlanBuilder, expressions Iterable<Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Rename Variable outputSymbols : Assignments.Builder to outputVariables : Assignments.Builder 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 symbol : Symbol to variable : VariableReferenceExpression in method private coerce(expressions Iterable<? extends Expression>, subPlan PlanBuilder, translations TranslationMap) : Map<VariableReferenceExpression,Expression> in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Rename Variable outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method public visitFilter(node FilterNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable newRadiusSymbol : Optional<Symbol> to newRadiusVariable : Optional<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputSymbols List<Symbol>, 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 symbolToColumnMap : Map<Symbol,ColumnMetadata> to variableToColumnMap : Map<VariableReferenceExpression,ColumnMetadata> in method private createRemoteMaterializedExchange(exchange ExchangeNode, context RewriteContext<FragmentProperties>) : PlanNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Rename Variable partitioningSymbols : List<VariableReferenceExpression> to partitioningVariables : List<VariableReferenceExpression> in method private createTemporaryTableWrite(tableHandle TableHandle, variableToColumnMap Map<VariableReferenceExpression,ColumnMetadata>, outputs List<VariableReferenceExpression>, inputs List<List<VariableReferenceExpression>>, sources List<PlanNode>, constantExpressions Map<VariableReferenceExpression,Expression>, partitioningMetadata PartitioningMetadata) : TableFinishNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method public isIdentity(projectNode ProjectNode) : boolean in class com.facebook.presto.sql.relational.ProjectNodeUtils |
From |
To |
|
Rename Variable symbol : Symbol to variable : 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 Variable partitionsSymbol : Symbol to partitionsVariable : 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 symbol : Symbol to variable : VariableReferenceExpression in method private explicitCoercionFields(subPlan PlanBuilder, alreadyCoerced Iterable<Expression>, uncoerced Iterable<? extends Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Rename Variable outputSymbols : Assignments.Builder to outputVariables : Assignments.Builder in method public visitAggregation(node AggregationNode, 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 appendMarkers(source PlanNode, markerIndex int, markers List<VariableReferenceExpression>, projections Map<VariableReferenceExpression,SymbolReference>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.ImplementIntersectAndExceptAsUnion.Rewriter |
From |
To |
|
Rename Variable constantSymbols : List<Symbol> to constantVariables : List<VariableReferenceExpression> in method private createTemporaryTableWrite(tableHandle TableHandle, variableToColumnMap Map<VariableReferenceExpression,ColumnMetadata>, outputs List<VariableReferenceExpression>, inputs List<List<VariableReferenceExpression>>, sources List<PlanNode>, constantExpressions Map<VariableReferenceExpression,Expression>, partitioningMetadata PartitioningMetadata) : TableFinishNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Rename Variable computedSymbol : Symbol to computedVariable : VariableReferenceExpression in method private canonicalize(oldAssignments Assignments) : Assignments in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Rename Variable columnNameToSymbol : Map<String,Symbol> to columnNameToVariable : Map<String,VariableReferenceExpression> in method private createTemporaryTableWrite(tableHandle TableHandle, variableToColumnMap Map<VariableReferenceExpression,ColumnMetadata>, outputs List<VariableReferenceExpression>, inputs List<List<VariableReferenceExpression>>, sources List<PlanNode>, constantExpressions Map<VariableReferenceExpression,Expression>, partitioningMetadata PartitioningMetadata) : TableFinishNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Rename Variable deterministicSymbols : Set<Symbol> to deterministicVariables : Set<VariableReferenceExpression> in method public visitProject(node ProjectNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Variable outputSymbol : Symbol to outputVariable : VariableReferenceExpression in method private assignTemporaryTableColumnNames(outputVariables Collection<VariableReferenceExpression>, constantPartitioningVariables Collection<VariableReferenceExpression>) : Map<VariableReferenceExpression,ColumnMetadata> in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Rename Variable partitionCountSymbol : Symbol to partitionCountVariable : VariableReferenceExpression in method public apply(node AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.RewriteSpatialPartitioningAggregation |
From |
To |
|
Rename Variable inPredicateOutputSymbol : Symbol to inPredicateOutputVariable : VariableReferenceExpression in method public apply(apply ApplyNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin |
From |
To |
|
Rename Variable inPredicateSubquerySymbol : Symbol to inPredicateSubqueryVariable : VariableReferenceExpression in method private appendInPredicateApplyNode(subPlan PlanBuilder, inPredicate InPredicate, correlationAllowed boolean, node Node) : PlanBuilder in class com.facebook.presto.sql.planner.SubqueryPlanner |
From |
To |
|
Rename Variable coercedQuantifiedComparisonSymbol : Symbol to coercedQuantifiedComparisonVariable : VariableReferenceExpression in method private planQuantifiedApplyNode(subPlan PlanBuilder, quantifiedComparison QuantifiedComparisonExpression, correlationAllowed boolean) : PlanBuilder in class com.facebook.presto.sql.planner.SubqueryPlanner |
From |
To |
|
Rename Variable envelopeSymbol : Symbol to envelopeVariable : VariableReferenceExpression in method public apply(node AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.RewriteSpatialPartitioningAggregation |
From |
To |
|
Rename Variable aggregationOutputSymbols : List<Symbol> to aggregationOutputVariables : List<VariableReferenceExpression> in method private rewriteScalarAggregation(lateralJoinNode LateralJoinNode, scalarAggregation AggregationNode, scalarAggregationSource PlanNode, joinExpression Optional<Expression>, nonNull VariableReferenceExpression) : PlanNode in class com.facebook.presto.sql.planner.optimizations.ScalarAggregationToJoinRewriter |
From |
To |
|
Rename Variable symbols : ImmutableList.Builder<Symbol> to variables : ImmutableList.Builder<VariableReferenceExpression> in method private assignPartitioningVariables(partitioning Partitioning) : PartitioningVariableAssignments in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Rename Variable symbolsToAdd : List<Symbol> to variablesToAdd : List<VariableReferenceExpression> in method public visitProject(node ProjectNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method private canonicalize(oldAssignments Assignments) : Assignments in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Rename Variable partitioningSymbolAssignments : PartitioningSymbolAssignments to partitioningVariableAssignments : PartitioningVariableAssignments in method private createRemoteMaterializedExchange(exchange ExchangeNode, context RewriteContext<FragmentProperties>) : PlanNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Rename Variable newSecondSymbol : Optional<Symbol> to newSecondVariable : Optional<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputSymbols List<Symbol>, 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 quantifiedComparisonSymbol : Symbol to quantifiedComparisonVariable : 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 |
|
Rename Variable newFirstSymbol : Optional<Symbol> to newFirstVariable : Optional<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputSymbols List<Symbol>, 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 scalarAggregationSourceWithNonNullableSymbol : ProjectNode to scalarAggregationSourceWithNonNullableVariable : ProjectNode in method public rewriteScalarAggregation(lateralJoinNode LateralJoinNode, aggregation AggregationNode) : PlanNode in class com.facebook.presto.sql.planner.optimizations.ScalarAggregationToJoinRewriter |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method private assignPartitioningVariables(partitioning Partitioning) : PartitioningVariableAssignments in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method public visitAggregation(node AggregationNode, 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 public putIdentities(variables Iterable<VariableReferenceExpression>) : Builder in class com.facebook.presto.sql.planner.plan.Assignments.Builder |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method public putIdentities(variables Iterable<VariableReferenceExpression>) : Builder in class com.facebook.presto.sql.planner.plan.Assignments.Builder |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,Expression> to entry : Map.Entry<VariableReferenceExpression,Expression> in method public isIdentity(projectNode ProjectNode) : boolean in class com.facebook.presto.sql.relational.ProjectNodeUtils |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,Expression> to entry : Map.Entry<VariableReferenceExpression,Expression> in method public visitProject(node ProjectNode, context Void) : Void in class com.facebook.presto.util.GraphvizPrinter.NodePrinter |
From |
To |
|
Change Variable Type unused : Symbol to unused : VariableReferenceExpression in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type leftValue : Symbol to leftValue : VariableReferenceExpression in method private buildProjectedSemiJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneSemiJoinColumns |
From |
To |
|
Change Variable Type input2 : Symbol to input2 : VariableReferenceExpression in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,Expression> to entry : Map.Entry<VariableReferenceExpression,Expression> in method protected doCalculate(node ProjectNode, statsProvider StatsProvider, lookup Lookup, session Session, types TypeProvider) : Optional<PlanNodeStatsEstimate> in class com.facebook.presto.cost.ProjectStatsRule |
From |
To |
|
Change Variable Type mappings : List<Symbol> to mappings : List<VariableReferenceExpression> in method protected visitAliasedRelation(node AliasedRelation, context Void) : RelationPlan in class com.facebook.presto.sql.planner.RelationPlanner |
From |
To |
|
Change Variable Type nonNull : Symbol to nonNull : VariableReferenceExpression in method public rewriteScalarAggregation(lateralJoinNode LateralJoinNode, aggregation AggregationNode) : PlanNode in class com.facebook.presto.sql.planner.optimizations.ScalarAggregationToJoinRewriter |
From |
To |
|
Change Variable Type assignmentsWithoutTargetOutputIdentities : Map<Symbol,Expression> to assignmentsWithoutTargetOutputIdentities : Map<VariableReferenceExpression,Expression> 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 symbol : Symbol to variable : VariableReferenceExpression in method public isIdentity(projectNode ProjectNode) : boolean in class com.facebook.presto.sql.relational.ProjectNodeUtils |
From |
To |
|
Change Variable Type newMappings : ImmutableList.Builder<Symbol> to newMappings : ImmutableList.Builder<VariableReferenceExpression> in method protected visitAliasedRelation(node AliasedRelation, context Void) : RelationPlan in class com.facebook.presto.sql.planner.RelationPlanner |
From |
To |
|
Change Variable Type aggregationOutputSymbols : List<Symbol> to aggregationOutputVariables : List<VariableReferenceExpression> in method private rewriteScalarAggregation(lateralJoinNode LateralJoinNode, scalarAggregation AggregationNode, scalarAggregationSource PlanNode, joinExpression Optional<Expression>, nonNull VariableReferenceExpression) : PlanNode in class com.facebook.presto.sql.planner.optimizations.ScalarAggregationToJoinRewriter |
From |
To |
|
Change Variable Type output2 : Symbol to output2 : VariableReferenceExpression in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type inputs : List<Symbol> to inputs : List<VariableReferenceExpression> in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type canonical : Symbol to canonical : VariableReferenceExpression in method private canonicalize(oldAssignments Assignments) : Assignments in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type targetOutputs : Set<Symbol> to targetOutputs : 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 hash : Symbol to hash : VariableReferenceExpression in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type buildSideKnownNonNull : Symbol to buildSideKnownNonNull : VariableReferenceExpression in method private buildInPredicateEquivalent(apply ApplyNode, inPredicate InPredicate, inPredicateOutputVariable VariableReferenceExpression, decorrelated Decorrelated, idAllocator PlanNodeIdAllocator, symbolAllocator SymbolAllocator) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin |
From |
To |
|
Change Variable Type assignment : Map.Entry<Symbol,Expression> to assignment : Map.Entry<VariableReferenceExpression,Expression> in method public visitProject(node ProjectNode, inputProperties List<ActualProperties>) : ActualProperties in class com.facebook.presto.sql.planner.optimizations.PropertyDerivations.Visitor |
From |
To |
|
Change Variable Type childOutputSet : Set<Symbol> to childOutputSet : Set<VariableReferenceExpression> in method private extractInliningTargets(parent ProjectNode, child ProjectNode, context Context) : Sets.SetView<VariableReferenceExpression> in class com.facebook.presto.sql.planner.iterative.rule.InlineProjections |
From |
To |
|
Change Variable Type singletons : Set<Symbol> to singletons : Set<VariableReferenceExpression> in method private extractInliningTargets(parent ProjectNode, child ProjectNode, context Context) : Sets.SetView<VariableReferenceExpression> in class com.facebook.presto.sql.planner.iterative.rule.InlineProjections |
From |
To |
|
Change Variable Type b : Symbol to b : VariableReferenceExpression in method private buildProjectedAggregation(planBuilder PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneAggregationColumns |
From |
To |
|
Change Variable Type partitionCountSymbol : Symbol to partitionCountVariable : VariableReferenceExpression in method public apply(node AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.RewriteSpatialPartitioningAggregation |
From |
To |
|
Change Variable Type outputs : List<Symbol> to outputs : List<VariableReferenceExpression> in method public visitExchange(node ExchangeNode, pattern PlanMatchPattern) : MatchResult in class com.facebook.presto.sql.planner.assertions.PlanMatchingVisitor |
From |
To |
|
Change Variable Type input : Symbol to input : VariableReferenceExpression in method private pushPartial(aggregation AggregationNode, exchange ExchangeNode, context Context) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughExchange |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method private coerce(expressions Iterable<? extends Expression>, subPlan PlanBuilder, translations TranslationMap) : Map<VariableReferenceExpression,Expression> in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type inPredicateOutputSymbol : Symbol to inPredicateOutputVariable : VariableReferenceExpression in method public apply(apply ApplyNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin |
From |
To |
|
Change Variable Type projections : ImmutableMap.Builder<Symbol,Expression> to projections : ImmutableMap.Builder<VariableReferenceExpression,Expression> in method private coerce(expressions Iterable<? extends Expression>, subPlan PlanBuilder, translations TranslationMap) : Map<VariableReferenceExpression,Expression> in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type outputToInputMapping : Map<Symbol,Symbol> to outputToInputMapping : Map<VariableReferenceExpression,VariableReferenceExpression> in method public visitProject(node ProjectNode, parentPreference HashComputationSet) : PlanWithProperties in class com.facebook.presto.sql.planner.optimizations.HashGenerationOptimizer.Rewriter |
From |
To |
|
Change Variable Type a : Symbol to a : VariableReferenceExpression in method private buildProjectedFilter(planBuilder PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneFilterColumns |
From |
To |
|
Change Variable Type outputs : List<Symbol> to outputs : List<VariableReferenceExpression> in method private buildProjectedJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneJoinColumns |
From |
To |
|
Change Variable Type exists : Symbol to exists : VariableReferenceExpression in method private rewriteToDefaultAggregation(parent ApplyNode, context Context) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TransformExistsApplyToLateralNode |
From |
To |
|
Change Variable Type assignments : Map<Symbol,Expression> to assignments : Map<VariableReferenceExpression,Expression> in method public getAssignedSymbol(node PlanNode, session Session, metadata Metadata, symbolAliases SymbolAliases) : Optional<Symbol> in class com.facebook.presto.sql.planner.assertions.ExpressionMatcher |
From |
To |
|
Change Variable Type targetInputs : Set<Symbol> to targetInputs : 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 outputSymbol : Symbol to outputVariable : VariableReferenceExpression in method private assignTemporaryTableColumnNames(outputVariables Collection<VariableReferenceExpression>, constantPartitioningVariables Collection<VariableReferenceExpression>) : Map<VariableReferenceExpression,ColumnMetadata> in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Variable Type a : Symbol to a : VariableReferenceExpression in method private buildProjectedLimit(planBuilder PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneLimitColumns |
From |
To |
|
Change Variable Type b : Symbol to b : VariableReferenceExpression in method private buildProjectedTopN(planBuilder PlanBuilder, projectionTopN Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneTopNColumns |
From |
To |
|
Change Variable Type newRadiusSymbol : Optional<Symbol> to newRadiusVariable : Optional<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputSymbols List<Symbol>, 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 a : Symbol to a : VariableReferenceExpression in method private buildProjectedTopN(planBuilder PlanBuilder, projectionTopN Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneTopNColumns |
From |
To |
|
Change Variable Type inPredicateSubquerySymbol : Symbol to inPredicateSubqueryVariable : VariableReferenceExpression in method private appendInPredicateApplyNode(subPlan PlanBuilder, inPredicate InPredicate, correlationAllowed boolean, node Node) : PlanBuilder in class com.facebook.presto.sql.planner.SubqueryPlanner |
From |
To |
|
Change Variable Type outputs : List<Symbol> to outputs : List<VariableReferenceExpression> in method private buildProjectedCrossJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneCrossJoinColumns |
From |
To |
|
Change Variable Type partitionKey : Symbol to partitionKey : VariableReferenceExpression in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type symbolsToAdd : List<Symbol> to variablesToAdd : List<VariableReferenceExpression> in method public visitProject(node ProjectNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Variable Type outputs : List<Symbol> to outputs : List<VariableReferenceExpression> in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type partitioningSymbolAssignments : PartitioningSymbolAssignments to partitioningVariableAssignments : PartitioningVariableAssignments in method private createRemoteMaterializedExchange(exchange ExchangeNode, context RewriteContext<FragmentProperties>) : PlanNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Variable Type constantSymbols : List<Symbol> to constantVariables : List<VariableReferenceExpression> in method private createTemporaryTableWrite(tableHandle TableHandle, variableToColumnMap Map<VariableReferenceExpression,ColumnMetadata>, outputs List<VariableReferenceExpression>, inputs List<List<VariableReferenceExpression>>, sources List<PlanNode>, constantExpressions Map<VariableReferenceExpression,Expression>, partitioningMetadata PartitioningMetadata) : TableFinishNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,Expression> to entry : Map.Entry<VariableReferenceExpression,Expression> in method private canonicalize(oldAssignments Assignments) : Assignments in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type assignment : Map.Entry<Symbol,Expression> to assignment : Map.Entry<VariableReferenceExpression,Expression> in method public computeIdentityTranslations(assignments Assignments, types TypeProvider) : Map<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.AddExchanges |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,SymbolReference> to entry : Map.Entry<VariableReferenceExpression,SymbolReference> in method private appendMarkers(source PlanNode, markerIndex int, markers List<VariableReferenceExpression>, projections Map<VariableReferenceExpression,SymbolReference>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.ImplementIntersectAndExceptAsUnion.Rewriter |
From |
To |
|
Change Variable Type directSymbolTranslationOutputMap : Map<Symbol,Symbol> to directSymbolTranslationOutputMap : Map<VariableReferenceExpression,Symbol> in method public visitProject(node ProjectNode, lookupVariables Set<VariableReferenceExpression>) : Map<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.IndexJoinOptimizer.IndexKeyTracer.Visitor |
From |
To |
|
Change Variable Type columnNameToSymbol : Map<String,Symbol> to columnNameToVariable : Map<String,VariableReferenceExpression> in method private createTemporaryTableWrite(tableHandle TableHandle, variableToColumnMap Map<VariableReferenceExpression,ColumnMetadata>, outputs List<VariableReferenceExpression>, inputs List<List<VariableReferenceExpression>>, sources List<PlanNode>, constantExpressions Map<VariableReferenceExpression,Expression>, partitioningMetadata PartitioningMetadata) : TableFinishNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,Expression> to entry : Map.Entry<VariableReferenceExpression,Expression> in method public visitProject(node ProjectNode, context Void) : Void in class com.facebook.presto.sql.planner.sanity.TypeValidator.Visitor |
From |
To |
|
Change Variable Type subqueryTrue : Symbol to subqueryTrue : VariableReferenceExpression in method private rewriteToNonDefaultAggregation(applyNode ApplyNode, context Context) : Optional<PlanNode> in class com.facebook.presto.sql.planner.iterative.rule.TransformExistsApplyToLateralNode |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method private project(subPlan PlanBuilder, expressions Iterable<Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type rightValue : Symbol to rightValue : VariableReferenceExpression in method private buildProjectedCrossJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneCrossJoinColumns |
From |
To |
|
Change Variable Type leftKeyHash : Symbol to leftKeyHash : VariableReferenceExpression in method private buildProjectedSemiJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneSemiJoinColumns |
From |
To |
|
Change Variable Type leftValue : Symbol to leftValue : VariableReferenceExpression in method private buildProjectedJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneJoinColumns |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method private explicitCoercionFields(subPlan PlanBuilder, alreadyCoerced Iterable<Expression>, uncoerced Iterable<? extends Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type rightValue : Symbol to rightValue : VariableReferenceExpression in method private buildProjectedJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneJoinColumns |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method private appendMarkers(source PlanNode, markerIndex int, markers List<VariableReferenceExpression>, projections Map<VariableReferenceExpression,SymbolReference>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.ImplementIntersectAndExceptAsUnion.Rewriter |
From |
To |
|
Change Variable Type outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method public visitFilter(node FilterNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type leftValue : Symbol to leftValue : VariableReferenceExpression in method private buildProjectedCrossJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneCrossJoinColumns |
From |
To |
|
Change Variable Type exists : Symbol to exists : VariableReferenceExpression in method private rewriteToNonDefaultAggregation(applyNode ApplyNode, context Context) : Optional<PlanNode> in class com.facebook.presto.sql.planner.iterative.rule.TransformExistsApplyToLateralNode |
From |
To |
|
Change Variable Type partitionsSymbol : Symbol to partitionsVariable : 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 newSecondSymbol : Optional<Symbol> to newSecondVariable : Optional<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputSymbols List<Symbol>, 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 orderKey : Symbol to orderKey : VariableReferenceExpression in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type envelopeAssignments : ImmutableMap.Builder<Symbol,Expression> to envelopeAssignments : ImmutableMap.Builder<VariableReferenceExpression,Expression> in method public apply(node AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.RewriteSpatialPartitioningAggregation |
From |
To |
|
Change Variable Type projection : Map.Entry<Symbol,Expression> to projection : Map.Entry<VariableReferenceExpression,Expression> in method public apply(project ProjectNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.PushProjectionThroughExchange |
From |
To |
|
Change Variable Type b : Symbol to b : VariableReferenceExpression in method private buildProjectedLimit(planBuilder PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneLimitColumns |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method public visitAggregation(node AggregationNode, context RewriteContext<Optional<AggregateInfo>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.OptimizeMixedDistinctAggregations.Optimizer |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,Expression> to entry : Map.Entry<VariableReferenceExpression,Expression> 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 a : Symbol to a : VariableReferenceExpression in method private buildProjectedAggregation(planBuilder PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneAggregationColumns |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method private assignPartitioningVariables(partitioning Partitioning) : PartitioningVariableAssignments in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Variable Type computedSymbol : Symbol to computedVariable : VariableReferenceExpression in method private canonicalize(oldAssignments Assignments) : Assignments in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type output : Symbol to output : VariableReferenceExpression in method private pushPartial(aggregation AggregationNode, exchange ExchangeNode, context Context) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.PushPartialAggregationThroughExchange |
From |
To |
|
Change Variable Type deterministicSymbols : Set<Symbol> to deterministicVariables : Set<VariableReferenceExpression> in method public visitProject(node ProjectNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type output1 : Symbol to output1 : VariableReferenceExpression in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type outputs : List<Symbol> to outputs : List<VariableReferenceExpression> in method private buildProjectedSemiJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneSemiJoinColumns |
From |
To |
|
Change Variable Type assignment : Entry<Symbol,Expression> to assignment : Entry<VariableReferenceExpression,Expression> in method public putAll(assignments Map<VariableReferenceExpression,Expression>) : Builder in class com.facebook.presto.sql.planner.plan.Assignments.Builder |
From |
To |
|
Change Variable Type rightKey : Symbol to rightKey : VariableReferenceExpression in method private buildProjectedJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneJoinColumns |
From |
To |
|
Change Variable Type symbolToColumnMap : Map<Symbol,ColumnMetadata> to variableToColumnMap : Map<VariableReferenceExpression,ColumnMetadata> in method private createRemoteMaterializedExchange(exchange ExchangeNode, context RewriteContext<FragmentProperties>) : PlanNode in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Variable Type filteredInputs : List<Symbol> to filteredInputs : List<VariableReferenceExpression> in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type coercedQuantifiedComparisonSymbol : Symbol to coercedQuantifiedComparisonVariable : VariableReferenceExpression in method private planQuantifiedApplyNode(subPlan PlanBuilder, quantifiedComparison QuantifiedComparisonExpression, correlationAllowed boolean) : PlanBuilder in class com.facebook.presto.sql.planner.SubqueryPlanner |
From |
To |
|
Change Variable Type exists : Symbol to exists : VariableReferenceExpression in method private appendExistSubqueryApplyNode(subPlan PlanBuilder, existsPredicate ExistsPredicate, correlationAllowed boolean) : PlanBuilder in class com.facebook.presto.sql.planner.SubqueryPlanner |
From |
To |
|
Change Variable Type constants : Set<Symbol> to constants : Set<VariableReferenceExpression> in method private extractInliningTargets(parent ProjectNode, child ProjectNode, context Context) : Sets.SetView<VariableReferenceExpression> in class com.facebook.presto.sql.planner.iterative.rule.InlineProjections |
From |
To |
|
Change Variable Type computedExpressions : Map<Expression,Symbol> to computedExpressions : Map<Expression,VariableReferenceExpression> in method private canonicalize(oldAssignments Assignments) : Assignments in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type parentAssignments : Map<Symbol,Expression> to parentAssignments : Map<VariableReferenceExpression,Expression> in method public apply(parent ProjectNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.InlineProjections |
From |
To |
|
Change Variable Type targets : Sets.SetView<Symbol> to targets : Sets.SetView<VariableReferenceExpression> in method public apply(parent ProjectNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.InlineProjections |
From |
To |
|
Change Variable Type leftKey : Symbol to leftKey : VariableReferenceExpression in method private buildProjectedJoin(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneJoinColumns |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method private canonicalize(oldAssignments Assignments) : Assignments in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type quantifiedComparisonSymbol : Symbol to quantifiedComparisonVariable : 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 newFirstSymbol : Optional<Symbol> to newFirstVariable : Optional<VariableReferenceExpression> in method private tryCreateSpatialJoin(context Context, joinNode JoinNode, filter Expression, nodeId PlanNodeId, outputSymbols List<Symbol>, 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 constants : ImmutableMap.Builder<Symbol,Expression> to constants : ImmutableMap.Builder<VariableReferenceExpression,Expression> in method private assignPartitioningVariables(partitioning Partitioning) : PartitioningVariableAssignments in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,Expression> to entry : Map.Entry<VariableReferenceExpression,Expression> in method public visitApply(node ApplyNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type aliasedColumn : Symbol to aliasedColumn : VariableReferenceExpression in method protected visitAliasedRelation(node AliasedRelation, context Void) : RelationPlan in class com.facebook.presto.sql.planner.RelationPlanner |
From |
To |
|
Change Variable Type assignment : Map.Entry<Symbol,Expression> to assignment : Map.Entry<VariableReferenceExpression,Expression> in method public apply(parent ProjectNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.InlineProjections |
From |
To |
|
Change Variable Type assignment : Map.Entry<Symbol,Expression> to assignment : Map.Entry<VariableReferenceExpression,Expression> in method public getAssignedSymbol(node PlanNode, session Session, metadata Metadata, symbolAliases SymbolAliases) : Optional<Symbol> in class com.facebook.presto.sql.planner.assertions.ExpressionMatcher |
From |
To |
|
Change Variable Type input1 : Symbol to input1 : VariableReferenceExpression in method private buildProjectedWindow(p PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>, sourceFilter Predicate<VariableReferenceExpression>) : PlanNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneWindowColumns |
From |
To |
|
Change Variable Type output : Symbol to output : VariableReferenceExpression in method private createInsertPlan(analysis Analysis, insertStatement Insert) : RelationPlan in class com.facebook.presto.sql.planner.LogicalPlanner |
From |
To |
|
Change Variable Type envelopeSymbol : Symbol to envelopeVariable : VariableReferenceExpression in method public apply(node AggregationNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.RewriteSpatialPartitioningAggregation |
From |
To |
|
Change Variable Type result : ImmutableMap.Builder<Symbol,ColumnMetadata> to result : ImmutableMap.Builder<VariableReferenceExpression,ColumnMetadata> in method private assignTemporaryTableColumnNames(outputVariables Collection<VariableReferenceExpression>, constantPartitioningVariables Collection<VariableReferenceExpression>) : Map<VariableReferenceExpression,ColumnMetadata> in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Variable Type symbol : Symbol to variable : 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 Variable Type input : Symbol to input : VariableReferenceExpression in method public apply(parent ProjectNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.InlineProjections |
From |
To |
|
Change Variable Type output : Symbol to output : VariableReferenceExpression in method public visitApply(node ApplyNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type symbols : ImmutableList.Builder<Symbol> to variables : ImmutableList.Builder<VariableReferenceExpression> in method private assignPartitioningVariables(partitioning Partitioning) : PartitioningVariableAssignments in class com.facebook.presto.sql.planner.PlanFragmenter.Fragmenter |
From |
To |
|
Change Variable Type b : Symbol to b : VariableReferenceExpression in method private buildProjectedFilter(planBuilder PlanBuilder, projectionFilter Predicate<VariableReferenceExpression>) : ProjectNode in class com.facebook.presto.sql.planner.iterative.rule.TestPruneFilterColumns |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,Expression> to entry : Map.Entry<VariableReferenceExpression,Expression> in method private printAssignments(nodeOutput NodeRepresentation, assignments Assignments) : void in class com.facebook.presto.sql.planner.planPrinter.PlanPrinter.Visitor |
From |
To |
|
Change Variable Type assignment : Map.Entry<Symbol,Expression> to assignment : Map.Entry<VariableReferenceExpression,Expression> in method private getUpdatedAssignments(assignments Assignments) : Map<String,SymbolReference> in class com.facebook.presto.sql.planner.assertions.SymbolAliases |
From |
To |