|
Change Variable Type row : List<Expression> to row : List<RowExpression> in method protected pushDownProjectOff(idAllocator PlanNodeIdAllocator, valuesNode ValuesNode, referencedOutputs Set<Symbol>) : Optional<PlanNode> in class com.facebook.presto.sql.planner.iterative.rule.PruneValuesColumns |
From |
To |
|
Change Variable Type rewrittenRows : List<List<Expression>> to rewrittenRows : List<List<RowExpression>> in method public visitValues(node ValuesNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.SubqueryPlanner.ExpressionReplacer |
From |
To |
|
Change Variable Type rewrittenRows : List<List<Expression>> to rewrittenRows : List<List<RowExpression>> in method public visitValues(node ValuesNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type rowsBuilder : ImmutableList.Builder<List<Expression>> to rowsBuilder : ImmutableList.Builder<List<RowExpression>> in method protected pushDownProjectOff(idAllocator PlanNodeIdAllocator, valuesNode ValuesNode, referencedOutputs Set<Symbol>) : Optional<PlanNode> in class com.facebook.presto.sql.planner.iterative.rule.PruneValuesColumns |
From |
To |
|
Change Variable Type newRow : ImmutableList.Builder<Expression> to newRow : ImmutableList.Builder<RowExpression> in method public apply(valuesNode ValuesNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExpressionRewriteRuleSet.ValuesExpressionRewrite |
From |
To |
|
Change Variable Type row : List<Expression> to row : List<RowExpression> in method public apply(valuesNode ValuesNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExpressionRewriteRuleSet.ValuesExpressionRewrite |
From |
To |
|
Change Variable Type rowBuilders : ImmutableList<ImmutableList.Builder<Expression>> to rowBuilders : ImmutableList<ImmutableList.Builder<RowExpression>> in method public visitValues(node ValuesNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type rowBuildersBuilder : ImmutableList.Builder<ImmutableList.Builder<Expression>> to rowBuildersBuilder : ImmutableList.Builder<ImmutableList.Builder<RowExpression>> in method public visitValues(node ValuesNode, context RewriteContext<Set<Symbol>>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.PruneUnreferencedOutputs.Rewriter |
From |
To |
|
Change Variable Type values : ImmutableList.Builder<Expression> to values : ImmutableList.Builder<RowExpression> in method protected visitUnnest(node Unnest, context Void) : RelationPlan in class com.facebook.presto.sql.planner.RelationPlanner |
From |
To |
|
Change Variable Type rowsBuilder : ImmutableList.Builder<List<Expression>> to rowsBuilder : ImmutableList.Builder<List<RowExpression>> in method public visitAggregation(node AggregationNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.MetadataQueryOptimizer.Optimizer |
From |
To |
|
Change Variable Type row : List<Expression> to row : List<RowExpression> in method public visitValues(node ValuesNode, context LocalExecutionPlanContext) : PhysicalOperation in class com.facebook.presto.sql.planner.LocalExecutionPlanner.Visitor |
From |
To |
|
Change Variable Type values : ImmutableList.Builder<Expression> to values : ImmutableList.Builder<RowExpression> in method protected visitValues(node Values, context Void) : RelationPlan in class com.facebook.presto.sql.planner.RelationPlanner |
From |
To |
|
Change Variable Type row : List<Expression> to row : List<RowExpression> in method public visitValues(node ValuesNode, context Void) : Void in class com.facebook.presto.sql.planner.planPrinter.PlanPrinter.Visitor |
From |
To |
|
Change Variable Type nullLiterals : ImmutableList.Builder<Expression> to nullLiterals : ImmutableList.Builder<RowExpression> in method private createAggregationOverNull(referenceAggregation AggregationNode, symbolAllocator SymbolAllocator, idAllocator PlanNodeIdAllocator, lookup Lookup) : Optional<MappedAggregationInfo> in class com.facebook.presto.sql.planner.iterative.rule.PushAggregationThroughOuterJoin |
From |
To |
|
Change Variable Type rowBuilder : ImmutableList.Builder<Expression> to rowBuilder : ImmutableList.Builder<RowExpression> in method public visitAggregation(node AggregationNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.MetadataQueryOptimizer.Optimizer |
From |
To |
|
Change Variable Type row : List<Expression> to row : List<RowExpression> in method public ValuesNode(id PlanNodeId, outputSymbols List<Symbol>, rows List<List<RowExpression>>) in class com.facebook.presto.sql.planner.plan.ValuesNode |
From |
To |
|
Change Variable Type rows : ImmutableList.Builder<List<Expression>> to rows : ImmutableList.Builder<List<RowExpression>> in method public apply(valuesNode ValuesNode, captures Captures, context Context) : Result in class com.facebook.presto.sql.planner.iterative.rule.ExpressionRewriteRuleSet.ValuesExpressionRewrite |
From |
To |
|
Change Variable Type rows : ImmutableList.Builder<List<Expression>> to rowsBuilder : ImmutableList.Builder<List<RowExpression>> in method protected visitValues(node Values, context Void) : RelationPlan in class com.facebook.presto.sql.planner.RelationPlanner |
From |
To |
|
Change Variable Type canonicalizedRows : List<List<Expression>> to canonicalizedRows : List<List<RowExpression>> in method public visitValues(node ValuesNode, context RewriteContext<Void>) : PlanNode in class com.facebook.presto.sql.planner.optimizations.UnaliasSymbolReferences.Rewriter |
From |
To |