Package | Description |
---|---|
org.apache.flink.optimizer.costs | |
org.apache.flink.optimizer.dag | |
org.apache.flink.optimizer.plan |
Modifier and Type | Method and Description |
---|---|
void |
DefaultCostEstimator.addArtificialDamCost(EstimateProvider estimates,
long bufferSize,
Costs costs) |
abstract void |
CostEstimator.addArtificialDamCost(EstimateProvider estimates,
long bufferSize,
Costs costs) |
void |
DefaultCostEstimator.addBlockNestedLoopsCosts(EstimateProvider outerSide,
EstimateProvider innerSide,
long blockSize,
Costs costs,
int costWeight) |
abstract void |
CostEstimator.addBlockNestedLoopsCosts(EstimateProvider outerSide,
EstimateProvider innerSide,
long blockSize,
Costs costs,
int costWeight) |
void |
DefaultCostEstimator.addBroadcastCost(EstimateProvider estimates,
int replicationFactor,
Costs costs) |
abstract void |
CostEstimator.addBroadcastCost(EstimateProvider estimates,
int replicationFactor,
Costs costs) |
void |
DefaultCostEstimator.addCachedHybridHashCosts(EstimateProvider buildSideInput,
EstimateProvider probeSideInput,
Costs costs,
int costWeight)
Calculates the costs for the cached variant of the hybrid hash join.
|
abstract void |
CostEstimator.addCachedHybridHashCosts(EstimateProvider buildSide,
EstimateProvider probeSide,
Costs costs,
int costWeight) |
void |
DefaultCostEstimator.addHashPartitioningCost(EstimateProvider estimates,
Costs costs) |
abstract void |
CostEstimator.addHashPartitioningCost(EstimateProvider estimates,
Costs costs) |
void |
DefaultCostEstimator.addHybridHashCosts(EstimateProvider buildSideInput,
EstimateProvider probeSideInput,
Costs costs,
int costWeight) |
abstract void |
CostEstimator.addHybridHashCosts(EstimateProvider buildSide,
EstimateProvider probeSide,
Costs costs,
int costWeight) |
void |
DefaultCostEstimator.addLocalMergeCost(EstimateProvider input1,
EstimateProvider input2,
Costs costs,
int costWeight) |
abstract void |
CostEstimator.addLocalMergeCost(EstimateProvider estimates1,
EstimateProvider estimates2,
Costs costs,
int costWeight) |
void |
DefaultCostEstimator.addLocalSortCost(EstimateProvider estimates,
Costs costs) |
abstract void |
CostEstimator.addLocalSortCost(EstimateProvider estimates,
Costs costs) |
void |
DefaultCostEstimator.addRandomPartitioningCost(EstimateProvider estimates,
Costs costs) |
abstract void |
CostEstimator.addRandomPartitioningCost(EstimateProvider estimates,
Costs costs) |
void |
DefaultCostEstimator.addRangePartitionCost(EstimateProvider estimates,
Costs costs) |
abstract void |
CostEstimator.addRangePartitionCost(EstimateProvider estimates,
Costs costs) |
void |
DefaultCostEstimator.addStreamedNestedLoopsCosts(EstimateProvider outerSide,
EstimateProvider innerSide,
long bufferSize,
Costs costs,
int costWeight) |
abstract void |
CostEstimator.addStreamedNestedLoopsCosts(EstimateProvider outerSide,
EstimateProvider innerSide,
long bufferSize,
Costs costs,
int costWeight) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractPartialSolutionNode
The optimizer's internal representation of the partial solution that is input to a bulk
iteration.
|
class |
BinaryUnionNode
The Optimizer representation of a binary Union.
|
class |
BulkIterationNode
A node in the optimizer's program representation for a bulk iteration.
|
class |
BulkPartialSolutionNode
The optimizer's internal representation of the partial solution that is input to a bulk
iteration.
|
class |
CoGroupNode
The Optimizer representation of a CoGroup operator.
|
class |
CoGroupRawNode
The Optimizer representation of a CoGroupRaw operator.
|
class |
CrossNode
The Optimizer representation of a Cross (Cartesian product) operator.
|
class |
DagConnection
A connection between two operators.
|
class |
DataSinkNode
The Optimizer representation of a data sink.
|
class |
DataSourceNode
The optimizer's internal representation of a data source.
|
class |
FilterNode
The optimizer's internal representation of a Filter operator node.
|
class |
FlatMapNode
The optimizer's internal representation of a FlatMap operator node.
|
class |
GroupCombineNode
The optimizer representation of a GroupCombineNode operation.
|
class |
GroupReduceNode
The optimizer representation of a GroupReduce operation.
|
class |
JoinNode
The Optimizer representation of a join operator.
|
class |
MapNode
The optimizer's internal representation of a Map operator node.
|
class |
MapPartitionNode
The optimizer's internal representation of a MapPartition operator node.
|
class |
NoOpNode
The optimizer's internal representation of a No Operation node.
|
class |
OptimizerNode
The OptimizerNode is the base class of all nodes in the optimizer DAG.
|
class |
OuterJoinNode |
class |
PartitionNode
The optimizer's internal representation of a Partition operator node.
|
class |
ReduceNode
The Optimizer representation of a Reduce operator.
|
class |
SingleInputNode
A node in the optimizer's program representation for an operation with a single input.
|
class |
SinkJoiner
This class represents a utility node that is not part of the actual plan.
|
class |
SolutionSetNode
The optimizer's internal representation of the solution set of a workset iteration.
|
class |
SortPartitionNode
The optimizer's internal representation of a SortPartition operator node.
|
class |
TwoInputNode
A node in the optimizer plan that represents an operator with a two different inputs, such as
Join, Cross, CoGroup, or Union.
|
class |
UnaryOperatorNode |
class |
WorksetIterationNode
A node in the optimizer's program representation for a workset iteration.
|
static class |
WorksetIterationNode.SingleRootJoiner |
class |
WorksetNode
The optimizer's internal representation of the partial solution that is input to a bulk
iteration.
|
Modifier and Type | Class and Description |
---|---|
class |
Channel
A Channel represents the result produced by an operator and the data exchange before the
consumption by the target operator.
|
class |
NamedChannel |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.