BatchExecBoundedStreamScan |
|
BatchExecCalc |
|
BatchExecCorrelate |
Batch exec node which matches along with join a Java/Scala user defined table function.
|
BatchExecDynamicFilteringDataCollector |
|
BatchExecExchange |
This ExecNode represents a change of partitioning of the input elements for batch.
|
BatchExecExecutionOrderEnforcer |
Batch ExecNode for ExecutionOrderEnforcer.
|
BatchExecExpand |
Batch ExecNode that can expand one row to multiple rows based on given projects.
|
BatchExecHashAggregate |
Batch ExecNode for hash-based aggregate operator.
|
BatchExecHashJoin |
|
BatchExecHashWindowAggregate |
Batch ExecNode for hash-based window aggregate operator.
|
BatchExecInputAdapter |
Batch ExecNode for multiple operator fusion codegen input, it is adapter source node.
|
BatchExecLegacySink<T> |
|
BatchExecLegacyTableSourceScan |
|
BatchExecLimit |
|
BatchExecLookupJoin |
BatchExecNode for temporal table join that implemented by lookup.
|
BatchExecMatch |
Batch ExecNode which matches along with MATCH_RECOGNIZE.
|
BatchExecMultipleInput |
|
BatchExecNestedLoopJoin |
|
BatchExecOverAggregate |
Batch ExecNode for sort-based over window aggregate.
|
BatchExecOverAggregateBase |
Batch ExecNode base class for sort-based over window aggregate.
|
BatchExecPythonCalc |
Batch ExecNode for Python ScalarFunctions.
|
BatchExecPythonCorrelate |
Batch exec node which matches along with join a Python user defined table function.
|
BatchExecPythonGroupAggregate |
Batch ExecNode for Python unbounded group aggregate.
|
BatchExecPythonGroupWindowAggregate |
Batch ExecNode for group widow aggregate (Python user defined aggregate function).
|
BatchExecPythonOverAggregate |
Batch ExecNode for sort-based over window aggregate (Python user defined aggregate
function).
|
BatchExecRank |
|
BatchExecScriptTransform |
|
BatchExecSink |
|
BatchExecSort |
|
BatchExecSortAggregate |
Batch ExecNode for (global) sort-based aggregate operator.
|
BatchExecSortLimit |
|
BatchExecSortMergeJoin |
|
BatchExecSortWindowAggregate |
Batch ExecNode for sort-based window aggregate operator.
|
BatchExecTableSourceScan |
|
BatchExecUnion |
Batch ExecNode that is not a physical node and just union the inputs' records into one
node.
|
BatchExecValues |
Batch ExecNode that read records from given values.
|
BatchExecWindowTableFunction |
Batch ExecNode for window table-valued function.
|