Modifier and Type | Class and Description |
---|---|
class |
Plan
This class represents Flink programs, in the form of dataflow plans.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractUdfOperator<OUT,FT extends Function>
Abstract superclass for all contracts that represent actual operators.
|
class |
DualInputOperator<IN1,IN2,OUT,FT extends Function>
Abstract operator superclass for all operators that have two inputs, like "Join", "CoGroup", or
"Cross".
|
class |
GenericDataSinkBase<IN>
Operator for nodes that act as data sinks, storing the data they receive.
|
class |
GenericDataSourceBase<OUT,T extends InputFormat<OUT,?>>
Abstract superclass for data sources in a Pact plan.
|
class |
Operator<OUT>
Abstract base class for all operators.
|
class |
SingleInputOperator<IN,OUT,FT extends Function>
Abstract superclass for all operators that have one input like "map" or "reduce".
|
class |
Union<T>
This operator represents a Union between two inputs.
|
Modifier and Type | Class and Description |
---|---|
class |
BulkIterationBase<T> |
static class |
BulkIterationBase.PartialSolutionPlaceHolder<OT>
Specialized operator to use as a recognizable place-holder for the input to the step function
when composing the nested data flow.
|
class |
CoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> |
class |
CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> |
class |
CrossOperatorBase<IN1,IN2,OUT,FT extends CrossFunction<IN1,IN2,OUT>> |
class |
DeltaIterationBase<ST,WT>
A DeltaIteration is similar to a
BulkIterationBase , but maintains state across the
individual iteration steps. |
static class |
DeltaIterationBase.SolutionSetPlaceHolder<ST>
Specialized operator to use as a recognizable place-holder for the solution set input to the
step function.
|
static class |
DeltaIterationBase.WorksetPlaceHolder<WT>
Specialized operator to use as a recognizable place-holder for the working set input to the
step function.
|
class |
FilterOperatorBase<T,FT extends FlatMapFunction<T,T>> |
class |
FlatMapOperatorBase<IN,OUT,FT extends FlatMapFunction<IN,OUT>> |
class |
GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>>
Base operator for the combineGroup transformation.
|
class |
GroupReduceOperatorBase<IN,OUT,FT extends GroupReduceFunction<IN,OUT>> |
class |
InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
class |
JoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
class |
MapOperatorBase<IN,OUT,FT extends MapFunction<IN,OUT>> |
class |
MapPartitionOperatorBase<IN,OUT,FT extends MapPartitionFunction<IN,OUT>> |
class |
OuterJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> |
class |
PartitionOperatorBase<IN> |
class |
ReduceOperatorBase<T,FT extends ReduceFunction<T>>
Base data flow operator for Reduce user-defined functions.
|
class |
SortPartitionOperatorBase<IN> |
Modifier and Type | Class and Description |
---|---|
class |
PlanBothUnwrappingCoGroupOperator<I1,I2,OUT,K>
A co group operator that applies the operation only on the unwrapped values.
|
class |
PlanFilterOperator<T> |
class |
PlanLeftUnwrappingCoGroupOperator<I1,I2,OUT,K>
A co group operator that applies the operation only on the unwrapped values on the left.
|
class |
PlanProjectOperator<T,R extends Tuple>
A map operator that retains a subset of fields from incoming tuples.
|
class |
PlanRightUnwrappingCoGroupOperator<I1,I2,OUT,K>
A co group operator that applies the operation only on the unwrapped values on the right.
|
class |
PlanUnwrappingGroupCombineOperator<IN,OUT,K>
A group combine operator that takes 2-tuples (key-value pairs), and applies the group combine
operation only on the unwrapped values.
|
class |
PlanUnwrappingReduceGroupOperator<IN,OUT,K>
A reduce operator that takes 2-tuples (key-value pairs), and applies the group reduce operation
only on the unwrapped values.
|
class |
PlanUnwrappingReduceOperator<T,K>
A reduce operator that takes 2-tuples (key-value pairs), and applies the reduce operation only on
the unwrapped values.
|
class |
PlanUnwrappingSortedGroupCombineOperator<IN,OUT,K1,K2>
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted partial
group reduce operation only on the unwrapped values.
|
class |
PlanUnwrappingSortedReduceGroupOperator<IN,OUT,K1,K2>
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted group
reduce operation only on the unwrapped values.
|
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 |
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 |
BinaryUnionPlanNode
A special subclass for the union to make it identifiable.
|
class |
BulkIterationPlanNode |
class |
BulkPartialSolutionPlanNode
Plan candidate node for partial solution of a bulk iteration.
|
class |
DualInputPlanNode |
class |
NAryUnionPlanNode
A union operation over multiple inputs (2 or more).
|
class |
OptimizedPlan
The execution plan generated by the Optimizer.
|
class |
PlanNode
The representation of a data exchange between two operators.
|
class |
SingleInputPlanNode |
class |
SinkJoinerPlanNode |
class |
SinkPlanNode
Plan candidate node for data flow sinks.
|
class |
SolutionSetPlanNode
Plan candidate node for partial solution of a bulk iteration.
|
class |
SourcePlanNode
Plan candidate node for data flow sources that have no input and no special strategies.
|
class |
WorksetIterationPlanNode
A node in the execution, representing a workset iteration (delta iteration).
|
class |
WorksetPlanNode
Plan candidate node for partial solution of a bulk iteration.
|
Modifier and Type | Class and Description |
---|---|
class |
NoOpBinaryUdfOp<OUT> |
class |
NoOpUnaryUdfOp<OUT> |
Modifier and Type | Interface and Description |
---|---|
interface |
Visitable<T extends Visitable<T>>
This interface marks types as visitable during a traversal.
|
interface |
Visitor<T extends Visitable<T>>
A visitor encapsulates functionality that is applied to each node in the process of a traversal
of a tree or DAG.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.