Package | Description |
---|---|
org.apache.flink.optimizer | |
org.apache.flink.optimizer.costs | |
org.apache.flink.optimizer.dag | |
org.apache.flink.optimizer.dataproperties | |
org.apache.flink.optimizer.operators | |
org.apache.flink.optimizer.plan | |
org.apache.flink.optimizer.plandump | |
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.
|
Class and Description |
---|
DataSinkNode
The Optimizer representation of a data sink.
|
Class and Description |
---|
EstimateProvider
Methods for operators / connections that provide estimated about data size and characteristics.
|
Class and Description |
---|
AbstractPartialSolutionNode
The optimizer's internal representation of the partial solution that is input to a bulk
iteration.
|
BulkIterationNode
A node in the optimizer's program representation for a bulk iteration.
|
BulkPartialSolutionNode
The optimizer's internal representation of the partial solution that is input to a bulk
iteration.
|
DagConnection
A connection between two operators.
|
EstimateProvider
Methods for operators / connections that provide estimated about data size and characteristics.
|
GroupReduceNode
The optimizer representation of a GroupReduce operation.
|
IterationNode |
OptimizerNode
The OptimizerNode is the base class of all nodes in the optimizer DAG.
|
OptimizerNode.UnclosedBranchDescriptor
Description of an unclosed branch.
|
ReduceNode
The Optimizer representation of a Reduce operator.
|
SingleInputNode
A node in the optimizer's program representation for an operation with a single input.
|
SolutionSetNode
The optimizer's internal representation of the solution set of a workset iteration.
|
TempMode
Enumeration to indicate the mode of temporarily materializing the data that flows across a
connection.
|
TwoInputNode
A node in the optimizer plan that represents an operator with a two different inputs, such as
Join, Cross, CoGroup, or Union.
|
UnaryOperatorNode |
WorksetIterationNode
A node in the optimizer's program representation for a workset iteration.
|
WorksetNode
The optimizer's internal representation of the partial solution that is input to a bulk
iteration.
|
Class and Description |
---|
OptimizerNode
The OptimizerNode is the base class of all nodes in the optimizer DAG.
|
Class and Description |
---|
SingleInputNode
A node in the optimizer's program representation for an operation with a single input.
|
TwoInputNode
A node in the optimizer plan that represents an operator with a two different inputs, such as
Join, Cross, CoGroup, or Union.
|
Class and Description |
---|
BinaryUnionNode
The Optimizer representation of a binary Union.
|
BulkIterationNode
A node in the optimizer's program representation for a bulk iteration.
|
BulkPartialSolutionNode
The optimizer's internal representation of the partial solution that is input to a bulk
iteration.
|
DataSinkNode
The Optimizer representation of a data sink.
|
DataSourceNode
The optimizer's internal representation of a data source.
|
EstimateProvider
Methods for operators / connections that provide estimated about data size and characteristics.
|
IterationNode |
OptimizerNode
The OptimizerNode is the base class of all nodes in the optimizer DAG.
|
SingleInputNode
A node in the optimizer's program representation for an operation with a single input.
|
SinkJoiner
This class represents a utility node that is not part of the actual plan.
|
SolutionSetNode
The optimizer's internal representation of the solution set of a workset iteration.
|
TempMode
Enumeration to indicate the mode of temporarily materializing the data that flows across a
connection.
|
TwoInputNode
A node in the optimizer plan that represents an operator with a two different inputs, such as
Join, Cross, CoGroup, or Union.
|
WorksetIterationNode
A node in the optimizer's program representation for a workset iteration.
|
WorksetNode
The optimizer's internal representation of the partial solution that is input to a bulk
iteration.
|
Class and Description |
---|
DataSinkNode
The Optimizer representation of a data sink.
|
OptimizerNode
The OptimizerNode is the base class of all nodes in the optimizer DAG.
|
Class and Description |
---|
DataSinkNode
The Optimizer representation of a data sink.
|
OptimizerNode
The OptimizerNode is the base class of all nodes in the optimizer DAG.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.