Interface | Description |
---|---|
BatchExecNode<T> |
Base class for batch
ExecNode . |
InputSortedExecNode<T> |
A
BatchExecNode which does not sort the input data within the operator, but requires the
input data is already sorted. |
Class | Description |
---|---|
BatchExecBoundedStreamScan |
Batch
ExecNode to connect a given bounded DataStream and consume data from it. |
BatchExecCalc |
Batch
ExecNode for Calc. |
BatchExecCorrelate |
Batch exec node which matches along with join a Java/Scala user defined table function.
|
BatchExecDynamicFilteringDataCollector |
Batch
ExecNode that collects inputs and builds DynamicFilteringData , and then sends the DynamicFilteringEvent to the source coordinator. |
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 |
BatchExecNode for Hash Join. |
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 |
Batch
ExecNode to read data from an external source defined by a bounded StreamTableSource . |
BatchExecLimit |
Batch
ExecNode for Limit. |
BatchExecLookupJoin |
BatchExecNode for temporal table join that implemented by lookup. |
BatchExecMatch |
Batch
ExecNode which matches along with MATCH_RECOGNIZE. |
BatchExecMultipleInput | |
BatchExecNestedLoopJoin |
BatchExecNode for Nested-loop Join. |
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 |
BatchExecNode for Rank. |
BatchExecScriptTransform |
Batch
ExecNode for ScripTransform. |
BatchExecSink |
Batch
ExecNode to write data into an external sink defined by a DynamicTableSink . |
BatchExecSort |
BatchExecNode for Sort without limit. |
BatchExecSortAggregate |
Batch
ExecNode for (global) sort-based aggregate operator. |
BatchExecSortLimit |
BatchExecNode for Sort with limit. |
BatchExecSortMergeJoin |
BatchExecNode for Sort Merge Join. |
BatchExecSortWindowAggregate |
Batch
ExecNode for sort-based window aggregate operator. |
BatchExecTableSourceScan |
Batch
ExecNode to read data from an external source defined by a bounded ScanTableSource . |
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. |
Enum | Description |
---|---|
BatchExecOverAggregateBase.OverWindowMode |
OverWindowMode describes the mode of a group in over window.
|
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.