|
Change Parameter Type estimatedCost : List<PlanNodeCostEstimate> to estimatedCost : List<PlanCostEstimate> in method public NodeRepresentation(id PlanNodeId, name String, type String, identifier String, outputs List<Symbol>, stats Optional<PlanNodeStats>, estimatedStats List<PlanNodeStatsEstimate>, estimatedCost List<PlanCostEstimate>, children List<PlanNodeId>, remoteSources List<PlanFragmentId>) in class com.facebook.presto.sql.planner.planPrinter.NodeRepresentation |
From |
To |
|
Change Parameter Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method private assertCost(node PlanNode, costs Map<String,PlanCostEstimate>, stats Map<String,PlanNodeStatsEstimate>, types Map<String,Type>) : CostAssertionBuilder in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Parameter Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method private assertCostFragmentedPlan(node PlanNode, costs Map<String,PlanCostEstimate>, stats Map<String,PlanNodeStatsEstimate>, types Map<String,Type>) : CostAssertionBuilder in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Parameter Type actual : PlanNodeCostEstimate to actual : PlanCostEstimate in method package CostAssertionBuilder(actual PlanCostEstimate) in class com.facebook.presto.cost.TestCostCalculator.CostAssertionBuilder |
From |
To |
|
Change Parameter Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method private assertCost(costCalculator CostCalculator, node PlanNode, costs Map<String,PlanCostEstimate>, stats Map<String,PlanNodeStatsEstimate>, types Map<String,Type>) : CostAssertionBuilder in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Parameter Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method private assertCostEstimatedExchanges(node PlanNode, costs Map<String,PlanCostEstimate>, stats Map<String,PlanNodeStatsEstimate>, types Map<String,Type>) : CostAssertionBuilder in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Parameter Type costs : Map<PlanNodeId,PlanNodeCostEstimate> to costs : Map<PlanNodeId,PlanCostEstimate> in method public StatsAndCosts(stats Map<PlanNodeId,PlanNodeStatsEstimate>, costs Map<PlanNodeId,PlanCostEstimate>) in class com.facebook.presto.cost.StatsAndCosts |
From |
To |
|
Change Parameter Type cost : PlanNodeCostEstimate to cost : PlanCostEstimate in method private JoinEnumerationResult(planNode Optional<PlanNode>, cost PlanCostEstimate) in class com.facebook.presto.sql.planner.iterative.rule.ReorderJoins.JoinEnumerationResult |
From |
To |
|
Change Parameter Type left : PlanNodeCostEstimate to left : PlanCostEstimate in method public compare(session Session, left PlanCostEstimate, right PlanCostEstimate) : int in class com.facebook.presto.cost.CostComparator |
From |
To |
|
Change Parameter Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method private sourceCostProvider(costCalculator CostCalculator, costs Map<String,PlanCostEstimate>, statsProvider Function<PlanNode,PlanNodeStatsEstimate>, types Map<String,Type>) : Function<PlanNode,PlanCostEstimate> in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Parameter Type costs : Function<PlanNode,PlanNodeCostEstimate> to costs : Function<PlanNode,PlanCostEstimate> in method private calculateCumulativeCost(costCalculator CostCalculator, node PlanNode, costs Function<PlanNode,PlanCostEstimate>, stats Function<PlanNode,PlanNodeStatsEstimate>, types Map<String,Type>) : PlanCostEstimate in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Parameter Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method private TestingCostProvider(costs Map<String,PlanCostEstimate>, costCalculator CostCalculator, statsProvider StatsProvider, session Session, types TypeProvider) in class com.facebook.presto.cost.TestCostCalculator.TestingCostProvider |
From |
To |
|
Change Parameter Type right : PlanNodeCostEstimate to right : PlanCostEstimate in method public compare(session Session, left PlanCostEstimate, right PlanCostEstimate) : int in class com.facebook.presto.cost.CostComparator |
From |
To |
|
Change Parameter Type other : PlanNodeCostEstimate to other : PlanCostEstimate in method public add(other PlanCostEstimate) : PlanCostEstimate in class com.facebook.presto.cost.PlanCostEstimate |
From |
To |
|
Change Parameter Type cost : PlanNodeCostEstimate to cost : PlanCostEstimate in method public storeCumulativeCost(group int, cost PlanCostEstimate) : void in class com.facebook.presto.sql.planner.iterative.Memo |
From |
To |
|
Change Parameter Type cost : PlanNodeCostEstimate to cost : PlanCostEstimate in method public PlanNodeWithCost(cost PlanCostEstimate, planNode PlanNode) in class com.facebook.presto.sql.planner.iterative.rule.PlanNodeWithCost |
From |
To |
|
Change Parameter Type cost : PlanNodeCostEstimate to cost : PlanCostEstimate in method package createJoinEnumerationResult(planNode Optional<PlanNode>, cost PlanCostEstimate) : JoinEnumerationResult in class com.facebook.presto.sql.planner.iterative.rule.ReorderJoins.JoinEnumerationResult |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitValues(node ValuesNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type Optional<PlanNodeCostEstimate> to Optional<PlanCostEstimate> in method public getCumulativeCost(group int) : Optional<PlanCostEstimate> in class com.facebook.presto.sql.planner.iterative.Memo |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitUnion(node UnionNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges.ExchangeCostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitAssignUniqueId(node AssignUniqueId, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitSemiJoin(node SemiJoinNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type Ordering<PlanNodeCostEstimate> to Ordering<PlanCostEstimate> in method public forSession(session Session) : Ordering<PlanCostEstimate> in class com.facebook.presto.cost.CostComparator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitJoin(node JoinNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitEnforceSingleRow(node EnforceSingleRowNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public networkCost(networkCost double) : PlanCostEstimate in class com.facebook.presto.cost.PlanCostEstimate |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitOutput(node OutputNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitGroupReference(node GroupReference, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitSpatialJoin(node SpatialJoinNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitAggregation(node AggregationNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges.ExchangeCostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method protected visitPlan(node PlanNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges.ExchangeCostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitTableScan(node TableScanNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public calculateCost(node PlanNode, stats StatsProvider, session Session, types TypeProvider) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method private calculateCumulativeCostFragmentedPlan(node PlanNode, statsCalculator StatsCalculator, types Map<String,Type>) : PlanCostEstimate in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitFilter(node FilterNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public getCost() : PlanCostEstimate in class com.facebook.presto.sql.planner.iterative.rule.PlanNodeWithCost |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method private calculateCumulativeCost(node PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.CachingCostProvider |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public zero() : PlanCostEstimate in class com.facebook.presto.cost.PlanCostEstimate |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public infinite() : PlanCostEstimate in class com.facebook.presto.cost.PlanCostEstimate |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public calculateJoinCostWithoutOutput(probe PlanNode, build PlanNode, stats StatsProvider, types TypeProvider, replicated boolean, estimatedSourceDistributedTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitSemiJoin(node SemiJoinNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges.ExchangeCostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method protected visitPlan(node PlanNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public calculateRemoteRepartitionCost(inputSizeInBytes double) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitProject(node ProjectNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitJoin(node JoinNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges.ExchangeCostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method private calculateJoinOutputCost(join PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type Map<PlanNodeId,PlanNodeCostEstimate> to Map<PlanNodeId,PlanCostEstimate> in method public getCosts() : Map<PlanNodeId,PlanCostEstimate> in class com.facebook.presto.cost.StatsAndCosts |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitSort(node SortNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method private calculateCumulativeCost(node PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.TestCostCalculator.TestingCostProvider |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public calculateCost(node PlanNode, stats StatsProvider, session Session, types TypeProvider) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public getCumulativeCost(node PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.CostProvider |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public cpuCost(cpuCost double) : PlanCostEstimate in class com.facebook.presto.cost.PlanCostEstimate |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public calculateRemoteReplicateCost(inputSizeInBytes double, destinationTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public calculateJoinInputCost(probe PlanNode, build PlanNode, stats StatsProvider, types TypeProvider, replicated boolean, estimatedSourceDistributedTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitRowNumber(node RowNumberNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitExchange(node ExchangeNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitGroupReference(node GroupReference, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges.ExchangeCostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public add(other PlanCostEstimate) : PlanCostEstimate in class com.facebook.presto.cost.PlanCostEstimate |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitSpatialJoin(node SpatialJoinNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges.ExchangeCostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method private calculateCumulativeCost(node PlanNode, costCalculator CostCalculator, statsCalculator StatsCalculator, types Map<String,Type>) : PlanCostEstimate in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method private calculateCumulativeCost(costCalculator CostCalculator, node PlanNode, costs Function<PlanNode,PlanCostEstimate>, stats Function<PlanNode,PlanNodeStatsEstimate>, types Map<String,Type>) : PlanCostEstimate in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method private calculateJoinCost(join PlanNode, probe PlanNode, build PlanNode, replicated boolean) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public calculateRemoteGatherCost(inputSizeInBytes double) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitUnion(node UnionNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public unknown() : PlanCostEstimate in class com.facebook.presto.cost.PlanCostEstimate |
From |
To |
|
Change Return Type Function<PlanNode,PlanNodeCostEstimate> to Function<PlanNode,PlanCostEstimate> in method private sourceCostProvider(costCalculator CostCalculator, costs Map<String,PlanCostEstimate>, statsProvider Function<PlanNode,PlanNodeStatsEstimate>, types Map<String,Type>) : Function<PlanNode,PlanCostEstimate> in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public calculateCost(node PlanNode, stats StatsProvider, session Session, types TypeProvider) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitLimit(node LimitNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type List<PlanNodeCostEstimate> to List<PlanCostEstimate> in method public getEstimatedCost() : List<PlanCostEstimate> in class com.facebook.presto.sql.planner.planPrinter.NodeRepresentation |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public getCumulativeCost(node PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.TestCostCalculator.TestingCostProvider |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method private getGroupCost(groupReference GroupReference) : PlanCostEstimate in class com.facebook.presto.cost.CachingCostProvider |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public getCumulativeCost(node PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.CachingCostProvider |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public calculateLocalRepartitionCost(inputSizeInBytes double) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method private calculateJoinExchangeCost(probe PlanNode, build PlanNode, stats StatsProvider, types TypeProvider, replicated boolean, estimatedSourceDistributedTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public visitAggregation(node AggregationNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Return Type PlanNodeCostEstimate to PlanCostEstimate in method public getCost() : PlanCostEstimate in class com.facebook.presto.sql.planner.iterative.rule.ReorderJoins.JoinEnumerationResult |
From |
To |
|
Change Variable Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method public testMemoryCostJoinAboveJoin() : void in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type cumulativeCost : PlanNodeCostEstimate to cumulativeCost : PlanCostEstimate in method private getGroupCost(groupReference GroupReference) : PlanCostEstimate in class com.facebook.presto.cost.CachingCostProvider |
From |
To |
|
Change Variable Type cost : PlanNodeCostEstimate to cost : PlanCostEstimate in method private getSemiJoinNodeWithCost(possibleJoinNode SemiJoinNode, context Context) : PlanNodeWithCost in class com.facebook.presto.sql.planner.iterative.rule.DetermineSemiJoinDistributionType |
From |
To |
|
Change Variable Type exchangesCost : PlanNodeCostEstimate to exchangesCost : PlanCostEstimate in method public calculateJoinCostWithoutOutput(probe PlanNode, build PlanNode, stats StatsProvider, types TypeProvider, replicated boolean, estimatedSourceDistributedTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Variable Type remoteRepartitionCost : PlanNodeCostEstimate to remoteRepartitionCost : PlanCostEstimate in method public visitAggregation(node AggregationNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges.ExchangeCostEstimator |
From |
To |
|
Change Variable Type sourcesCost : PlanNodeCostEstimate to sourcesCost : PlanCostEstimate in method private calculateCumulativeCost(node PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.TestCostCalculator.TestingCostProvider |
From |
To |
|
Change Variable Type buildLocalRepartitionCost : PlanNodeCostEstimate to buildLocalRepartitionCost : PlanCostEstimate in method private calculateJoinExchangeCost(probe PlanNode, build PlanNode, stats StatsProvider, types TypeProvider, replicated boolean, estimatedSourceDistributedTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Variable Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method public testReplicatedJoin() : void in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type inputCost : PlanNodeCostEstimate to inputCost : PlanCostEstimate in method public calculateJoinCostWithoutOutput(probe PlanNode, build PlanNode, stats StatsProvider, types TypeProvider, replicated boolean, estimatedSourceDistributedTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Variable Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method public testProject() : void in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type costs : ImmutableMap.Builder<PlanNodeId,PlanNodeCostEstimate> to costs : ImmutableMap.Builder<PlanNodeId,PlanCostEstimate> in method public create(root PlanNode, statsProvider StatsProvider, costProvider CostProvider) : StatsAndCosts in class com.facebook.presto.cost.StatsAndCosts |
From |
To |
|
Change Variable Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method public testUnion() : void in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type joinOutputCost : PlanNodeCostEstimate to joinOutputCost : PlanCostEstimate in method private calculateJoinCost(join PlanNode, probe PlanNode, build PlanNode, replicated boolean) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Variable Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method public testRepartitionedJoin() : void in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type providedCost : PlanNodeCostEstimate to providedCost : PlanCostEstimate in method private sourceCostProvider(costCalculator CostCalculator, costs Map<String,PlanCostEstimate>, statsProvider Function<PlanNode,PlanNodeStatsEstimate>, types Map<String,Type>) : Function<PlanNode,PlanCostEstimate> in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type estimatedCosts : List<PlanNodeCostEstimate> to estimatedCosts : List<PlanCostEstimate> in method public addNode(rootNode PlanNode, name String, identifier String, allNodes List<PlanNodeId>, children List<PlanNode>, remoteSources List<PlanFragmentId>) : NodeRepresentation in class com.facebook.presto.sql.planner.planPrinter.PlanPrinter.Visitor |
From |
To |
|
Change Variable Type replicateCost : PlanNodeCostEstimate to replicateCost : PlanCostEstimate in method private calculateJoinExchangeCost(probe PlanNode, build PlanNode, stats StatsProvider, types TypeProvider, replicated boolean, estimatedSourceDistributedTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Variable Type estimatedExchangeCost : PlanNodeCostEstimate to estimatedExchangeCost : PlanCostEstimate in method public calculateCost(node PlanNode, stats StatsProvider, session Session, types TypeProvider) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Variable Type localRepartitionCost : PlanNodeCostEstimate to localRepartitionCost : PlanCostEstimate in method public visitAggregation(node AggregationNode, context Void) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges.ExchangeCostEstimator |
From |
To |
|
Change Variable Type costs : Map<String,PlanNodeCostEstimate> to costs : Map<String,PlanCostEstimate> in method public testAggregation() : void in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type sourcesCost : PlanNodeCostEstimate to sourcesCost : PlanCostEstimate in method private calculateCumulativeCost(node PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.CachingCostProvider |
From |
To |
|
Change Variable Type yCost : PlanNodeCostEstimate to yCost : PlanCostEstimate in method public testEvictCostOnReplace() : void in class com.facebook.presto.sql.planner.iterative.TestMemo |
From |
To |
|
Change Variable Type that : PlanNodeCostEstimate to that : PlanCostEstimate in method public equals(o Object) : boolean in class com.facebook.presto.cost.PlanCostEstimate |
From |
To |
|
Change Variable Type sourcesCost : PlanNodeCostEstimate to sourcesCost : PlanCostEstimate in method private calculateCumulativeCost(costCalculator CostCalculator, node PlanNode, costs Function<PlanNode,PlanCostEstimate>, stats Function<PlanNode,PlanNodeStatsEstimate>, types Map<String,Type>) : PlanCostEstimate in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type cumulativeCost : PlanNodeCostEstimate to cumulativeCost : PlanCostEstimate in method public getCumulativeCost(node PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.CachingCostProvider |
From |
To |
|
Change Variable Type cost : Optional<PlanNodeCostEstimate> to cost : Optional<PlanCostEstimate> in method private getGroupCost(groupReference GroupReference) : PlanCostEstimate in class com.facebook.presto.cost.CachingCostProvider |
From |
To |
|
Change Variable Type localRepartitionCost : PlanNodeCostEstimate to localRepartitionCost : PlanCostEstimate in method private calculateJoinExchangeCost(probe PlanNode, build PlanNode, stats StatsProvider, types TypeProvider, replicated boolean, estimatedSourceDistributedTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Variable Type cost : PlanNodeCostEstimate to cost : PlanCostEstimate in method private printEstimates(plan PlanRepresentation, node NodeRepresentation) : String in class com.facebook.presto.sql.planner.planPrinter.TextRenderer |
From |
To |
|
Change Variable Type localCost : PlanNodeCostEstimate to localCost : PlanCostEstimate in method private calculateCumulativeCost(costCalculator CostCalculator, node PlanNode, costs Function<PlanNode,PlanCostEstimate>, stats Function<PlanNode,PlanNodeStatsEstimate>, types Map<String,Type>) : PlanCostEstimate in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type costWithExchanges : PlanNodeCostEstimate to costWithExchanges : PlanCostEstimate in method private assertFragmentedEqualsUnfragmented(node PlanNode, stats Map<String,PlanNodeStatsEstimate>, types Map<String,Type>) : void in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type xCost : PlanNodeCostEstimate to xCost : PlanCostEstimate in method public testEvictCostOnReplace() : void in class com.facebook.presto.sql.planner.iterative.TestMemo |
From |
To |
|
Change Variable Type probeCost : PlanNodeCostEstimate to probeCost : PlanCostEstimate in method private calculateJoinExchangeCost(probe PlanNode, build PlanNode, stats StatsProvider, types TypeProvider, replicated boolean, estimatedSourceDistributedTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |
|
Change Variable Type cumulativeCost : PlanNodeCostEstimate to cumulativeCost : PlanCostEstimate in method private calculateCumulativeCost(node PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.CachingCostProvider |
From |
To |
|
Change Variable Type joinInputCost : PlanNodeCostEstimate to joinInputCost : PlanCostEstimate in method private calculateJoinCost(join PlanNode, probe PlanNode, build PlanNode, replicated boolean) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorUsingExchanges.CostEstimator |
From |
To |
|
Change Variable Type localCosts : PlanNodeCostEstimate to localCosts : PlanCostEstimate in method private calculateCumulativeCost(node PlanNode) : PlanCostEstimate in class com.facebook.presto.cost.CachingCostProvider |
From |
To |
|
Change Variable Type filteredCosts : ImmutableMap.Builder<PlanNodeId,PlanNodeCostEstimate> to filteredCosts : ImmutableMap.Builder<PlanNodeId,PlanCostEstimate> in method public getForSubplan(root PlanNode) : StatsAndCosts in class com.facebook.presto.cost.StatsAndCosts |
From |
To |
|
Change Variable Type costWithFragments : PlanNodeCostEstimate to costWithFragments : PlanCostEstimate in method private assertFragmentedEqualsUnfragmented(node PlanNode, stats Map<String,PlanNodeStatsEstimate>, types Map<String,Type>) : void in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type cumulativeCost : PlanNodeCostEstimate to cumulativeCost : PlanCostEstimate in method private assertCost(costCalculator CostCalculator, node PlanNode, costs Map<String,PlanCostEstimate>, stats Map<String,PlanNodeStatsEstimate>, types Map<String,Type>) : CostAssertionBuilder in class com.facebook.presto.cost.TestCostCalculator |
From |
To |
|
Change Variable Type cost : PlanNodeCostEstimate to cost : PlanCostEstimate in method private getJoinNodeWithCost(context Context, possibleJoinNode JoinNode) : PlanNodeWithCost in class com.facebook.presto.sql.planner.iterative.rule.DetermineJoinDistributionType |
From |
To |
|
Change Variable Type buildRemoteRepartitionCost : PlanNodeCostEstimate to buildRemoteRepartitionCost : PlanCostEstimate in method private calculateJoinExchangeCost(probe PlanNode, build PlanNode, stats StatsProvider, types TypeProvider, replicated boolean, estimatedSourceDistributedTaskCount int) : PlanCostEstimate in class com.facebook.presto.cost.CostCalculatorWithEstimatedExchanges |
From |
To |