Modifier and Type | Class and Description |
---|---|
class |
ExecNodeBase<T>
Base class for
ExecNode . |
Modifier and Type | Method and Description |
---|---|
static <T extends ExecNode<?>> |
ExecNodeContext.newContext(Class<T> execNodeClass) |
static <T extends ExecNode<?>> |
ExecNodeContext.newPersistedConfig(Class<T> execNodeClass,
ReadableConfig tableConfig)
Create a configuration for the
ExecNode , ready to be persisted to a JSON plan. |
Modifier and Type | Method and Description |
---|---|
ExecNode<?> |
ExecEdge.getSource() |
ExecNode<?> |
ExecEdge.getTarget() |
Modifier and Type | Method and Description |
---|---|
List<ExecNode<?>> |
ExecNodeGraph.getRootNodes() |
Modifier and Type | Method and Description |
---|---|
ExecEdge.Builder |
ExecEdge.Builder.source(ExecNode<?> source) |
ExecEdge.Builder |
ExecEdge.Builder.target(ExecNode<?> target) |
protected void |
ExecNodeGraphValidator.visitNode(ExecNode<?> node) |
Constructor and Description |
---|
ExecEdge(ExecNode<?> source,
ExecNode<?> target,
ExecEdge.Shuffle shuffle,
StreamExchangeMode exchangeMode) |
ExecEdge(ExecNode<?> source,
ExecNode<?> target,
ExecEdge.Shuffle shuffle,
StreamExchangeMode exchangeMode) |
Constructor and Description |
---|
ExecNodeGraph(FlinkVersion flinkVersion,
List<ExecNode<?>> rootNodes) |
ExecNodeGraph(List<ExecNode<?>> rootNodes) |
Modifier and Type | Interface and Description |
---|---|
interface |
BatchExecNode<T>
Base class for batch
ExecNode . |
interface |
InputSortedExecNode<T>
A
BatchExecNode which does not sort the input data within the operator, but requires the
input data is already sorted. |
Modifier and Type | Class and Description |
---|---|
class |
BatchExecBoundedStreamScan
Batch
ExecNode to connect a given bounded DataStream and consume data from it. |
class |
BatchExecCalc
Batch
ExecNode for Calc. |
class |
BatchExecCorrelate
Batch exec node which matches along with join a Java/Scala user defined table function.
|
class |
BatchExecExchange
This
ExecNode represents a change of partitioning of the input elements for batch. |
class |
BatchExecExpand
Batch
ExecNode that can expand one row to multiple rows based on given projects. |
class |
BatchExecHashAggregate
Batch
ExecNode for hash-based aggregate operator. |
class |
BatchExecHashJoin
BatchExecNode for Hash Join. |
class |
BatchExecHashWindowAggregate
Batch
ExecNode for hash-based window aggregate operator. |
class |
BatchExecLegacySink<T>
|
class |
BatchExecLegacyTableSourceScan
Batch
ExecNode to read data from an external source defined by a bounded StreamTableSource . |
class |
BatchExecLimit
Batch
ExecNode for Limit. |
class |
BatchExecLookupJoin
BatchExecNode for temporal table join that implemented by lookup. |
class |
BatchExecMultipleInput
|
class |
BatchExecNestedLoopJoin
BatchExecNode for Nested-loop Join. |
class |
BatchExecOverAggregate
Batch
ExecNode for sort-based over window aggregate. |
class |
BatchExecOverAggregateBase
Batch
ExecNode base class for sort-based over window aggregate. |
class |
BatchExecPythonCalc
Batch
ExecNode for Python ScalarFunctions. |
class |
BatchExecPythonCorrelate
Batch exec node which matches along with join a Python user defined table function.
|
class |
BatchExecPythonGroupAggregate
Batch
ExecNode for Python unbounded group aggregate. |
class |
BatchExecPythonGroupWindowAggregate
Batch
ExecNode for group widow aggregate (Python user defined aggregate function). |
class |
BatchExecPythonOverAggregate
Batch
ExecNode for sort-based over window aggregate (Python user defined aggregate
function). |
class |
BatchExecRank
BatchExecNode for Rank. |
class |
BatchExecSink
Batch
ExecNode to to write data into an external sink defined by a DynamicTableSink . |
class |
BatchExecSort
BatchExecNode for Sort without limit. |
class |
BatchExecSortAggregate
Batch
ExecNode for (global) sort-based aggregate operator. |
class |
BatchExecSortLimit
BatchExecNode for Sort with limit. |
class |
BatchExecSortMergeJoin
BatchExecNode for Sort Merge Join. |
class |
BatchExecSortWindowAggregate
Batch
ExecNode for sort-based window aggregate operator. |
class |
BatchExecTableSourceScan
Batch
ExecNode to read data from an external source defined by a bounded ScanTableSource . |
class |
BatchExecUnion
Batch
ExecNode that is not a physical node and just union the inputs' records into one
node. |
class |
BatchExecValues
Batch
ExecNode that read records from given values. |
class |
BatchExecWindowTableFunction
Batch
ExecNode for window table-valued function. |
Constructor and Description |
---|
BatchExecMultipleInput(ReadableConfig tableConfig,
List<InputProperty> inputProperties,
ExecNode<?> rootNode,
List<ExecEdge> originalEdges,
String description) |
Modifier and Type | Class and Description |
---|---|
class |
CommonExecCalc
Base class for exec Calc.
|
class |
CommonExecCorrelate
Base
ExecNode which matches along with join a Java/Scala user defined table function. |
class |
CommonExecExchange
Base class for exec Exchange.
|
class |
CommonExecExpand
Base
ExecNode that can expand one row to multiple rows based on given projects. |
class |
CommonExecLegacySink<T>
|
class |
CommonExecLegacyTableSourceScan
Base
ExecNode to read data from an external source defined by a StreamTableSource . |
class |
CommonExecLookupJoin
Base
ExecNode for temporal table join which shares most methods. |
class |
CommonExecPythonCalc
Base class for exec Python Calc.
|
class |
CommonExecPythonCorrelate
Base
ExecNode which matches along with join a Python user defined table function. |
class |
CommonExecSink
Base
ExecNode to write data to an external sink defined by a DynamicTableSink . |
class |
CommonExecTableSourceScan
Base
ExecNode to read data from an external source defined by a ScanTableSource . |
class |
CommonExecUnion
Base
ExecNode that is not a physical node and just union the inputs' records into one
node. |
class |
CommonExecValues
Base
ExecNode that read records from given values. |
class |
CommonExecWindowTableFunction
Base
ExecNode for window table-valued function. |
Modifier and Type | Method and Description |
---|---|
Map<ExecNode<?>,Integer> |
InputOrderCalculator.calculate() |
Modifier and Type | Method and Description |
---|---|
protected void |
InputPriorityConflictResolver.resolveInputPriorityConflict(ExecNode<?> node,
int higherInput,
int lowerInput) |
protected abstract void |
InputPriorityGraphGenerator.resolveInputPriorityConflict(ExecNode<?> node,
int higherInput,
int lowerInput) |
protected void |
InputOrderCalculator.resolveInputPriorityConflict(ExecNode<?> node,
int higherInput,
int lowerInput) |
Constructor and Description |
---|
InputOrderCalculator(ExecNode<?> root,
Set<ExecNode<?>> boundaries,
InputProperty.DamBehavior safeDamBehavior)
Create a
InputOrderCalculator for the given ExecNode sub-graph. |
Constructor and Description |
---|
InputOrderCalculator(ExecNode<?> root,
Set<ExecNode<?>> boundaries,
InputProperty.DamBehavior safeDamBehavior)
Create a
InputOrderCalculator for the given ExecNode sub-graph. |
InputPriorityConflictResolver(List<ExecNode<?>> roots,
InputProperty.DamBehavior safeDamBehavior,
StreamExchangeMode exchangeMode,
ReadableConfig tableConfig)
Create a
InputPriorityConflictResolver for the given ExecNode graph. |
InputPriorityGraphGenerator(List<ExecNode<?>> roots,
Set<ExecNode<?>> boundaries,
InputProperty.DamBehavior safeDamBehavior)
Create an
InputPriorityGraphGenerator for the given ExecNode sub-graph. |
InputPriorityGraphGenerator(List<ExecNode<?>> roots,
Set<ExecNode<?>> boundaries,
InputProperty.DamBehavior safeDamBehavior)
Create an
InputPriorityGraphGenerator for the given ExecNode sub-graph. |
Modifier and Type | Interface and Description |
---|---|
interface |
StreamExecNode<T>
Base class for stream
ExecNode . |
Modifier and Type | Class and Description |
---|---|
class |
StreamExecAggregateBase
The base class for aggregate
ExecNode . |
class |
StreamExecCalc
Stream
ExecNode for Calc. |
class |
StreamExecChangelogNormalize
Stream
ExecNode which normalizes a changelog stream which maybe an upsert stream or a
changelog stream containing duplicate events. |
class |
StreamExecCorrelate
Stream
ExecNode which matches along with join a Java/Scala user defined table function. |
class |
StreamExecDataStreamScan
Stream
ExecNode to connect a given DataStream and consume data from it. |
class |
StreamExecDeduplicate
Stream
ExecNode which deduplicate on keys and keeps only first row or last row. |
class |
StreamExecDropUpdateBefore
Stream
ExecNode which will drop the UPDATE_BEFORE messages. |
class |
StreamExecExchange
This
ExecNode represents a change of partitioning of the input elements for stream. |
class |
StreamExecExpand
Stream
ExecNode that can expand one row to multiple rows based on given projects. |
class |
StreamExecGlobalGroupAggregate
Stream
ExecNode for unbounded global group aggregate. |
class |
StreamExecGlobalWindowAggregate
Stream
ExecNode for window table-valued based global aggregate. |
class |
StreamExecGroupAggregate
Stream
ExecNode for unbounded group aggregate. |
class |
StreamExecGroupTableAggregate
Stream
ExecNode for unbounded java/scala group table aggregate. |
class |
StreamExecGroupWindowAggregate
Stream
ExecNode for either group window aggregate or group window table aggregate. |
class |
StreamExecIncrementalGroupAggregate
Stream
ExecNode for unbounded incremental group aggregate. |
class |
StreamExecIntervalJoin
StreamExecNode for a time interval stream join. |
class |
StreamExecJoin
StreamExecNode for regular Joins. |
class |
StreamExecLegacySink<T>
|
class |
StreamExecLegacyTableSourceScan
Stream
ExecNode to read data from an external source defined by a StreamTableSource . |
class |
StreamExecLimit
Stream
ExecNode for Limit. |
class |
StreamExecLocalGroupAggregate
Stream
ExecNode for unbounded local group aggregate. |
class |
StreamExecLocalWindowAggregate
Stream
ExecNode for window table-valued based local aggregate. |
class |
StreamExecLookupJoin
StreamExecNode for temporal table join that implemented by lookup. |
class |
StreamExecMatch
Stream
ExecNode which matches along with MATCH_RECOGNIZE. |
class |
StreamExecMiniBatchAssigner
Stream
ExecNode which injects a mini-batch event in the streaming data. |
class |
StreamExecMultipleInput
|
class |
StreamExecOverAggregate
Stream
ExecNode for time-based over operator. |
class |
StreamExecPythonCalc
Stream
ExecNode for Python ScalarFunctions. |
class |
StreamExecPythonCorrelate
Stream exec node which matches along with join a Python user defined table function.
|
class |
StreamExecPythonGroupAggregate
Stream
ExecNode for Python unbounded group aggregate. |
class |
StreamExecPythonGroupTableAggregate
Stream
ExecNode for unbounded python group table aggregate. |
class |
StreamExecPythonGroupWindowAggregate
Stream
ExecNode for group widow aggregate (Python user defined aggregate function). |
class |
StreamExecPythonOverAggregate
Stream
ExecNode for python time-based over operator. |
class |
StreamExecRank
Stream
ExecNode for Rank. |
class |
StreamExecSink
Stream
ExecNode to to write data into an external sink defined by a DynamicTableSink . |
class |
StreamExecSort
StreamExecNode for Sort. |
class |
StreamExecSortLimit
StreamExecNode for Sort with limit. |
class |
StreamExecTableSourceScan
Stream
ExecNode to read data from an external source defined by a ScanTableSource . |
class |
StreamExecTemporalJoin
StreamExecNode for temporal table join (FOR SYSTEM_TIME AS OF) and temporal TableFunction
join (LATERAL TemporalTableFunction(o.proctime)). |
class |
StreamExecTemporalSort
StreamExecNode for time-ascending-order Sort without `limit`. |
class |
StreamExecUnion
Stream
ExecNode that is not a physical node and just union the inputs' records into one
node. |
class |
StreamExecValues
Stream
ExecNode that read records from given values. |
class |
StreamExecWatermarkAssigner
Stream
ExecNode which generates watermark based on the input elements. |
class |
StreamExecWindowAggregate
Stream
ExecNode for window table-valued based aggregate. |
class |
StreamExecWindowAggregateBase
The base class for window aggregate
ExecNode . |
class |
StreamExecWindowDeduplicate
Stream
ExecNode for Window Deduplicate. |
class |
StreamExecWindowJoin
StreamExecNode for WindowJoin. |
class |
StreamExecWindowRank
Stream
ExecNode for WindowRank. |
class |
StreamExecWindowTableFunction
Stream
ExecNode which acts as a table-valued function to assign a window for each row of
the input relation. |
Constructor and Description |
---|
StreamExecMultipleInput(ReadableConfig tableConfig,
List<InputProperty> inputProperties,
ExecNode<?> rootNode,
String description) |
Modifier and Type | Method and Description |
---|---|
static String |
ExecNodeUtil.getMultipleInputDescription(ExecNode<?> rootNode,
List<ExecNode<?>> inputNodes,
List<InputProperty> inputProperties)
Return description for multiple input node.
|
static String |
ExecNodePlanDumper.treeToString(ExecNode<?> node)
Converts an
ExecNode tree to a string as a tree style. |
static String |
ExecNodePlanDumper.treeToString(ExecNode<?> node,
List<ExecNode<?>> borders,
boolean includingBorders)
Converts an
ExecNode tree to a string as a tree style. |
Modifier and Type | Method and Description |
---|---|
static String |
ExecNodePlanDumper.dagToString(List<ExecNode<?>> nodes)
Converts an
ExecNode DAG to a string as a tree style. |
static String |
ExecNodeUtil.getMultipleInputDescription(ExecNode<?> rootNode,
List<ExecNode<?>> inputNodes,
List<InputProperty> inputProperties)
Return description for multiple input node.
|
static String |
ExecNodePlanDumper.treeToString(ExecNode<?> node,
List<ExecNode<?>> borders,
boolean includingBorders)
Converts an
ExecNode tree to a string as a tree style. |
Modifier and Type | Method and Description |
---|---|
void |
ExecNodeVisitor.visit(ExecNode<?> node)
Visits a node during a traversal.
|
void |
ExecNodeVisitorImpl.visit(ExecNode<?> node) |
void |
AbstractExecNodeExactlyOnceVisitor.visit(ExecNode<?> node) |
protected void |
ExecNodeVisitorImpl.visitInputs(ExecNode<?> node) |
protected void |
AbstractExecNodeExactlyOnceVisitor.visitInputs(ExecNode<?> node) |
protected abstract void |
AbstractExecNodeExactlyOnceVisitor.visitNode(ExecNode<?> node) |
Modifier and Type | Method and Description |
---|---|
static <T extends ExecNode<?>> |
ExecNodeMetadataUtil.consumedOptions(Class<T> execNodeClass) |
static <T extends ExecNode<?>> |
ExecNodeMetadataUtil.isUnsupported(Class<T> execNode) |
static <T extends ExecNode<?>> |
ExecNodeMetadataUtil.latestAnnotation(Class<T> execNodeClass)
Returns the
ExecNodeMetadata annotation of the class with the highest (most recent)
ExecNodeMetadata.version() . |
static <T extends ExecNode<?>> |
ExecNodeMetadataUtil.newPersistedConfig(Class<T> execNodeClass,
ReadableConfig tableConfig,
java.util.stream.Stream<ConfigOption<?>> configOptions) |
Modifier and Type | Method and Description |
---|---|
static Set<Class<? extends ExecNode<?>>> |
ExecNodeMetadataUtil.execNodes() |
static Class<? extends ExecNode<?>> |
ExecNodeMetadataUtil.retrieveExecNode(String name,
int version) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.