Package | Description |
---|---|
org.apache.flink.optimizer | |
org.apache.flink.optimizer.costs | |
org.apache.flink.optimizer.dag | |
org.apache.flink.optimizer.traversals |
This package contains the various traversals over the program plan and the optimizer DAG
(directed acyclic graph) that are made in the course of the optimization.
|
Constructor and Description |
---|
Optimizer(CostEstimator estimator,
Configuration config)
Creates a new optimizer instance.
|
Optimizer(DataStatistics stats,
CostEstimator estimator,
Configuration config)
Creates a new optimizer instance that uses the statistics object to determine properties
about the input.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultCostEstimator
A default cost estimator that has access to basic size and cardinality estimates.
|
Modifier and Type | Method and Description |
---|---|
protected void |
TwoInputNode.addLocalCandidates(Channel template1,
Channel template2,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
RequestedGlobalProperties rgps1,
RequestedGlobalProperties rgps2,
List<PlanNode> target,
OperatorDescriptorDual.LocalPropertiesPair[] validLocalCombinations,
CostEstimator estimator) |
protected void |
SingleInputNode.addLocalCandidates(Channel template,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
RequestedGlobalProperties rgps,
List<PlanNode> target,
CostEstimator estimator) |
void |
DataSourceNode.computeInterestingPropertiesForInputs(CostEstimator estimator) |
void |
AbstractPartialSolutionNode.computeInterestingPropertiesForInputs(CostEstimator estimator) |
void |
WorksetIterationNode.computeInterestingPropertiesForInputs(CostEstimator estimator) |
abstract void |
OptimizerNode.computeInterestingPropertiesForInputs(CostEstimator estimator)
Tells the node to compute the interesting properties for its inputs.
|
void |
TwoInputNode.computeInterestingPropertiesForInputs(CostEstimator estimator) |
void |
DataSinkNode.computeInterestingPropertiesForInputs(CostEstimator estimator) |
void |
BinaryUnionNode.computeInterestingPropertiesForInputs(CostEstimator estimator) |
void |
SingleInputNode.computeInterestingPropertiesForInputs(CostEstimator estimator) |
void |
BulkIterationNode.computeInterestingPropertiesForInputs(CostEstimator estimator) |
List<PlanNode> |
DataSourceNode.getAlternativePlans(CostEstimator estimator) |
List<PlanNode> |
AbstractPartialSolutionNode.getAlternativePlans(CostEstimator estimator) |
abstract List<PlanNode> |
OptimizerNode.getAlternativePlans(CostEstimator estimator)
Computes the plan alternatives for this node, an implicitly for all nodes that are children
of this node.
|
List<PlanNode> |
TwoInputNode.getAlternativePlans(CostEstimator estimator) |
List<PlanNode> |
DataSinkNode.getAlternativePlans(CostEstimator estimator) |
List<PlanNode> |
BinaryUnionNode.getAlternativePlans(CostEstimator estimator) |
List<PlanNode> |
SingleInputNode.getAlternativePlans(CostEstimator estimator) |
protected void |
WorksetIterationNode.instantiate(OperatorDescriptorDual operator,
Channel solutionSetIn,
Channel worksetIn,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
List<PlanNode> target,
CostEstimator estimator,
RequestedGlobalProperties globPropsReqSolutionSet,
RequestedGlobalProperties globPropsReqWorkset,
RequestedLocalProperties locPropsReqSolutionSet,
RequestedLocalProperties locPropsReqWorkset) |
protected void |
TwoInputNode.instantiate(OperatorDescriptorDual operator,
Channel in1,
Channel in2,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
List<PlanNode> target,
CostEstimator estimator,
RequestedGlobalProperties globPropsReq1,
RequestedGlobalProperties globPropsReq2,
RequestedLocalProperties locPropsReq1,
RequestedLocalProperties locPropsReq2) |
protected void |
SingleInputNode.instantiateCandidate(OperatorDescriptorSingle dps,
Channel in,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
List<PlanNode> target,
CostEstimator estimator,
RequestedGlobalProperties globPropsReq,
RequestedLocalProperties locPropsReq) |
protected void |
BulkIterationNode.instantiateCandidate(OperatorDescriptorSingle dps,
Channel in,
List<Set<? extends NamedChannel>> broadcastPlanChannels,
List<PlanNode> target,
CostEstimator estimator,
RequestedGlobalProperties globPropsReq,
RequestedLocalProperties locPropsReq) |
Constructor and Description |
---|
InterestingPropertyVisitor(CostEstimator estimator)
Creates a new visitor that computes the interesting properties for all nodes in the plan.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.