Package | Description |
---|---|
org.apache.flink.table.planner.plan.nodes.exec.batch | |
org.apache.flink.table.planner.plan.nodes.exec.stream |
Class and Description |
---|
CommonExecCalc
Base class for exec Calc.
|
CommonExecCorrelate
Base
ExecNode which matches along with join a Java/Scala user defined table function. |
CommonExecExchange
Base class for exec Exchange.
|
CommonExecExpand
Base
ExecNode that can expand one row to multiple rows based on given projects. |
CommonExecLegacySink |
CommonExecLegacyTableSourceScan
Base
ExecNode to read data from an external source defined by a StreamTableSource . |
CommonExecLookupJoin
Base
ExecNode for temporal table join which shares most methods. |
CommonExecPythonCalc
Base class for exec Python Calc.
|
CommonExecPythonCorrelate
Base
ExecNode which matches along with join a Python user defined table function. |
CommonExecSink
Base
ExecNode to write data to an external sink defined by a DynamicTableSink . |
CommonExecTableSourceScan
Base
ExecNode to read data from an external source defined by a ScanTableSource . |
CommonExecUnion
Base
ExecNode that is not a physical node and just union the inputs' records into one
node. |
CommonExecValues
Base
ExecNode that read records from given values. |
Class and Description |
---|
CommonExecCalc
Base class for exec Calc.
|
CommonExecCorrelate
Base
ExecNode which matches along with join a Java/Scala user defined table function. |
CommonExecExchange
Base class for exec Exchange.
|
CommonExecExpand
Base
ExecNode that can expand one row to multiple rows based on given projects. |
CommonExecLegacySink |
CommonExecLegacyTableSourceScan
Base
ExecNode to read data from an external source defined by a StreamTableSource . |
CommonExecLookupJoin
Base
ExecNode for temporal table join which shares most methods. |
CommonExecPythonCalc
Base class for exec Python Calc.
|
CommonExecPythonCorrelate
Base
ExecNode which matches along with join a Python user defined table function. |
CommonExecSink
Base
ExecNode to write data to an external sink defined by a DynamicTableSink . |
CommonExecTableSourceScan
Base
ExecNode to read data from an external source defined by a ScanTableSource . |
CommonExecUnion
Base
ExecNode that is not a physical node and just union the inputs' records into one
node. |
CommonExecValues
Base
ExecNode that read records from given values. |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.