Package org.apache.flink.table.runtime.generated
-
Interface Summary Interface Description AggsHandleFunction The base class for handling aggregate functions.AggsHandleFunctionBase The base class for handling aggregate or table aggregate functions.FilterCondition Interface for code generated filter condition function on single RowData.FilterCondition.Context Context for generating expressions such as e.g.HashFunction Interface for code generated hash code ofRowDatawhich will select some fields to hash orArrayDataorMapData.JoinCondition Interface for code generated condition function for [[org.apache.calcite.rel.core.Join]].MultiJoinCondition Interface for code generated condition function for Multi-way Joins.NamespaceAggsHandleFunction<N> The base class for handling aggregate functions with namespace.NamespaceAggsHandleFunctionBase<N> The base class for handling aggregate or table aggregate functions.NamespaceTableAggsHandleFunction<N> The base class for handling table aggregate functions with namespace.NormalizedKeyComputer Normalized key computer forBinaryInMemorySortBuffer.Projection<IN extends org.apache.flink.table.data.RowData,OUT extends org.apache.flink.table.data.RowData> Interface for code generated projection, which will map a RowData to another one.RecordComparator Record comparator forBinaryInMemorySortBuffer.RecordEqualiser Record equaliser for RowData which can compare two RowData and returns whether they are equal.TableAggsHandleFunction The base class for handling table aggregate functions. -
Class Summary Class Description CompileUtils Utilities to compile a generated code to a Class.GeneratedAggsHandleFunction Describes a generatedAggsHandleFunction.GeneratedClass<T> A wrapper for generated class, defines aGeneratedClass.newInstance(ClassLoader)method to get an instance by reference objects easily.GeneratedCollector<C extends org.apache.flink.util.Collector<?>> Describes a generatedCollector.GeneratedFilterCondition Describes a generatedFilterCondition.GeneratedFunction<F extends org.apache.flink.api.common.functions.Function> Describes a generatedFunction.GeneratedHashFunction Describes a generatedHashFunction.GeneratedInput<F extends org.apache.flink.api.common.io.InputFormat<?,?>> Describes a generatedInputFormat.GeneratedJoinCondition Describes a generatedJoinCondition.GeneratedNamespaceAggsHandleFunction<N> Describes a generatedNamespaceAggsHandleFunction.GeneratedNamespaceTableAggsHandleFunction<N> Describes a generatedNamespaceTableAggsHandleFunction.GeneratedNormalizedKeyComputer Describes a generatedNormalizedKeyComputer.GeneratedOperator<C extends org.apache.flink.streaming.api.operators.StreamOperator<?>> Describes a generatedStreamOperator.GeneratedProcessTableRunner Describes a generatedProcessTableRunner.GeneratedProjection Describes a generatedProjection.GeneratedRecordComparator Describes a generatedRecordComparator.GeneratedRecordEqualiser Describes a generatedRecordEqualiser.GeneratedResultFuture<T extends org.apache.flink.streaming.api.functions.async.ResultFuture<?>> Describes a generatedResultFuture.GeneratedTableAggsHandleFunction Describes a generatedTableAggsHandleFunction.GeneratedWatermarkGenerator Describes a generatedWatermarkGenerator.GeneratedWatermarkGeneratorSupplier Wrapper of theGeneratedWatermarkGeneratorthat is used to createWatermarkGenerator.GeneratedWatermarkGeneratorSupplier.DefaultWatermarkGenerator Wrapper of the code-generatedWatermarkGenerator.ProcessTableRunner Abstraction of code-generated calls toProcessTableFunctionto be used withinAbstractProcessTableOperator.WatermarkGenerator TheWatermarkGeneratoris used to generate watermark based the input elements.WatermarkGeneratorCodeGeneratorFunctionContextWrapper A function wrapper forFunctionContextif the source supportsSupportsWatermarkPushDown.