|
Change Parameter Type expressions : List<List<FieldOrExpression>> to expressions : List<List<Expression>> in method public setGroupingSets(node QuerySpecification, expressions List<List<Expression>>) : void in class com.facebook.presto.sql.analyzer.Analysis |
From |
To |
|
Change Parameter Type inputs : Iterable<FieldOrExpression> to inputs : Iterable<Expression> in method private handleSubqueries(subPlan PlanBuilder, node Node, inputs Iterable<Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Parameter Type outputExpressions : List<FieldOrExpression> to outputExpressions : List<Expression> in method private analyzeWindowFunctions(node QuerySpecification, outputExpressions List<Expression>, orderByExpressions List<Expression>) : void in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Parameter Type expressions : List<FieldOrExpression> to expressions : List<Expression> in method public setOutputExpressions(node Node, expressions List<Expression>) : void in class com.facebook.presto.sql.analyzer.Analysis |
From |
To |
|
Change Parameter Type outputExpressions : List<FieldOrExpression> to outputExpressions : List<Expression> in method private analyzeGroupBy(node QuerySpecification, tupleDescriptor RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<List<Expression>> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Parameter Type groupByExpressions : List<FieldOrExpression> to groupByExpressions : List<Expression> in method public AggregationAnalyzer(groupByExpressions List<Expression>, metadata Metadata, tupleDescriptor RelationType, columnReferences Set<Expression>) in class com.facebook.presto.sql.analyzer.AggregationAnalyzer |
From |
To |
|
Change Parameter Type groupingSets : List<List<FieldOrExpression>> to groupingSets : List<List<Expression>> in method private analyzeAggregations(node QuerySpecification, tupleDescriptor RelationType, groupingSets List<List<Expression>>, outputExpressions List<Expression>, orderByExpressions List<Expression>, context AnalysisContext, columnReferences Set<Expression>) : void in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Parameter Type outputExpressions : List<FieldOrExpression> to outputExpressions : List<Expression> in method private analyzeOrderBy(node QuerySpecification, sourceType RelationType, outputType RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Parameter Type orderByExpressions : List<FieldOrExpression> to orderByExpressions : List<Expression> in method private sort(subPlan PlanBuilder, orderBy List<SortItem>, limit Optional<String>, orderByExpressions List<Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Parameter Type items : List<FieldOrExpression> to items : List<Expression> in method public setOrderByExpressions(node Node, items List<Expression>) : void in class com.facebook.presto.sql.analyzer.Analysis |
From |
To |
|
Change Parameter Type outputExpressions : List<FieldOrExpression> to outputExpressions : List<Expression> in method private analyzeGroupingColumns(groupingColumns Set<Expression>, node QuerySpecification, tupleDescriptor RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Parameter Type outputExpressions : List<FieldOrExpression> to outputExpressions : List<Expression> in method private analyzeAggregations(node QuerySpecification, tupleDescriptor RelationType, groupingSets List<List<Expression>>, outputExpressions List<Expression>, orderByExpressions List<Expression>, context AnalysisContext, columnReferences Set<Expression>) : void in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Parameter Type outputs : List<FieldOrExpression> to outputs : List<Expression> in method private distinct(subPlan PlanBuilder, node QuerySpecification, outputs List<Expression>, orderBy List<Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Parameter Type orderBy : List<FieldOrExpression> to orderBy : List<Expression> in method private distinct(subPlan PlanBuilder, node QuerySpecification, outputs List<Expression>, orderBy List<Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Parameter Type orderByExpressions : List<FieldOrExpression> to orderByExpressions : List<Expression> in method private analyzeAggregations(node QuerySpecification, tupleDescriptor RelationType, groupingSets List<List<Expression>>, outputExpressions List<Expression>, orderByExpressions List<Expression>, context AnalysisContext, columnReferences Set<Expression>) : void in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Parameter Type alreadyCoerced : Iterable<FieldOrExpression> to alreadyCoerced : Iterable<Expression> in method private explicitCoercionFields(subPlan PlanBuilder, alreadyCoerced Iterable<Expression>, uncoerced Iterable<? extends Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Parameter Type orderByExpressions : List<FieldOrExpression> to orderByExpressions : List<Expression> in method private analyzeWindowFunctions(node QuerySpecification, outputExpressions List<Expression>, orderByExpressions List<Expression>) : void in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Parameter Type expressions : Iterable<FieldOrExpression> to expressions : Iterable<Expression> in method private project(subPlan PlanBuilder, expressions Iterable<Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Parameter Type outputExpressions : List<FieldOrExpression> to outputExpressions : List<Expression> in method private computeOutputs(builder PlanBuilder, outputExpressions List<Expression>) : List<Symbol> in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Return Type List<FieldOrExpression> to List<Expression> in method public getOrderByExpressions(node Node) : List<Expression> in class com.facebook.presto.sql.analyzer.Analysis |
From |
To |
|
Change Return Type List<FieldOrExpression> to List<Expression> in method private analyzeSelect(node QuerySpecification, tupleDescriptor RelationType, context AnalysisContext) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Return Type List<FieldOrExpression> to List<Expression> in method private analyzeGroupingColumns(groupingColumns Set<Expression>, node QuerySpecification, tupleDescriptor RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Return Type List<List<FieldOrExpression>> to List<List<Expression>> in method private analyzeGroupBy(node QuerySpecification, tupleDescriptor RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<List<Expression>> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Return Type List<FieldOrExpression> to List<Expression> in method private descriptorToFields(tupleDescriptor RelationType, context AnalysisContext) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Return Type List<FieldOrExpression> to List<Expression> in method public getOutputExpressions(node Node) : List<Expression> in class com.facebook.presto.sql.analyzer.Analysis |
From |
To |
|
Change Return Type List<FieldOrExpression> to List<Expression> in method private analyzeOrderBy(node QuerySpecification, sourceType RelationType, outputType RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Return Type List<List<FieldOrExpression>> to List<List<Expression>> in method public getGroupingSets(node QuerySpecification) : List<List<Expression>> in class com.facebook.presto.sql.analyzer.Analysis |
From |
To |
|
Change Variable Type fieldOrExpression : FieldOrExpression to fieldOrExpression : Expression in method private sort(subPlan PlanBuilder, orderBy List<SortItem>, limit Optional<String>, orderByExpressions List<Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type analyzedGroupingSets : List<List<FieldOrExpression>> to analyzedGroupingSets : List<List<Expression>> in method private analyzeGroupBy(node QuerySpecification, tupleDescriptor RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<List<Expression>> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type orderByExpressions : List<FieldOrExpression> to orderByExpressions : List<Expression> in method private analyzeOrderBy(node QuerySpecification, sourceType RelationType, outputType RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type orderByExpressionsBuilder : ImmutableList.Builder<FieldOrExpression> to orderByExpressionsBuilder : ImmutableList.Builder<Expression> in method private analyzeOrderBy(node QuerySpecification, sourceType RelationType, outputType RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type builder : ImmutableList.Builder<FieldOrExpression> to builder : ImmutableList.Builder<Expression> in method private descriptorToFields(tupleDescriptor RelationType, context AnalysisContext) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type fieldOrExpression : FieldOrExpression to expression : Expression in method private analyzeAggregations(node QuerySpecification, tupleDescriptor RelationType, groupingSets List<List<Expression>>, outputExpressions List<Expression>, orderByExpressions List<Expression>, context AnalysisContext, columnReferences Set<Expression>) : void in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type fieldOrExpression : FieldOrExpression to expression : Expression in method private analyzeWindowFunctions(node QuerySpecification, outputExpressions List<Expression>, orderByExpressions List<Expression>) : void in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type result : ImmutableList<FieldOrExpression> to result : ImmutableList<Expression> in method private analyzeSelect(node QuerySpecification, tupleDescriptor RelationType, context AnalysisContext) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type groupingColumnsBuilder : ImmutableList.Builder<FieldOrExpression> to groupingColumnsBuilder : ImmutableList.Builder<Expression> in method private analyzeGroupingColumns(groupingColumns Set<Expression>, node QuerySpecification, tupleDescriptor RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type groupByExpression : FieldOrExpression to groupByExpression : Expression in method private analyzeGroupingColumns(groupingColumns Set<Expression>, node QuerySpecification, tupleDescriptor RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type groupingSet : List<FieldOrExpression> to groupingSet : List<Expression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type groupingSets : List<List<FieldOrExpression>> to groupingSets : List<List<Expression>> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type outputs : List<FieldOrExpression> to outputs : List<Expression> in method public plan(node QuerySpecification) : RelationPlan in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type orderByExpression : FieldOrExpression to orderByExpression : Expression in method private analyzeOrderBy(node QuerySpecification, sourceType RelationType, outputType RelationType, context AnalysisContext, outputExpressions List<Expression>) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type outputExpressions : List<FieldOrExpression> to outputExpressions : List<Expression> in method protected visitQuerySpecification(node QuerySpecification, parentContext AnalysisContext) : RelationType in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type fieldOrExpression : FieldOrExpression to expression : Expression in method private explicitCoercionFields(subPlan PlanBuilder, alreadyCoerced Iterable<Expression>, uncoerced Iterable<? extends Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type fieldOrExpression : FieldOrExpression to expression : Expression in method private project(subPlan PlanBuilder, expressions Iterable<Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type input : FieldOrExpression to input : Expression in method private handleSubqueries(subPlan PlanBuilder, node Node, inputs Iterable<Expression>) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type inputs : Iterable<FieldOrExpression> to inputs : Iterable<Expression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type fieldOrExpression : FieldOrExpression to expression : Expression in method private computeOutputs(builder PlanBuilder, outputExpressions List<Expression>) : List<Symbol> in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type outputExpressionBuilder : ImmutableList.Builder<FieldOrExpression> to outputExpressionBuilder : ImmutableList.Builder<Expression> in method private analyzeSelect(node QuerySpecification, tupleDescriptor RelationType, context AnalysisContext) : List<Expression> in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type orderBy : List<FieldOrExpression> to orderBy : List<Expression> in method public plan(query Query) : RelationPlan in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type orderBy : List<FieldOrExpression> to orderBy : List<Expression> in method public plan(node QuerySpecification) : RelationPlan in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type distinctGroupingColumns : Set<FieldOrExpression> to distinctGroupingColumns : Set<Expression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type arguments : List<FieldOrExpression> to arguments : List<Expression> in method private aggregate(subPlan PlanBuilder, node QuerySpecification) : PlanBuilder in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type outputs : List<FieldOrExpression> to outputs : List<Expression> in method public plan(query Query) : RelationPlan in class com.facebook.presto.sql.planner.QueryPlanner |
From |
To |
|
Change Variable Type orderByExpressions : List<FieldOrExpression> to orderByExpressions : List<Expression> in method protected visitQuerySpecification(node QuerySpecification, parentContext AnalysisContext) : RelationType in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type distinctGroupingColumns : ImmutableList<FieldOrExpression> to distinctGroupingColumns : ImmutableList<Expression> in method private analyzeAggregations(node QuerySpecification, tupleDescriptor RelationType, groupingSets List<List<Expression>>, outputExpressions List<Expression>, orderByExpressions List<Expression>, context AnalysisContext, columnReferences Set<Expression>) : void in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type groupByExpressions : List<List<FieldOrExpression>> to groupByExpressions : List<List<Expression>> in method protected visitQuerySpecification(node QuerySpecification, parentContext AnalysisContext) : RelationType in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |
|
Change Variable Type orderByFieldsBuilder : ImmutableList.Builder<FieldOrExpression> to orderByFieldsBuilder : ImmutableList.Builder<Expression> in method private analyzeOrderBy(node Query, tupleDescriptor RelationType, context AnalysisContext) : void in class com.facebook.presto.sql.analyzer.StatementAnalyzer |
From |
To |