|
Change Parameter Type correlation : Iterable<Symbol> to correlation : Iterable<VariableReferenceExpression> in method public DecorrelatingVisitor(lookup Lookup, correlation Iterable<VariableReferenceExpression>, types TypeProvider) in class com.facebook.presto.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin.DecorrelatingVisitor |
From |
To |
|
Change Parameter Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in method public ApplyNode(id PlanNodeId, input PlanNode, subquery PlanNode, subqueryAssignments Assignments, correlation List<VariableReferenceExpression>, originSubqueryError String) in class com.facebook.presto.sql.planner.plan.ApplyNode |
From |
To |
|
Change Parameter Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in method private error(correlation List<VariableReferenceExpression>, originSubqueryError String) : SemanticException in class com.facebook.presto.sql.planner.optimizations.CheckSubqueryNodesAreRewritten |
From |
To |
|
Change Parameter Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in method public lateral(correlation List<VariableReferenceExpression>, input PlanNode, subquery PlanNode) : LateralJoinNode in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder |
From |
To |
|
Change Parameter Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in method private decorrelatedNode(correlatedPredicates List<Expression>, node PlanNode, correlation List<VariableReferenceExpression>) : Optional<DecorrelatedNode> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator |
From |
To |
|
Change Parameter Type symbolsToPropagate : Set<Symbol> to variablesToPropagate : Set<VariableReferenceExpression> in method package DecorrelationResult(node PlanNode, variablesToPropagate Set<VariableReferenceExpression>, correlatedPredicates List<Expression>, correlatedVariablesMapping Multimap<VariableReferenceExpression,VariableReferenceExpression>, atMostSingleRow boolean) in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelationResult |
From |
To |
|
Change Parameter Type correlatedSymbolsMapping : Multimap<Symbol,Symbol> to correlatedVariablesMapping : Multimap<VariableReferenceExpression,VariableReferenceExpression> in method package DecorrelationResult(node PlanNode, variablesToPropagate Set<VariableReferenceExpression>, correlatedPredicates List<Expression>, correlatedVariablesMapping Multimap<VariableReferenceExpression,VariableReferenceExpression>, atMostSingleRow boolean) in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelationResult |
From |
To |
|
Change Parameter Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in method public apply(subqueryAssignments Assignments, correlation List<VariableReferenceExpression>, input PlanNode, subquery PlanNode) : ApplyNode in class com.facebook.presto.sql.planner.iterative.rule.test.PlanBuilder |
From |
To |
|
Change Parameter Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in method public decorrelateFilters(node PlanNode, correlation List<VariableReferenceExpression>) : Optional<DecorrelatedNode> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator |
From |
To |
|
Change Parameter Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in method package DecorrelatingVisitor(correlation List<VariableReferenceExpression>) in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Parameter Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in method private containsCorrelation(node PlanNode, correlation List<VariableReferenceExpression>) : boolean in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator |
From |
To |
|
Change Parameter Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in method public LateralJoinNode(id PlanNodeId, input PlanNode, subquery PlanNode, correlation List<VariableReferenceExpression>, type Type, originSubqueryError String) in class com.facebook.presto.sql.planner.plan.LateralJoinNode |
From |
To |
|
Rename Variable symbolsToPropagate : Set<Symbol> to variablesToPropagate : Set<VariableReferenceExpression> in method public visitFilter(node FilterNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Rename Variable symbolsToAdd : List<Symbol> to variablesToAdd : List<VariableReferenceExpression> in method public visitAggregation(node AggregationNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Rename Variable subquerySymbols : Set<Symbol> to subqueryVariables : Set<VariableReferenceExpression> in method public visitLateralJoin(node LateralJoinNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Rename Variable constantSymbols : Set<Symbol> to constantVariables : Set<VariableReferenceExpression> in method public visitAggregation(node AggregationNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Rename Variable constantSymbols : Set<Symbol> to constantVariables : Set<VariableReferenceExpression> in method public visitLimit(node LimitNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Return Type Property<ApplyNode,List<Symbol>> to Property<ApplyNode,List<VariableReferenceExpression>> in method public correlation() : Property<ApplyNode,List<VariableReferenceExpression>> in class com.facebook.presto.sql.planner.plan.Patterns.Apply |
From |
To |
|
Change Return Type List<Symbol> to List<VariableReferenceExpression> in method public getCorrelation() : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.LateralJoinNode |
From |
To |
|
Change Return Type Multimap<Symbol,Symbol> to Multimap<VariableReferenceExpression,VariableReferenceExpression> in method private extractCorrelatedSymbolsMapping(correlatedConjuncts List<Expression>) : Multimap<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Return Type Set<Symbol> to Set<VariableReferenceExpression> in method package getConstantVariables() : Set<VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelationResult |
From |
To |
|
Change Return Type Property<LateralJoinNode,List<Symbol>> to Property<LateralJoinNode,List<VariableReferenceExpression>> in method public correlation() : Property<LateralJoinNode,List<VariableReferenceExpression>> in class com.facebook.presto.sql.planner.plan.Patterns.LateralJoin |
From |
To |
|
Change Return Type List<Symbol> to List<VariableReferenceExpression> in method private getCorrelation(node PlanNode) : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.assertions.CorrelationMatcher |
From |
To |
|
Change Return Type List<Symbol> to List<VariableReferenceExpression> in method public getCorrelation() : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.ApplyNode |
From |
To |
|
Change Variable Type canonicalCorrelation : List<Symbol> to canonicalCorrelation : List<VariableReferenceExpression> in method public visitLateralJoin(node LateralJoinNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type newCorrelation : List<Symbol> to newCorrelation : List<VariableReferenceExpression> in method public visitLateralJoin(node LateralJoinNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type mapping : ImmutableMultimap.Builder<Symbol,Symbol> to mapping : ImmutableMultimap.Builder<VariableReferenceExpression,VariableReferenceExpression> in method private extractCorrelatedSymbolsMapping(correlatedConjuncts List<Expression>) : Multimap<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Variable Type subquerySymbols : Set<Symbol> to subqueryVariables : Set<VariableReferenceExpression> in method public visitLateralJoin(node LateralJoinNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type right : Symbol to right : VariableReferenceExpression in method private extractCorrelatedSymbolsMapping(correlatedConjuncts List<Expression>) : Multimap<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Variable Type groupingKeys : Set<Symbol> to groupingKeys : Set<VariableReferenceExpression> in method public visitAggregation(node AggregationNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Variable Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in method public rewriteScalarAggregation(lateralJoinNode LateralJoinNode, aggregation AggregationNode) : PlanNode in class com.facebook.presto.sql.planner.optimizations.ScalarAggregationToJoinRewriter |
From |
To |
|
Change Variable Type symbolsToAdd : List<Symbol> to variablesToAdd : List<VariableReferenceExpression> in method public visitAggregation(node AggregationNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Variable Type symbolsToPropagate : Set<Symbol> to variablesToPropagate : Set<VariableReferenceExpression> in method public visitFilter(node FilterNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Variable Type constantSymbols : Set<Symbol> to constantVariables : Set<VariableReferenceExpression> in method public visitAggregation(node AggregationNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Variable Type actualCorrelation : List<Symbol> to actualCorrelation : List<VariableReferenceExpression> in method public detailMatches(node PlanNode, stats StatsProvider, session Session, metadata Metadata, symbolAliases SymbolAliases) : MatchResult in class com.facebook.presto.sql.planner.assertions.CorrelationMatcher |
From |
To |
|
Change Variable Type subquerySymbols : Set<Symbol> to subquerySymbols : Set<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 canonicalCorrelation : List<Symbol> to canonicalCorrelation : List<VariableReferenceExpression> in method public visitApply(node ApplyNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |
|
Change Variable Type newCorrelation : List<Symbol> to newCorrelation : List<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 left : Symbol to left : VariableReferenceExpression in method private extractCorrelatedSymbolsMapping(correlatedConjuncts List<Expression>) : Multimap<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Variable Type constantSymbols : Set<Symbol> to constantVariables : Set<VariableReferenceExpression> in method public visitLimit(node LimitNode, context Void) : Optional<DecorrelationResult> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Attribute Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.LateralJoinNode |
From |
To |
|
Change Attribute Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.ApplyNode |
From |
To |
|
Change Attribute Type correlation : Set<Symbol> to correlation : Set<VariableReferenceExpression> in class com.facebook.presto.sql.planner.iterative.rule.TransformCorrelatedInPredicateToJoin.DecorrelatingVisitor |
From |
To |
|
Change Attribute Type correlatedSymbolsMapping : Multimap<Symbol,Symbol> to correlatedVariablesMapping : Multimap<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelationResult |
From |
To |
|
Change Attribute Type correlation : List<Symbol> to correlation : List<VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelatingVisitor |
From |
To |
|
Change Attribute Type symbolsToPropagate : Set<Symbol> to variablesToPropagate : Set<VariableReferenceExpression> in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelationResult |
From |
To |
|
Rename Parameter symbolsToPropagate : Set<Symbol> to variablesToPropagate : Set<VariableReferenceExpression> in method package DecorrelationResult(node PlanNode, variablesToPropagate Set<VariableReferenceExpression>, correlatedPredicates List<Expression>, correlatedVariablesMapping Multimap<VariableReferenceExpression,VariableReferenceExpression>, atMostSingleRow boolean) in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelationResult |
From |
To |
|
Rename Parameter correlatedSymbolsMapping : Multimap<Symbol,Symbol> to correlatedVariablesMapping : Multimap<VariableReferenceExpression,VariableReferenceExpression> in method package DecorrelationResult(node PlanNode, variablesToPropagate Set<VariableReferenceExpression>, correlatedPredicates List<Expression>, correlatedVariablesMapping Multimap<VariableReferenceExpression,VariableReferenceExpression>, atMostSingleRow boolean) in class com.facebook.presto.sql.planner.optimizations.PlanNodeDecorrelator.DecorrelationResult |
From |
To |