Package | Description |
---|---|
org.apache.flink.optimizer | |
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(DataStatistics stats,
Configuration config)
Creates a new optimizer instance that uses the statistics object to determine properties about the input.
|
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 | Method and Description |
---|---|
protected void |
DataSourceNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
BulkIterationNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
PartitionNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
FilterNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics)
Computes the estimates for the Filter operator.
|
protected void |
SinkJoiner.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
WorksetIterationNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
WorksetIterationNode.SingleRootJoiner.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
CoGroupNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
SortPartitionNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
MapPartitionNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics)
Computes the estimates for the MapPartition operator.
|
protected void |
NoOpNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
BinaryUnionNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
JoinNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics)
The default estimates build on the principle of inclusion: The smaller input key domain is included in the larger
input key domain.
|
protected void |
MapNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics)
Computes the estimates for the Map operator.
|
protected void |
AbstractPartialSolutionNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
CoGroupRawNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected abstract void |
OptimizerNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
OuterJoinNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
GroupCombineNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
CrossNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics)
We assume that the cardinality is the product of the input cardinalities
and that the result width is the sum of the input widths.
|
protected void |
FlatMapNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics)
Computes the estimates for the FlatMap operator.
|
protected void |
DataSinkNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics)
Computes the estimated outputs for the data sink.
|
protected void |
UnaryOperatorNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
GroupReduceNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
protected void |
ReduceNode.computeOperatorSpecificDefaultEstimates(DataStatistics statistics) |
void |
SinkJoiner.computeOutputEstimates(DataStatistics statistics) |
void |
BinaryUnionNode.computeOutputEstimates(DataStatistics statistics) |
void |
WorksetNode.computeOutputEstimates(DataStatistics statistics) |
void |
SolutionSetNode.computeOutputEstimates(DataStatistics statistics) |
void |
BulkPartialSolutionNode.computeOutputEstimates(DataStatistics statistics) |
void |
OptimizerNode.computeOutputEstimates(DataStatistics statistics)
Causes this node to compute its output estimates (such as number of rows, size in bytes)
based on the inputs and the compiler hints.
|
Constructor and Description |
---|
IdAndEstimatesVisitor(DataStatistics statistics) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.