|
Rename Method public outputSymbolMap(sourceIndex int) : Multimap<Symbol,Symbol> renamed to public outputMap(sourceIndex int) : Multimap<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.SetOperationNode |
From |
To |
|
Rename Method private symbolBeginsWith(prefixes String...) : Predicate<Symbol> renamed to private variableBeginsWith(prefixes String...) : Predicate<VariableReferenceExpression> in class com.facebook.presto.sql.planner.TestEqualityInference |
From |
To |
|
Rename Method private symbolBeginsWith(prefixes Iterable<String>) : Predicate<Symbol> renamed to private variableBeginsWith(prefixes Iterable<String>) : Predicate<VariableReferenceExpression> in class com.facebook.presto.sql.planner.TestEqualityInference |
From |
To |
|
Rename Method private matchesSymbols(symbols Collection<String>) : Predicate<Symbol> renamed to private matchesVariables(variables Collection<String>) : Predicate<VariableReferenceExpression> in class com.facebook.presto.sql.planner.TestEqualityInference |
From |
To |
|
Rename Method private pullExpressionThroughSymbols(expression Expression, symbols Collection<Symbol>) : Expression renamed to private pullExpressionThroughVariables(expression Expression, variables Collection<VariableReferenceExpression>) : Expression in class com.facebook.presto.sql.planner.EffectivePredicateExtractor.Visitor |
From |
To |
|
Rename Method public expressionOrNullSymbols(nullSymbolScopes Predicate<Symbol>...) : Function<Expression,Expression> renamed to public expressionOrNullVariables(types TypeProvider, nullVariableScopes Predicate<VariableReferenceExpression>...) : Function<Expression,Expression> in class com.facebook.presto.sql.ExpressionUtils |
From |
To |
|
Change Parameter Type mapping : Function<Integer,Collection<Map.Entry<Symbol,SymbolReference>>> to mapping : Function<Integer,Collection<Map.Entry<VariableReferenceExpression,SymbolReference>>> in method private deriveCommonPredicates(node PlanNode, mapping Function<Integer,Collection<Map.Entry<VariableReferenceExpression,SymbolReference>>>) : Expression in class com.facebook.presto.sql.planner.EffectivePredicateExtractor.Visitor |
From |
To |
|
Change Parameter Type outerSymbols : Collection<Symbol> to outerVariables : Collection<VariableReferenceExpression> in method private processLimitedOuterJoin(inheritedPredicate Expression, outerEffectivePredicate Expression, innerEffectivePredicate Expression, joinPredicate Expression, outerVariables Collection<VariableReferenceExpression>) : OuterJoinPushDownResult in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Parameter Type symbolScope : Predicate<Symbol> to variableScope : Predicate<VariableReferenceExpression> in method public generateEqualitiesPartitionedBy(variableScope Predicate<VariableReferenceExpression>, types TypeProvider) : EqualityPartition in class com.facebook.presto.sql.planner.EqualityInference |
From |
To |
|
Change Parameter Type symbolScope : Predicate<Symbol> to variableScope : Predicate<VariableReferenceExpression> in method private rewriteExpression(expression Expression, variableScope Predicate<VariableReferenceExpression>, allowFullReplacement boolean, types TypeProvider) : Expression in class com.facebook.presto.sql.planner.EqualityInference |
From |
To |
|
Change Parameter Type symbolScope : Predicate<Symbol> to variableScope : Predicate<VariableReferenceExpression> in method public rewriteExpression(expression Expression, variableScope Predicate<VariableReferenceExpression>, types TypeProvider) : Expression in class com.facebook.presto.sql.planner.EqualityInference |
From |
To |
|
Change Parameter Type symbols : Collection<Symbol> to variables : Collection<VariableReferenceExpression> in method private pullExpressionThroughVariables(expression Expression, variables Collection<VariableReferenceExpression>) : Expression in class com.facebook.presto.sql.planner.EffectivePredicateExtractor.Visitor |
From |
To |
|
Change Parameter Type leftSymbols : Collection<Symbol> to leftVariables : Collection<VariableReferenceExpression> in method private processInnerJoin(inheritedPredicate Expression, leftEffectivePredicate Expression, rightEffectivePredicate Expression, joinPredicate Expression, leftVariables Collection<VariableReferenceExpression>) : InnerJoinPushDownResult in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Parameter Type leftSymbols : Collection<Symbol> to leftVariables : Collection<VariableReferenceExpression> in method private joinEqualityExpression(leftVariables Collection<VariableReferenceExpression>) : Predicate<Expression> in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Parameter Type symbolScope : Predicate<Symbol> to variableScope : Predicate<VariableReferenceExpression> in method public rewriteExpressionAllowNonDeterministic(expression Expression, variableScope Predicate<VariableReferenceExpression>, types TypeProvider) : Expression in class com.facebook.presto.sql.planner.EqualityInference |
From |
To |
|
Change Parameter Type innerSymbolsForOuterJoin : List<Symbol> to innerVariablesForOuterJoin : List<VariableReferenceExpression> in method private canConvertOuterToInner(innerVariablesForOuterJoin List<VariableReferenceExpression>, inheritedPredicate Expression) : boolean in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Variable symbols : List<Symbol> to variables : List<VariableReferenceExpression> in method public expressionOrNullVariables(types TypeProvider, nullVariableScopes Predicate<VariableReferenceExpression>...) : Function<Expression,Expression> in class com.facebook.presto.sql.ExpressionUtils |
From |
To |
|
Rename Variable filteringSourceSymbols : List<Symbol> to filteringSourceVariables : List<VariableReferenceExpression> in method private visitFilteringSemiJoin(node SemiJoinNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Variable symbols2 : Set<Symbol> to variables2 : Set<VariableReferenceExpression> in method private joinEqualityExpression(leftVariables Collection<VariableReferenceExpression>) : Predicate<Expression> in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Variable nullSymbolScope : Predicate<Symbol> to nullVariableScope : Predicate<VariableReferenceExpression> in method public expressionOrNullVariables(types TypeProvider, nullVariableScopes Predicate<VariableReferenceExpression>...) : Function<Expression,Expression> in class com.facebook.presto.sql.ExpressionUtils |
From |
To |
|
Rename Variable symbols : Set<Symbol> to variables : Set<VariableReferenceExpression> in method private matchesStraddlingScope(variableScope Predicate<VariableReferenceExpression>, types TypeProvider) : Predicate<Expression> in class com.facebook.presto.sql.planner.TestEqualityInference |
From |
To |
|
Rename Variable predicateSymbols : Set<Symbol> to predicateVariables : Set<VariableReferenceExpression> in method public visitAssignUniqueId(node AssignUniqueId, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Variable symbols1 : Set<Symbol> to variables1 : Set<VariableReferenceExpression> in method private joinEqualityExpression(leftVariables Collection<VariableReferenceExpression>) : Predicate<Expression> in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Variable sourceSymbols : List<Symbol> to sourceVariables : List<VariableReferenceExpression> in method private visitFilteringSemiJoin(node SemiJoinNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Variable commonGroupingSymbolMapping : Map<Symbol,SymbolReference> to commonGroupingVariableMapping : Map<VariableReferenceExpression,SymbolReference> in method public visitGroupId(node GroupIdNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Variable groupingKeySymbols : List<Symbol> to groupingKeyVariables : List<VariableReferenceExpression> in method public visitAggregation(node AggregationNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Return Type Predicate<Symbol> to Predicate<VariableReferenceExpression> in method private matchesVariables(variables Collection<String>) : Predicate<VariableReferenceExpression> in class com.facebook.presto.sql.planner.TestEqualityInference |
From |
To |
|
Change Return Type Predicate<Symbol> to Predicate<VariableReferenceExpression> in method private variableBeginsWith(prefixes String...) : Predicate<VariableReferenceExpression> in class com.facebook.presto.sql.planner.TestEqualityInference |
From |
To |
|
Change Return Type Multimap<Symbol,Symbol> to Multimap<VariableReferenceExpression,VariableReferenceExpression> in method public outputMap(sourceIndex int) : Multimap<VariableReferenceExpression,VariableReferenceExpression> in class com.facebook.presto.sql.planner.plan.SetOperationNode |
From |
To |
|
Change Return Type Predicate<Symbol> to Predicate<VariableReferenceExpression> in method private variableBeginsWith(prefixes Iterable<String>) : Predicate<VariableReferenceExpression> in class com.facebook.presto.sql.planner.TestEqualityInference |
From |
To |
|
Change Variable Type groupingKeySymbols : List<Symbol> to groupingKeyVariables : List<VariableReferenceExpression> in method public visitAggregation(node AggregationNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type mappings : Map<Symbol,SymbolReference> to mappings : Map<VariableReferenceExpression,SymbolReference> in method public visitExchange(node ExchangeNode, context Void) : Expression in class com.facebook.presto.sql.planner.EffectivePredicateExtractor.Visitor |
From |
To |
|
Change Variable Type symbols : List<Symbol> to variables : List<VariableReferenceExpression> in method public expressionOrNullVariables(types TypeProvider, nullVariableScopes Predicate<VariableReferenceExpression>...) : Function<Expression,Expression> in class com.facebook.presto.sql.ExpressionUtils |
From |
To |
|
Change Variable Type symbols2 : Set<Symbol> to variables2 : Set<VariableReferenceExpression> in method private joinEqualityExpression(leftVariables Collection<VariableReferenceExpression>) : Predicate<Expression> in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type filteringSourceSymbols : List<Symbol> to filteringSourceVariables : List<VariableReferenceExpression> in method private visitFilteringSemiJoin(node SemiJoinNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type symbols : Set<Symbol> to variables : Set<VariableReferenceExpression> in method private matchesStraddlingScope(variableScope Predicate<VariableReferenceExpression>, types TypeProvider) : Predicate<Expression> in class com.facebook.presto.sql.planner.TestEqualityInference |
From |
To |
|
Change Variable Type predicateSymbols : Set<Symbol> to predicateVariables : Set<VariableReferenceExpression> in method public visitAssignUniqueId(node AssignUniqueId, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type childOutputSet : Set<Symbol> to childOutputSet : Set<VariableReferenceExpression> in method private isInliningCandidate(expression Expression, node ProjectNode) : boolean in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type symbols1 : Set<Symbol> to variables1 : Set<VariableReferenceExpression> in method private joinEqualityExpression(leftVariables Collection<VariableReferenceExpression>) : Predicate<Expression> in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type dependencies : Map<Symbol,Long> to dependencies : Map<VariableReferenceExpression,Long> in method private isInliningCandidate(expression Expression, node ProjectNode) : boolean in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type commonGroupingSymbolMapping : Map<Symbol,SymbolReference> to commonGroupingVariableMapping : Map<VariableReferenceExpression,SymbolReference> in method public visitGroupId(node GroupIdNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type nullSymbolScope : Predicate<Symbol> to nullVariableScope : Predicate<VariableReferenceExpression> in method public expressionOrNullVariables(types TypeProvider, nullVariableScopes Predicate<VariableReferenceExpression>...) : Function<Expression,Expression> in class com.facebook.presto.sql.ExpressionUtils |
From |
To |
|
Change Variable Type symbolSet : Set<Symbol> to symbolSet : Set<VariableReferenceExpression> in method private matchesVariables(variables Collection<String>) : Predicate<VariableReferenceExpression> in class com.facebook.presto.sql.planner.TestEqualityInference |
From |
To |
|
Change Variable Type outputsToInputs : Map<Symbol,SymbolReference> to outputsToInputs : Map<VariableReferenceExpression,SymbolReference> in method public visitExchange(node ExchangeNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Change Variable Type sourceSymbols : List<Symbol> to sourceVariables : List<VariableReferenceExpression> in method private visitFilteringSemiJoin(node SemiJoinNode, context RewriteContext<Expression>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Parameter leftSymbols : Collection<Symbol> to leftVariables : Collection<VariableReferenceExpression> in method private processInnerJoin(inheritedPredicate Expression, leftEffectivePredicate Expression, rightEffectivePredicate Expression, joinPredicate Expression, leftVariables Collection<VariableReferenceExpression>) : InnerJoinPushDownResult in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Parameter leftSymbols : Collection<Symbol> to leftVariables : Collection<VariableReferenceExpression> in method private joinEqualityExpression(leftVariables Collection<VariableReferenceExpression>) : Predicate<Expression> in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Parameter innerSymbolsForOuterJoin : List<Symbol> to innerVariablesForOuterJoin : List<VariableReferenceExpression> in method private canConvertOuterToInner(innerVariablesForOuterJoin List<VariableReferenceExpression>, inheritedPredicate Expression) : boolean in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Parameter symbolScope : Predicate<Symbol> to variableScope : Predicate<VariableReferenceExpression> in method public rewriteExpressionAllowNonDeterministic(expression Expression, variableScope Predicate<VariableReferenceExpression>, types TypeProvider) : Expression in class com.facebook.presto.sql.planner.EqualityInference |
From |
To |
|
Rename Parameter outerSymbols : Collection<Symbol> to outerVariables : Collection<VariableReferenceExpression> in method private processLimitedOuterJoin(inheritedPredicate Expression, outerEffectivePredicate Expression, innerEffectivePredicate Expression, joinPredicate Expression, outerVariables Collection<VariableReferenceExpression>) : OuterJoinPushDownResult in class com.facebook.presto.sql.planner.optimizations.PredicatePushDown.Rewriter |
From |
To |
|
Rename Parameter symbolScope : Predicate<Symbol> to variableScope : Predicate<VariableReferenceExpression> in method public generateEqualitiesPartitionedBy(variableScope Predicate<VariableReferenceExpression>, types TypeProvider) : EqualityPartition in class com.facebook.presto.sql.planner.EqualityInference |
From |
To |
|
Rename Parameter symbolScope : Predicate<Symbol> to variableScope : Predicate<VariableReferenceExpression> in method private rewriteExpression(expression Expression, variableScope Predicate<VariableReferenceExpression>, allowFullReplacement boolean, types TypeProvider) : Expression in class com.facebook.presto.sql.planner.EqualityInference |
From |
To |
|
Rename Parameter symbols : Collection<String> to variables : Collection<String> in method private matchesVariables(variables Collection<String>) : Predicate<VariableReferenceExpression> in class com.facebook.presto.sql.planner.TestEqualityInference |
From |
To |
|
Rename Parameter symbolScope : Predicate<Symbol> to variableScope : Predicate<VariableReferenceExpression> in method public rewriteExpression(expression Expression, variableScope Predicate<VariableReferenceExpression>, types TypeProvider) : Expression in class com.facebook.presto.sql.planner.EqualityInference |
From |
To |
|
Rename Parameter symbols : Collection<Symbol> to variables : Collection<VariableReferenceExpression> in method private pullExpressionThroughVariables(expression Expression, variables Collection<VariableReferenceExpression>) : Expression in class com.facebook.presto.sql.planner.EffectivePredicateExtractor.Visitor |
From |
To |