|
Change Parameter Type radiusSymbol : Optional<Symbol> to radiusVariable : Optional<VariableReferenceExpression> in method private createPagesSpatialIndexFactory(node SpatialJoinNode, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, probeLayout Map<VariableReferenceExpression,Integer>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PagesSpatialIndexFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method private toRowExpression(projection Expression, expressionTypes Map<NodeRef<Expression>,Type>, layout Map<VariableReferenceExpression,Integer>) : RowExpression in class com.facebook.presto.operator.scalar.FunctionAssertions |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method private PhysicalOperation(operatorFactory OperatorFactory, layout Map<VariableReferenceExpression,Integer>, context LocalExecutionPlanContext, source Optional<PhysicalOperation>, pipelineExecutionStrategy PipelineExecutionStrategy) in class com.facebook.presto.sql.planner.LocalExecutionPlanner.PhysicalOperation |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public visitConstant(literal ConstantExpression, layout Map<VariableReferenceExpression,Integer>) : RowExpression in class com.facebook.presto.sql.relational.VariableToChannelTranslator.Visitor |
From |
To |
|
Change Parameter Type probeLayout : Map<Symbol,Integer> to probeLayout : Map<VariableReferenceExpression,Integer> in method private createPagesSpatialIndexFactory(node SpatialJoinNode, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, probeLayout Map<VariableReferenceExpression,Integer>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PagesSpatialIndexFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public IndexLookupSourceFactory(lookupSourceInputChannels Set<Integer>, keyOutputChannels List<Integer>, keyOutputHashChannel OptionalInt, outputTypes List<Type>, layout Map<VariableReferenceExpression,Integer>, indexBuildDriverFactoryProvider IndexBuildDriverFactoryProvider, maxIndexMemorySize DataSize, stats IndexJoinLookupStats, shareIndexLoading boolean, pagesIndexFactory PagesIndex.Factory, joinCompiler JoinCompiler) in class com.facebook.presto.operator.index.IndexLookupSourceFactory |
From |
To |
|
Change Parameter Type probeSymbol : Symbol to probeVariable : VariableReferenceExpression in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeSource PhysicalOperation, probeVariable VariableReferenceExpression, pagesSpatialIndexFactory PagesSpatialIndexFactory, context LocalExecutionPlanContext) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public visitSpecialForm(specialForm SpecialFormExpression, layout Map<VariableReferenceExpression,Integer>) : RowExpression in class com.facebook.presto.sql.relational.VariableToChannelTranslator.Visitor |
From |
To |
|
Change Parameter Type buildLayout : Map<Symbol,Integer> to buildLayout : Map<VariableReferenceExpression,Integer> in method private sortExpressionAsSortChannel(sortExpression RowExpression, probeLayout Map<VariableReferenceExpression,Integer>, buildLayout Map<VariableReferenceExpression,Integer>) : int in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method private Visitor(types Map<NodeRef<Expression>,Type>, layout Map<VariableReferenceExpression,Integer>, typeManager TypeManager, functionManager FunctionManager, session Session) in class com.facebook.presto.sql.relational.SqlToRowExpressionTranslator.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public translate(expression RowExpression, layout Map<VariableReferenceExpression,Integer>) : RowExpression in class com.facebook.presto.sql.relational.VariableToChannelTranslator |
From |
To |
|
Change Parameter Type buildSymbol : Symbol to buildVariable : VariableReferenceExpression in method private createPagesSpatialIndexFactory(node SpatialJoinNode, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, probeLayout Map<VariableReferenceExpression,Integer>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PagesSpatialIndexFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public visitCall(call CallExpression, layout Map<VariableReferenceExpression,Integer>) : RowExpression in class com.facebook.presto.sql.relational.VariableToChannelTranslator.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public visitLambda(lambda LambdaDefinitionExpression, layout Map<VariableReferenceExpression,Integer>) : RowExpression in class com.facebook.presto.sql.relational.VariableToChannelTranslator.Visitor |
From |
To |
|
Change Parameter Type probeLayout : Map<Symbol,Integer> to probeLayout : Map<VariableReferenceExpression,Integer> in method private compileJoinFilterFunction(filterExpression RowExpression, probeLayout Map<VariableReferenceExpression,Integer>, buildLayout Map<VariableReferenceExpression,Integer>) : JoinFilterFunctionFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public visitVariableReference(reference VariableReferenceExpression, layout Map<VariableReferenceExpression,Integer>) : RowExpression in class com.facebook.presto.sql.relational.VariableToChannelTranslator.Visitor |
From |
To |
|
Change Parameter Type outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method private makeLayoutFromOutputVariables(outputVariables List<VariableReferenceExpression>) : ImmutableMap<VariableReferenceExpression,Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type probeSymbol : Symbol to probeVariable : VariableReferenceExpression in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeVariable VariableReferenceExpression, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type lookupSourceLayout : Map<Symbol,Integer> to lookupSourceLayout : Map<VariableReferenceExpression,Integer> in method private createJoinSourcesLayout(lookupSourceLayout Map<VariableReferenceExpression,Integer>, probeSourceLayout Map<VariableReferenceExpression,Integer>) : Map<VariableReferenceExpression,Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public PartitionedLookupSourceFactory(types List<Type>, outputTypes List<Type>, hashChannelTypes List<Type>, partitionCount int, layout Map<VariableReferenceExpression,Integer>, outer boolean) in class com.facebook.presto.operator.PartitionedLookupSourceFactory |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method private toTypes(layout Map<VariableReferenceExpression,Integer>) : List<Type> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.PhysicalOperation |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public PhysicalOperation(operatorFactory OperatorFactory, layout Map<VariableReferenceExpression,Integer>, context LocalExecutionPlanContext, pipelineExecutionStrategy PipelineExecutionStrategy) in class com.facebook.presto.sql.planner.LocalExecutionPlanner.PhysicalOperation |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method private getChannelsForVariables(variables Collection<VariableReferenceExpression>, layout Map<VariableReferenceExpression,Integer>) : List<Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner |
From |
To |
|
Change Parameter Type buildSymbol : Symbol to buildVariable : VariableReferenceExpression in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeVariable VariableReferenceExpression, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type sourceLayout : Map<Symbol,Integer> to sourceLayout : Map<VariableReferenceExpression,Integer> in method private bindChannels(expression RowExpression, sourceLayout Map<VariableReferenceExpression,Integer>) : RowExpression in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type probeSourceLayout : Map<Symbol,Integer> to probeSourceLayout : Map<VariableReferenceExpression,Integer> in method private createJoinSourcesLayout(lookupSourceLayout Map<VariableReferenceExpression,Integer>, probeSourceLayout Map<VariableReferenceExpression,Integer>) : Map<VariableReferenceExpression,Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public translate(expression Expression, types Map<NodeRef<Expression>,Type>, layout Map<VariableReferenceExpression,Integer>, functionManager FunctionManager, typeManager TypeManager, session Session, optimize boolean) : RowExpression in class com.facebook.presto.sql.relational.SqlToRowExpressionTranslator |
From |
To |
|
Change Parameter Type radiusSymbol : Optional<Symbol> to radiusVariable : Optional<VariableReferenceExpression> in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeVariable VariableReferenceExpression, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type inputLayout : Map<Symbol,Integer> to inputLayout : Map<VariableReferenceExpression,Integer> in method private enforceLayoutProcessor(expectedLayout List<VariableReferenceExpression>, inputLayout Map<VariableReferenceExpression,Integer>) : Function<Page,Page> in class com.facebook.presto.sql.planner.LocalExecutionPlanner |
From |
To |
|
Change Parameter Type buildLayout : Map<Symbol,Integer> to buildLayout : Map<VariableReferenceExpression,Integer> in method private compileJoinFilterFunction(filterExpression RowExpression, probeLayout Map<VariableReferenceExpression,Integer>, buildLayout Map<VariableReferenceExpression,Integer>) : JoinFilterFunctionFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public PhysicalOperation(operatorFactory OperatorFactory, layout Map<VariableReferenceExpression,Integer>, context LocalExecutionPlanContext, source PhysicalOperation) in class com.facebook.presto.sql.planner.LocalExecutionPlanner.PhysicalOperation |
From |
To |
|
Change Parameter Type probeLayout : Map<Symbol,Integer> to probeLayout : Map<VariableReferenceExpression,Integer> in method private sortExpressionAsSortChannel(sortExpression RowExpression, probeLayout Map<VariableReferenceExpression,Integer>, buildLayout Map<VariableReferenceExpression,Integer>) : int in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Parameter Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public visitInputReference(input InputReferenceExpression, layout Map<VariableReferenceExpression,Integer>) : RowExpression in class com.facebook.presto.sql.relational.VariableToChannelTranslator.Visitor |
From |
To |
|
Change Parameter Type symbolInput : Map<Symbol,Integer> to variableInput : Map<VariableReferenceExpression,Integer> in method private toRowExpression(session Session, expression Expression, variableInput Map<VariableReferenceExpression,Integer>, types TypeProvider) : RowExpression in class com.facebook.presto.sql.planner.optimizations.ExpressionEquivalence |
From |
To |
|
Change Parameter Type sourceLayout : Map<Symbol,Integer> to sourceLayout : Map<VariableReferenceExpression,Integer> in method private toRowExpression(expression Expression, types Map<NodeRef<Expression>,Type>, sourceLayout Map<VariableReferenceExpression,Integer>) : RowExpression in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable probeOutputSymbols : List<Symbol> to probeOutputVariables : List<VariableReferenceExpression> in method private createLookupJoin(node JoinNode, probeSource PhysicalOperation, probeVariables List<VariableReferenceExpression>, probeHashVariable Optional<VariableReferenceExpression>, lookupSourceFactoryManager JoinBridgeManager<? extends LookupSourceFactory>, context LocalExecutionPlanContext) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable buildOutputSymbols : List<Symbol> to buildOutputVariables : List<VariableReferenceExpression> in method private createPagesSpatialIndexFactory(node SpatialJoinNode, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, probeLayout Map<VariableReferenceExpression,Integer>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PagesSpatialIndexFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method protected createHashProjectOperator(operatorId int, planNodeId PlanNodeId, types List<Type>) : OperatorFactory in class com.facebook.presto.benchmark.AbstractOperatorBenchmark |
From |
To |
|
Rename Variable probeOutputSymbols : List<Symbol> to probeOutputVariables : List<VariableReferenceExpression> in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeSource PhysicalOperation, probeVariable VariableReferenceExpression, pagesSpatialIndexFactory PagesSpatialIndexFactory, context LocalExecutionPlanContext) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable firstSymbol : VariableReferenceExpression to firstVariable : VariableReferenceExpression in method private tryCreateSpatialJoin(context LocalExecutionPlanContext, node SpatialJoinNode, filterExpression Optional<RowExpression>, spatialFunction CallExpression, radius Optional<VariableReferenceExpression>, comparisonOperator Optional<OperatorType>) : Optional<PhysicalOperation> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable buildOutputSymbols : List<Symbol> to buildOutputVariables : List<VariableReferenceExpression> in method private createLookupSourceFactory(node JoinNode, buildNode PlanNode, buildVariables List<VariableReferenceExpression>, buildHashVariable Optional<VariableReferenceExpression>, probeSource PhysicalOperation, context LocalExecutionPlanContext) : JoinBridgeManager<PartitionedLookupSourceFactory> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeVariable VariableReferenceExpression, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method public setup() : void in class com.facebook.presto.sql.gen.PageProcessorBenchmark |
From |
To |
|
Rename Variable symbolInput : Map<Symbol,Integer> to variableInput : Map<VariableReferenceExpression,Integer> in method public areExpressionsEquivalent(session Session, leftExpression Expression, rightExpression Expression, types TypeProvider) : boolean in class com.facebook.presto.sql.planner.optimizations.ExpressionEquivalence |
From |
To |
|
Rename Variable secondSymbol : VariableReferenceExpression to secondVariable : VariableReferenceExpression in method private tryCreateSpatialJoin(context LocalExecutionPlanContext, node SpatialJoinNode, filterExpression Optional<RowExpression>, spatialFunction CallExpression, radius Optional<VariableReferenceExpression>, comparisonOperator Optional<OperatorType>) : Optional<PhysicalOperation> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method private createLookupJoin(node JoinNode, probeNode PlanNode, probeVariables List<VariableReferenceExpression>, probeHashVariable Optional<VariableReferenceExpression>, buildNode PlanNode, buildVariables List<VariableReferenceExpression>, buildHashVariable Optional<VariableReferenceExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable symbolToInputMapping : ImmutableMap.Builder<Symbol,Integer> to variableToInputMapping : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method protected createHashProjectOperator(operatorId int, planNodeId PlanNodeId, types List<Type>) : OperatorFactory in class com.facebook.presto.benchmark.AbstractOperatorBenchmark |
From |
To |
|
Rename Variable symbol : Symbol to variable : VariableReferenceExpression in method private makeLayoutFromOutputVariables(outputVariables List<VariableReferenceExpression>) : ImmutableMap<VariableReferenceExpression,Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Variable argumentSymbol : Symbol to argumentVariable : VariableReferenceExpression in method private buildAccumulatorFactory(source PhysicalOperation, aggregation Aggregation, types TypeProvider) : AccumulatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method public visitWindow(node WindowNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type buildLayout : Map<Symbol,Integer> to buildLayout : Map<VariableReferenceExpression,Integer> in method private createPagesSpatialIndexFactory(node SpatialJoinNode, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, probeLayout Map<VariableReferenceExpression,Integer>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PagesSpatialIndexFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type sourceLayout : Map<Symbol,Integer> to sourceLayout : Map<VariableReferenceExpression,Integer> 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 Variable Type joinSourcesLayout : Map<Symbol,Integer> to joinSourcesLayout : Map<VariableReferenceExpression,Integer> in method private sortExpressionAsSortChannel(sortExpression RowExpression, probeLayout Map<VariableReferenceExpression,Integer>, buildLayout Map<VariableReferenceExpression,Integer>) : int in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public visitTableFinish(node TableFinishNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method private createLookupJoin(node JoinNode, probeNode PlanNode, probeVariables List<VariableReferenceExpression>, probeHashVariable Optional<VariableReferenceExpression>, buildNode PlanNode, buildVariables List<VariableReferenceExpression>, buildHashVariable Optional<VariableReferenceExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type symbolToInputMapping : ImmutableMap.Builder<Symbol,Integer> to variableToInputMapping : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method protected createHashProjectOperator(operatorId int, planNodeId PlanNodeId, types List<Type>) : OperatorFactory in class com.facebook.presto.benchmark.AbstractOperatorBenchmark |
From |
To |
|
Change Variable Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeVariable VariableReferenceExpression, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type argumentSymbol : Symbol to argumentVariable : VariableReferenceExpression in method private buildAccumulatorFactory(source PhysicalOperation, aggregation Aggregation, types TypeProvider) : AccumulatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method public visitRowNumber(node RowNumberNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type channelLayout : Map<Integer,Symbol> to channelLayout : Map<Integer,VariableReferenceExpression> in method private toTypes(layout Map<VariableReferenceExpression,Integer>) : List<Type> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.PhysicalOperation |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,Integer> to entry : Map.Entry<VariableReferenceExpression,Integer> in method private createNestedLoopJoin(node JoinNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type probeChannelGetter : Function<Symbol,Integer> to probeChannelGetter : Function<VariableReferenceExpression,Integer> in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeSource PhysicalOperation, probeVariable VariableReferenceExpression, pagesSpatialIndexFactory PagesSpatialIndexFactory, context LocalExecutionPlanContext) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method public visitUnnest(node UnnestNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type probeOutputSymbols : List<Symbol> to probeOutputVariables : List<VariableReferenceExpression> in method private createLookupJoin(node JoinNode, probeSource PhysicalOperation, probeVariables List<VariableReferenceExpression>, probeHashVariable Optional<VariableReferenceExpression>, lookupSourceFactoryManager JoinBridgeManager<? extends LookupSourceFactory>, context LocalExecutionPlanContext) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type probeOutputSymbols : List<Symbol> to probeOutputVariables : List<VariableReferenceExpression> in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeSource PhysicalOperation, probeVariable VariableReferenceExpression, pagesSpatialIndexFactory PagesSpatialIndexFactory, context LocalExecutionPlanContext) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeVariable VariableReferenceExpression, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type buildOutputSymbols : List<Symbol> to buildOutputVariables : List<VariableReferenceExpression> in method private createLookupSourceFactory(node JoinNode, buildNode PlanNode, buildVariables List<VariableReferenceExpression>, buildHashVariable Optional<VariableReferenceExpression>, probeSource PhysicalOperation, context LocalExecutionPlanContext) : JoinBridgeManager<PartitionedLookupSourceFactory> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type symbolInput : Map<Symbol,Integer> to variableInput : Map<VariableReferenceExpression,Integer> in method public areExpressionsEquivalent(session Session, leftExpression Expression, rightExpression Expression, types TypeProvider) : boolean in class com.facebook.presto.sql.planner.optimizations.ExpressionEquivalence |
From |
To |
|
Change Variable Type mappings : ImmutableMap.Builder<String,String> to mappings : ImmutableMap.Builder<VariableReferenceExpression,VariableReferenceExpression> in method private rewriteSource(writerNode TableWriterNode, unionNode UnionNode, source int, sourceMappings List<Map<VariableReferenceExpression,VariableReferenceExpression>>, context Context) : TableWriterNode in class com.facebook.presto.sql.planner.iterative.rule.PushTableWriteThroughUnion |
From |
To |
|
Change Variable Type outputMappings : Map<Symbol,Integer> to outputMappings : Map<VariableReferenceExpression,Integer> 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 Variable Type layout : ImmutableMap<Symbol,Integer> to layout : ImmutableMap<VariableReferenceExpression,Integer> in method private createLocalMerge(node ExchangeNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type outputMappingsBuilder : ImmutableMap.Builder<Symbol,Integer> to outputMappingsBuilder : ImmutableMap.Builder<VariableReferenceExpression,Integer> 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 Variable Type joinSourcesLayout : Builder<Symbol,Integer> to joinSourcesLayout : Builder<VariableReferenceExpression,Integer> in method private createJoinSourcesLayout(lookupSourceLayout Map<VariableReferenceExpression,Integer>, probeSourceLayout Map<VariableReferenceExpression,Integer>) : Map<VariableReferenceExpression,Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type probeLayoutEntry : Map.Entry<Symbol,Integer> to probeLayoutEntry : Map.Entry<VariableReferenceExpression,Integer> in method private createJoinSourcesLayout(lookupSourceLayout Map<VariableReferenceExpression,Integer>, probeSourceLayout Map<VariableReferenceExpression,Integer>) : Map<VariableReferenceExpression,Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method private makeLayoutFromOutputVariables(outputVariables List<VariableReferenceExpression>) : ImmutableMap<VariableReferenceExpression,Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method public visitTopNRowNumber(node TopNRowNumberNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type layout : ImmutableMap<Symbol,Integer> to layout : ImmutableMap<VariableReferenceExpression,Integer> in method private createMergeSource(node RemoteSourceNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type buildChannelGetter : Function<Symbol,Integer> to buildChannelGetter : Function<VariableReferenceExpression,Integer> in method private createPagesSpatialIndexFactory(node SpatialJoinNode, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, probeLayout Map<VariableReferenceExpression,Integer>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PagesSpatialIndexFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method private createLookupJoin(node JoinNode, probeNode PlanNode, probeVariables List<VariableReferenceExpression>, probeHashVariable Optional<VariableReferenceExpression>, buildNode PlanNode, buildVariables List<VariableReferenceExpression>, buildHashVariable Optional<VariableReferenceExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method public visitIndexJoin(node IndexJoinNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type buildOutputSymbols : List<Symbol> to buildOutputVariables : List<VariableReferenceExpression> in method private createPagesSpatialIndexFactory(node SpatialJoinNode, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, probeLayout Map<VariableReferenceExpression,Integer>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PagesSpatialIndexFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type joinSourcesLayout : Map<Symbol,Integer> to joinSourcesLayout : Map<VariableReferenceExpression,Integer> in method private compileJoinFilterFunction(filterExpression RowExpression, probeLayout Map<VariableReferenceExpression,Integer>, buildLayout Map<VariableReferenceExpression,Integer>) : JoinFilterFunctionFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method protected createHashProjectOperator(operatorId int, planNodeId PlanNodeId, types List<Type>) : OperatorFactory in class com.facebook.presto.benchmark.AbstractOperatorBenchmark |
From |
To |
|
Change Variable Type outputMappings : Builder<Symbol,Integer> to outputMappings : Builder<VariableReferenceExpression,Integer> in method private makeLayoutFromOutputVariables(outputVariables List<VariableReferenceExpression>) : ImmutableMap<VariableReferenceExpression,Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type symbol : Symbol to variable : VariableReferenceExpression in method public setup() : void in class com.facebook.presto.sql.gen.PageProcessorBenchmark |
From |
To |
|
Change Variable Type newLayout : Map<Symbol,Integer> to newLayout : Map<VariableReferenceExpression,Integer> in method public visitGroupId(node GroupIdNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type entry : Map.Entry<Symbol,Integer> to entry : Map.Entry<VariableReferenceExpression,Integer> in method public visitIndexJoin(node IndexJoinNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type layout : Map<Symbol,Integer> to layout : Map<VariableReferenceExpression,Integer> in method public visitDelete(node DeleteNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type outputMappings : ImmutableMap.Builder<Symbol,Integer> to outputMappings : ImmutableMap.Builder<VariableReferenceExpression,Integer> in method private createNestedLoopJoin(node JoinNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type symbol : Symbol to input : VariableReferenceExpression in method private variableToChannel(input VariableReferenceExpression) : int in class com.facebook.presto.sql.planner.LocalExecutionPlanner.PhysicalOperation |
From |
To |
|
Rename Parameter probeSymbol : Symbol to probeVariable : VariableReferenceExpression in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeSource PhysicalOperation, probeVariable VariableReferenceExpression, pagesSpatialIndexFactory PagesSpatialIndexFactory, context LocalExecutionPlanContext) : OperatorFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Parameter buildSymbol : Symbol to buildVariable : VariableReferenceExpression in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeVariable VariableReferenceExpression, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Parameter outputSymbols : List<Symbol> to outputVariables : List<VariableReferenceExpression> in method private makeLayoutFromOutputVariables(outputVariables List<VariableReferenceExpression>) : ImmutableMap<VariableReferenceExpression,Integer> in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Parameter symbolInput : Map<Symbol,Integer> to variableInput : Map<VariableReferenceExpression,Integer> in method private toRowExpression(session Session, expression Expression, variableInput Map<VariableReferenceExpression,Integer>, types TypeProvider) : RowExpression in class com.facebook.presto.sql.planner.optimizations.ExpressionEquivalence |
From |
To |
|
Rename Parameter radiusSymbol : Optional<Symbol> to radiusVariable : Optional<VariableReferenceExpression> in method private createPagesSpatialIndexFactory(node SpatialJoinNode, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, probeLayout Map<VariableReferenceExpression,Integer>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PagesSpatialIndexFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Parameter probeSymbol : Symbol to probeVariable : VariableReferenceExpression in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeVariable VariableReferenceExpression, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Parameter radiusSymbol : Optional<Symbol> to radiusVariable : Optional<VariableReferenceExpression> in method private createSpatialLookupJoin(node SpatialJoinNode, probeNode PlanNode, probeVariable VariableReferenceExpression, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Rename Parameter buildSymbol : Symbol to buildVariable : VariableReferenceExpression in method private createPagesSpatialIndexFactory(node SpatialJoinNode, buildNode PlanNode, buildVariable VariableReferenceExpression, radiusVariable Optional<VariableReferenceExpression>, probeLayout Map<VariableReferenceExpression,Integer>, spatialRelationshipTest SpatialPredicate, joinFilter Optional<RowExpression>, context LocalExecutionPlanContext) : PagesSpatialIndexFactory in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |