|
Rename Method protected visitExpression(expression Expression, context Void) : Optional<SortExpressionContext> renamed to public visitConstant(literal ConstantExpression, context Void) : Optional<SortExpressionContext> in class com.facebook.presto.sql.planner.SortExpressionExtractor.SortExpressionVisitor |
From |
To |
|
Rename Method protected visitSymbolReference(symbolReference SymbolReference, context Void) : Boolean renamed to public visitVariableReference(reference VariableReferenceExpression, context Void) : Boolean in class com.facebook.presto.sql.planner.SortExpressionExtractor.BuildSymbolReferenceFinder |
From |
To |
|
Rename Method private asBuildSymbolReference(buildLayout Set<Symbol>, expression Expression) : Optional<SymbolReference> renamed to private asBuildVariableReference(buildLayout Set<Symbol>, expression RowExpression) : Optional<VariableReferenceExpression> in class com.facebook.presto.sql.planner.SortExpressionExtractor |
From |
To |
|
Rename Method protected visitNode(node Node, context Void) : Boolean renamed to public visitCall(call CallExpression, context Void) : Boolean in class com.facebook.presto.sql.planner.SortExpressionExtractor.BuildSymbolReferenceFinder |
From |
To |
|
Change Parameter Type filter : Optional<Expression> to filter : Optional<RowExpression> in method public JoinNode(id PlanNodeId, type Type, left PlanNode, right PlanNode, criteria List<EquiJoinClause>, outputSymbols List<Symbol>, filter Optional<RowExpression>, leftHashSymbol Optional<Symbol>, rightHashSymbol Optional<Symbol>, distributionType Optional<DistributionType>) in class com.facebook.presto.sql.planner.plan.JoinNode |
From |
To |
|
Change Parameter Type joinFilter : Optional<Expression> to joinFilter : Optional<RowExpression> in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeSymbol Symbol, buildNode PlanNode, buildSymbol Symbol, radiusSymbol Optional<Symbol>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type searchExpressions : List<Expression> to searchExpressions : List<RowExpression> in method public SortExpressionContext(sortExpression RowExpression, searchExpressions List<RowExpression>) in class com.facebook.presto.sql.planner.SortExpressionContext |
From |
To |
|
Change Parameter Type joinFilter : Optional<Expression> to joinFilter : Optional<RowExpression> in method private createPagesSpatialIndexFactory(node SpatialJoinNode, buildNode PlanNode, buildSymbol Symbol, radiusSymbol Optional<Symbol>, probeLayout Map<Symbol,Integer>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PagesSpatialIndexFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type sortExpression : Expression to sortExpression : RowExpression in method private sortExpressionAsSortChannel(sortExpression RowExpression, probeLayout Map<Symbol,Integer>, buildLayout Map<Symbol,Integer>) : int in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type symbolReference : SymbolReference to reference : VariableReferenceExpression in method public visitVariableReference(reference VariableReferenceExpression, context Void) : Boolean in class com.facebook.presto.sql.planner.SortExpressionExtractor.BuildSymbolReferenceFinder |
From |
To |
|
Change Parameter Type expression : Expression to literal : ConstantExpression in method public visitConstant(literal ConstantExpression, context Void) : Optional<SortExpressionContext> in class com.facebook.presto.sql.planner.SortExpressionExtractor.SortExpressionVisitor |
From |
To |
|
Change Parameter Type expression : Expression to expression : RowExpression in method private asBuildVariableReference(buildLayout Set<Symbol>, expression RowExpression) : Optional<VariableReferenceExpression> in class com.facebook.presto.sql.planner.SortExpressionExtractor |
From |
To |
|
Change Parameter Type filter : Optional<Expression> to filter : Optional<RowExpression> in method package calculateJoinComplementStats(filter Optional<RowExpression>, criteria List<JoinNode.EquiJoinClause>, leftStats PlanNodeStatsEstimate, rightStats PlanNodeStatsEstimate, types TypeProvider) : PlanNodeStatsEstimate in class com.facebook.presto.cost.JoinStatsRule |
From |
To |
|
Change Parameter Type sortExpression : Expression to sortExpression : RowExpression in method public SortExpressionContext(sortExpression RowExpression, searchExpressions List<RowExpression>) in class com.facebook.presto.sql.planner.SortExpressionContext |
From |
To |
|
Change Parameter Type filter : Expression to filter : RowExpression in method public extractSortExpression(buildSymbols Set<Symbol>, filter RowExpression, functionManager FunctionManager) : Optional<SortExpressionContext> in class com.facebook.presto.sql.planner.SortExpressionExtractor |
From |
To |
|
Change Parameter Type node : Node to call : CallExpression in method public visitCall(call CallExpression, context Void) : Boolean in class com.facebook.presto.sql.planner.SortExpressionExtractor.BuildSymbolReferenceFinder |
From |
To |
|
Rename Variable symbolReference : SymbolReference to reference : VariableReferenceExpression in method private asBuildVariableReference(buildLayout Set<Symbol>, expression RowExpression) : Optional<VariableReferenceExpression> in class com.facebook.presto.sql.planner.SortExpressionExtractor |
From |
To |
|
Rename Variable child : Node to argument : RowExpression in method public visitCall(call CallExpression, context Void) : Boolean in class com.facebook.presto.sql.planner.SortExpressionExtractor.BuildSymbolReferenceFinder |
From |
To |
|
Rename Variable filterExpression : Optional<Expression> to filter : Optional<RowExpression> in method private tryCreateSpatialJoin(context LocalExecutionPlanContext, node SpatialJoinNode, filterExpression Optional<Expression>, spatialFunction FunctionCall, radius Optional<Expression>, comparisonOperator Optional<ComparisonExpression.Operator>) : Optional<PhysicalOperation> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type joinExpressions : List<Expression> to joinExpressions : List<String> in method public visitJoin(node JoinNode, context Void) : Void in class com.facebook.presto.sql.planner.planPrinter.PlanPrinter.Visitor |
From |
To |
|
Change Variable Type child : Node to argument : RowExpression in method public visitCall(call CallExpression, context Void) : Boolean in class com.facebook.presto.sql.planner.SortExpressionExtractor.BuildSymbolReferenceFinder |
From |
To |
|
Change Variable Type filterConjuncts : List<Expression> to filterConjuncts : List<RowExpression> in method public extractSortExpression(buildSymbols Set<Symbol>, filter RowExpression, functionManager FunctionManager) : Optional<SortExpressionContext> in class com.facebook.presto.sql.planner.SortExpressionExtractor |
From |
To |
|
Change Variable Type symbolReference : SymbolReference to reference : VariableReferenceExpression in method private asBuildVariableReference(buildLayout Set<Symbol>, expression RowExpression) : Optional<VariableReferenceExpression> in class com.facebook.presto.sql.planner.SortExpressionExtractor |
From |
To |
|
Change Variable Type searchExpressions : ImmutableList.Builder<Expression> to searchExpressions : ImmutableList.Builder<RowExpression> in method private merge(left SortExpressionContext, right SortExpressionContext) : SortExpressionContext in class com.facebook.presto.sql.planner.SortExpressionExtractor |
From |
To |
|
Change Variable Type filterExpression : Optional<Expression> to filter : Optional<RowExpression> in method private tryCreateSpatialJoin(context LocalExecutionPlanContext, node SpatialJoinNode, filterExpression Optional<Expression>, spatialFunction FunctionCall, radius Optional<Expression>, comparisonOperator Optional<ComparisonExpression.Operator>) : Optional<PhysicalOperation> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |