All Classes Interface Summary Class Summary Enum Summary Exception Summary
Class |
Description |
AbstractAsyncStateSliceWindowAggProcessor |
|
AbstractAsyncStateStreamingJoinOperator |
Abstract implementation for streaming unbounded Join operator based on async state api, which
defines some member fields can be shared between different implementations.
|
AbstractAsyncStateTopNFunction |
Base class for TopN Function with async state api.
|
AbstractAsyncStateWindowAggProcessor<W> |
A base class for window aggregate processors with async state.
|
AbstractAsyncStateWindowAggProcessor.WindowIsEmptyChecker |
A checker that checks whether the window is empty.
|
AbstractBinaryExternalMerger<Entry> |
|
AbstractBytesHashMap<K> |
Bytes based hash map.
|
AbstractBytesMultiMap<K> |
A binary map in the structure like Map<K, List<V>> , where there are multiple values under
a single key, and they are all bytes based.
|
AbstractMapBundleOperator<K,V,IN,OUT> |
|
AbstractRowDataSerializer<T extends org.apache.flink.table.data.RowData> |
Row serializer, provided paged serialize paged method.
|
AbstractRowTimeUnboundedPrecedingOver<K> |
A basic implementation to support unbounded event-time over-window.
|
AbstractSliceSyncStateWindowAggProcessor |
|
AbstractStreamingJoinOperator |
Abstract implementation for streaming unbounded Join operator which defines some member fields
can be shared between different implementations.
|
AbstractSyncStateTopNFunction |
Base class for TopN Function with sync state api.
|
AbstractSyncStateWindowAggProcessor<W> |
A base class for window aggregate processors.
|
AbstractTopNFunction |
Base class for TopN Function.
|
AbstractTopNFunction.AbstractTopNHelper |
An abstract helper to do the logic Top-n used for all top-n functions.
|
AbstractWindowProperty |
Deprecated.
|
AdaptiveBroadcastJoinOptimizationStrategy |
The stream graph optimization strategy of adaptive broadcast join.
|
AdaptiveJoin |
Interface for implementing an adaptive join operator.
|
AdaptiveJoinOperatorFactory<OUT> |
Adaptive join factory.
|
AdaptiveJoinOptimizationUtils |
Utils for adaptive join optimization strategies.
|
AdaptiveSkewedJoinOptimizationStrategy |
The stream graph optimization strategy of adaptive skewed join.
|
AggCombiner |
An implementation of RecordsCombiner that accumulates input records into the window
accumulator state.
|
AggCombiner.Factory |
|
AggregateWindowOperator<K,W extends Window> |
|
AggsHandleFunction |
The base class for handling aggregate functions.
|
AggsHandleFunctionBase |
The base class for handling aggregate or table aggregate functions.
|
AlignedWindowTableFunctionOperator |
The operator for aligned window table function.
|
AppendOnlyFirstNFunction |
|
AppendOnlyTopNFunction |
A TopN function could handle insert-only stream.
|
AppendOnlyTopNHelper |
|
ArrayAggFunction<T> |
Built-in ARRAY_AGG aggregate function.
|
ArrayAggFunction.ArrayAggAccumulator<T> |
Accumulator for ARRAY_AGG with retraction.
|
ArrayAppendFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_APPEND .
|
ArrayBooleanArrayConverter |
Converter for ArrayType of boolean[] external type.
|
ArrayByteArrayConverter |
Converter for ArrayType of byte[] external type.
|
ArrayConcatFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_CONCAT .
|
ArrayContainsFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_CONTAINS .
|
ArrayDataSerializer |
Serializer for ArrayData .
|
ArrayDataSerializer.ArrayDataSerializerSnapshot |
|
ArrayDistinctFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_DISTINCT .
|
ArrayDoubleArrayConverter |
Converter for ArrayType of double[] external type.
|
ArrayExceptFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_EXCEPT .
|
ArrayFloatArrayConverter |
Converter for ArrayType of float[] external type.
|
ArrayIntArrayConverter |
Converter for ArrayType of int[] external type.
|
ArrayIntersectFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_INTERSECT .
|
ArrayJoinFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_JOIN .
|
ArrayListConverter<E> |
Converter for ArrayType of List external type.
|
ArrayLongArrayConverter |
Converter for ArrayType of long[] external type.
|
ArrayMaxFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_MAX .
|
ArrayMinFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_MIN .
|
ArrayObjectArrayConverter<E> |
Converter for ArrayType of nested primitive or object arrays external types.
|
ArrayPositionFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_POSITION .
|
ArrayPrependFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_PREPEND .
|
ArrayRemoveFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_REMOVE .
|
ArrayReverseFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_REVERSE .
|
ArrayShortArrayConverter |
Converter for ArrayType of short[] external type.
|
ArraySliceFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_SLICE .
|
ArraySortFunction |
Implementation of ARRAY_SORT function.
|
ArrayUnionFunction |
Implementation of BuiltInFunctionDefinitions.ARRAY_UNION .
|
AssociatedRecords |
|
AsyncFunctionRunner |
Async function runner for AsyncScalarFunction , which
takes the generated function, instantiates it, and then calls its lifecycle methods.
|
AsyncLookupJoinRunner |
The async join runner to lookup the dimension table.
|
AsyncLookupJoinWithCalcRunner |
The async join runner with an additional calculate function on the dimension table.
|
AsyncMergeCallback<W,R> |
Callback to be used in when merging slices or windows for specifying which slices or windows
should be merged.
|
AsyncStateAggCombiner |
An implementation of RecordsCombiner that accumulates input records into the window
accumulator with async state.
|
AsyncStateAggCombiner.Factory |
|
AsyncStateAppendOnlyTopNFunction |
A TopN function could handle insert-only stream.
|
AsyncStateFastTop1Function |
|
AsyncStateGroupAggFunction |
Aggregate Function used for the groupby (without window) aggregate with async state api.
|
AsyncStateKeyContext |
Context to switch current key in async state backend.
|
AsyncStateRecordsCombiner |
|
AsyncStateRecordsCombiner.Factory |
|
AsyncStateRecordsWindowBuffer |
|
AsyncStateRecordsWindowBuffer.Factory |
|
AsyncStateRowTimeDeduplicateFunction |
This function is used to deduplicate on keys and keeps only first or last row on row time.
|
AsyncStateSliceSharedWindowAggProcessor |
A window aggregate processor implementation which works for SliceSharedAssigner with
async state api, e.g. hopping windows and cumulative windows.
|
AsyncStateSliceUnsharedWindowAggProcessor |
A window aggregate processor implementation which works for SliceUnsharedAssigner with
async state, e.g. tumbling windows.
|
AsyncStateSlicingWindowProcessor<W> |
|
AsyncStateStreamingJoinOperator |
Streaming unbounded Join operator based on async state api, which supports INNER/LEFT/RIGHT/FULL
JOIN.
|
AsyncStateTableStreamOperator<OUT> |
Table operator to invoke close always.
|
AsyncStateUtils |
Utils for processing with async state.
|
AsyncStateWindowAggOperator<K,W> |
A processor that processes elements for windows with async state api.
|
AsyncStateWindowBuffer |
A buffer that buffers data in memory and flushes many values to async state together at a time to
avoid frequently accessing async state, or flushes to output to reduce shuffling data.
|
AsyncStateWindowBuffer.Factory |
|
AsyncStateWindowJoinOperator |
|
AsyncStateWindowProcessor<W> |
A processor that processes elements for windows with async state.
|
AsyncStateWindowProcessor.AsyncStateContext<W> |
|
BaseAdaptiveJoinOperatorOptimizationStrategy |
The base stream graph optimization strategy class for adaptive join operator.
|
BaseHybridHashTable |
|
BaseTwoInputStreamOperatorWithStateRetention |
An abstract TwoInputStreamOperator that allows its subclasses to clean up their state
based on a TTL.
|
BatchApproxCountDistinctAggFunctions |
Built-in APPROX_COUNT_DISTINCT aggregate function for Batch sql.
|
BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction<T> |
Base function for APPROX_COUNT_DISTINCT aggregate.
|
BatchApproxCountDistinctAggFunctions.ByteApproxCountDistinctAggFunction |
Built-in byte APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.DateApproxCountDistinctAggFunction |
Built-in Date APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.DecimalApproxCountDistinctAggFunction |
Built-in decimal APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.DoubleApproxCountDistinctAggFunction |
Built-in double APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.FloatApproxCountDistinctAggFunction |
Built-in float APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.IntApproxCountDistinctAggFunction |
Built-in int APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.LongApproxCountDistinctAggFunction |
Built-in long APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.ShortApproxCountDistinctAggFunction |
Built-in Short APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.StringApproxCountDistinctAggFunction |
Built-in string APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.TimeApproxCountDistinctAggFunction |
Built-in Time APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.TimestampApproxCountDistinctAggFunction |
Built-in Timestamp APPROX_COUNT_DISTINCT aggregate function.
|
BatchApproxCountDistinctAggFunctions.TimestampLtzApproxCountDistinctAggFunction |
Built-in TimestampLtz APPROX_COUNT_DISTINCT aggregate function.
|
BatchMultipleInputStreamOperator |
|
BatchMultipleInputStreamOperatorFactory |
|
BigDecimalTypeInfo |
|
BinaryArrayWriter |
Writer for binary array.
|
BinaryArrayWriter.NullSetter |
Accessor for setting the elements of an array writer to null during runtime.
|
BinaryExternalMerger |
Record merger for sort of BinaryRowData.
|
BinaryExternalSorter |
|
BinaryHashBucketArea |
Bucket area for hash table.
|
BinaryHashPartition |
A partition.
|
BinaryHashPartition.BuildSideBuffer |
Build side buffer.
|
BinaryHashPartitioner |
Hash partitioner for BinaryRowData .
|
BinaryHashTable |
An implementation of a Hybrid Hash Join.
|
BinaryIndexedSortable |
abstract sortable, provide basic compare and swap.
|
BinaryInMemorySortBuffer |
In memory sort buffer for binary row.
|
BinaryKVExternalMerger |
Key-Value style record merger for sort.
|
BinaryKVInMemorySortBuffer |
In memory KV sortable buffer for binary row, it already has records in memory.
|
BinaryMergeIterator<Entry> |
Binary version of MergeIterator .
|
BinaryRowChannelInputViewIterator |
A simple iterator over the input read though an I/O channel.
|
BinaryRowDataKeySelector |
A KeySelector which will extract key from RowData.
|
BinaryRowDataSerializer |
Serializer for BinaryRowData .
|
BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot |
|
BinaryRowDataUtil |
Utilities for BinaryRowData .
|
BinaryRowWriter |
Writer for BinaryRowData .
|
BinaryStringDataUtil |
Util for BinaryStringData .
|
BinaryWriter |
Writer to write a composite data format, like row, array. 1.
|
BinaryWriter.ValueSetter |
Accessor for setting the elements of an array writer during runtime.
|
BoundedOutOfOrderWatermarkGenerator |
A watermark generator for rowtime attributes which are out-of-order by a bounded time interval.
|
BoxedWrapperRowData |
An implementation of RowData which also is also backed by an array of Java Object , just similar to GenericRowData .
|
BroadcastingOutput |
An Output that can be used to emit elements and other messages to multiple outputs.
|
BTrimFunction |
Implementation of BuiltInFunctionDefinitions.BTRIM .
|
BufferBundle<T> |
A BufferBundle is a bundle to buffer the input records in memory and fold data based on
specified pattern to reduce state access.
|
BufferDataOverWindowOperator |
the operator for OVER window need cache data by ResettableExternalBuffer for OverWindowFrame .
|
BufferedKVExternalSorter |
Sorter for buffered input in the form of Key-Value Style.
|
BuildSideIterator |
Iterate all the elements in memory which has not been(or has been) probed during probe phase.
|
BuildSideIterator.BucketIterator |
Partition bucket iterator.
|
BuiltInAggregateFunction<T,ACC> |
Base class for runtime implementation represented as AggregateFunction that is
constructed from BuiltInFunctionDefinition.specialize(SpecializedContext) .
|
BuiltInScalarFunction |
Base class for runtime implementation represented as ScalarFunction that is constructed
from BuiltInFunctionDefinition.specialize(SpecializedContext) .
|
BuiltInSpecializedFunction |
Base class for built-in functions that need another level of specialization via BuiltInFunctionDefinition.specialize(SpecializedContext) .
|
BuiltInTableFunction<T> |
Base class for runtime implementation represented as TableFunction that is constructed
from BuiltInFunctionDefinition.specialize(SpecializedContext) .
|
BundleTrigger<T> |
A BundleTrigger determines when a bundle of input elements should be evaluated and
trigger the callback which registered previously.
|
BundleTriggerCallback |
Interface for bundle trigger callbacks that can be registered to a BundleTrigger .
|
ByteHashSet |
Byte hash set.
|
BytesHashMap |
A binary map in the structure like Map<BinaryRowData, BinaryRowData> .
|
BytesHashMapSpillMemorySegmentPool |
MemorySegmentPool for BytesHashMap to fall back to sort agg.
|
BytesMap<K,V> |
|
BytesMap.LookupInfo<K,V> |
Result fetched when looking up a key.
|
BytesMultiMap |
A binary map in the structure like Map<BinaryRowData, List<BinaryRowData>> .
|
CacheLoader |
Abstract task that loads data in Full cache from source provided by ScanTableSource.ScanRuntimeProvider .
|
CachingAsyncLookupFunction |
A wrapper function around user-provided async lookup function with a cache layer.
|
CachingLookupFunction |
A wrapper function around user-provided lookup function with a cache layer.
|
ChannelReaderKVInputViewIterator<K,V> |
Key-Value style channel reader input view iterator.
|
ChannelWithMeta |
Channel with block count and numBytesInLastBlock of file.
|
ClassDataTypeConverter |
Utils for get DataType from a Class.
|
ClassLogicalTypeConverter |
Get internal(sql engine execution data formats) and default external class for LogicalType .
|
CleanupState |
Base interface for clean up state, both for ProcessFunction and CoProcessFunction .
|
ClockService |
A clock service which can get current processing time.
|
CoalesceFunction |
Implementation of BuiltInFunctionDefinitions.COALESCE .
|
CoBundleTrigger<IN1,IN2> |
|
CodeGenOperatorFactory<OUT> |
Stream operator factory for code gen operator.
|
CollectAggFunction<T> |
Built-in COLLECT aggregate function.
|
CollectAggFunction.CollectAccumulator<T> |
Accumulator for COLLECT.
|
ComparableRecordComparator |
|
CompileUtils |
Utilities to compile a generated code to a Class.
|
CompressedBlockChannelReader |
Compressed block channel reader provides a scenario where MemorySegment must be maintained.
|
CompressedBlockChannelWriter |
Compressed block channel writer provides a scenario where MemorySegment must be maintained.
|
CompressedHeaderlessChannelReaderInputView |
A DataInputView that is backed by a BufferFileReader , making it effectively a data input stream.
|
CompressedHeaderlessChannelWriterOutputView |
A DataOutputView that is backed by a FileIOChannel ,
making it effectively a data output stream.
|
ConstantRankRange |
rankStart and rankEnd are inclusive, rankStart always start from one.
|
ConstantRankRangeWithoutEnd |
ConstantRankRangeWithoutEnd is a RankRange which not specify RankEnd.
|
ConstraintEnforcer |
Processes RowData to enforce the following constraints:
NOT NULL column constraint of a sink table
CHAR(length) /@{code VARCHAR(length)}: trim string values to comply with the
length defined in their corresponding types.
|
ConstraintEnforcer.Builder |
Helper builder, so that the ConstraintEnforcer can be instantiated with only the NOT
NULL constraint validation, only the CHAR/VARCHAR length validation, only the
BINARY/VARBINARY length validation or combinations of them, or all of them.
|
ConstraintEnforcer.FieldInfo |
Helper POJO to keep info about CHAR/VARCHAR/BINARY/VARBINARY fields, used to determine if
trimming or padding is needed.
|
CopyingBroadcastingOutput |
Special version of BroadcastingOutput that performs a shallow copy of the StreamRecord to ensure that multi-output works correctly.
|
CopyingFirstInputOfTwoInputStreamOperatorOutput |
An Output that can be used to emit copying elements and other messages for the first
input of TwoInputStreamOperator .
|
CopyingOneInputStreamOperatorOutput |
An Output that can be used to emit copying elements and other messages for OneInputStreamOperator .
|
CopyingSecondInputOfTwoInputStreamOperatorOutput |
An Output that can be used to emit copying elements and other messages for the second
input of TwoInputStreamOperator .
|
CountBundleTrigger<T> |
A BundleTrigger that fires once the count of elements in a bundle reaches the given
count.
|
CountCoBundleTrigger<IN1,IN2> |
A CoBundleTrigger that fires once the count of elements in a bundle reaches the given
count.
|
CountSlidingWindowAssigner |
A GroupWindowAssigner that windows elements into sliding windows based on the count
number of the elements.
|
CountTumblingWindowAssigner |
A GroupWindowAssigner that windows elements into fixed-size windows based on the count
number of the elements.
|
CountWindow |
A Window that represents a count window.
|
CountWindow.Serializer |
The serializer used to write the CountWindow type.
|
CountWindow.Serializer.CountWindowSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
CumulativeWindowAssigner |
A GroupWindowAssigner that windows elements into cumulative windows based on the
timestamp of the elements.
|
DataFormatConverters |
Converters between internal data format and java format.
|
DataFormatConverters.AbstractRowDataConverter<E> |
Abstract converter for internal base row.
|
DataFormatConverters.ArrayDataConverter |
Converter for ArrayData.
|
DataFormatConverters.BigDecimalConverter |
Converter for BigDecimal.
|
DataFormatConverters.BooleanConverter |
Converter for boolean.
|
DataFormatConverters.ByteConverter |
Converter for byte.
|
DataFormatConverters.CaseClassConverter |
Converter for case class.
|
DataFormatConverters.DataFormatConverter<Internal,External> |
Converter between internal data format and java format.
|
DataFormatConverters.DateConverter |
Converter for date.
|
DataFormatConverters.DecimalDataConverter |
Converter for DecimalData.
|
DataFormatConverters.DoubleConverter |
Converter for double.
|
DataFormatConverters.FloatConverter |
Converter for float.
|
DataFormatConverters.GenericConverter<T> |
Converter for RawValueData .
|
DataFormatConverters.IdentityConverter<T> |
Identity converter.
|
DataFormatConverters.InstantConverter |
Converter for Instant.
|
DataFormatConverters.IntConverter |
Converter for int.
|
DataFormatConverters.LocalDateConverter |
Converter for LocalDate.
|
DataFormatConverters.LocalDateTimeConverter |
Converter for LocalDateTime.
|
DataFormatConverters.LocalTimeConverter |
Converter for LocalTime.
|
DataFormatConverters.LongConverter |
Converter for long.
|
DataFormatConverters.LongTimestampDataConverter |
Converter for Long and TimestampData.
|
DataFormatConverters.MapConverter |
Converter for map.
|
DataFormatConverters.MapDataConverter |
Converter for MapData.
|
DataFormatConverters.ObjectArrayConverter<T> |
Converter for object array.
|
DataFormatConverters.PojoConverter<T> |
Converter for pojo.
|
DataFormatConverters.PrimitiveBooleanArrayConverter |
Converter for primitive boolean array.
|
DataFormatConverters.PrimitiveByteArrayConverter |
Converter for primitive byte array.
|
DataFormatConverters.PrimitiveDoubleArrayConverter |
Converter for primitive double array.
|
DataFormatConverters.PrimitiveFloatArrayConverter |
Converter for primitive float array.
|
DataFormatConverters.PrimitiveIntArrayConverter |
Converter for primitive int array.
|
DataFormatConverters.PrimitiveLongArrayConverter |
Converter for primitive long array.
|
DataFormatConverters.PrimitiveShortArrayConverter |
Converter for primitive short array.
|
DataFormatConverters.RawValueDataConverter |
Converter for RawValueData.
|
DataFormatConverters.RowConverter |
Converter for row.
|
DataFormatConverters.RowDataConverter |
Converter for base row.
|
DataFormatConverters.ShortConverter |
Converter for short.
|
DataFormatConverters.StringConverter |
Converter for String.
|
DataFormatConverters.StringDataConverter |
Converter for StringData.
|
DataFormatConverters.TimeConverter |
Converter for time.
|
DataFormatConverters.TimestampConverter |
Converter for timestamp.
|
DataFormatConverters.TimestampDataConverter |
Converter for TimestampData class.
|
DataFormatConverters.TimestampLtzConverter |
Converter for timestamp which doesn't consider the time zone.
|
DataFormatConverters.TupleConverter |
Converter for flink tuple.
|
DataStructureConverter<I,E> |
Converter between internal and external data structure.
|
DataStructureConverters |
Registry of available data structure converters.
|
DataTypePrecisionFixer |
The data type visitor used to fix the precision for data type with the given logical type which
carries the correct precisions.
|
DataViewSpec |
Information about a DataView stored in state.
|
DateDateConverter |
Converter for DateType of Date external type.
|
DateLocalDateConverter |
Converter for DateType of LocalDate external type.
|
DayTimeIntervalDurationConverter |
Converter for DayTimeIntervalType of Duration external type.
|
DecimalBigDecimalConverter |
Converter for DecimalType of BigDecimal external type.
|
DecimalDataSerializer |
Serializer for DecimalData .
|
DecimalDataSerializer.DecimalSerializerSnapshot |
|
DecimalDataTypeInfo |
TypeInformation for DecimalData .
|
DecimalDataUtils |
Utilities for DecimalData .
|
DeduplicateFunctionBase<T,K,IN,OUT> |
Base class for deduplicate function.
|
DeduplicateFunctionHelper |
Utility for deduplicate function.
|
DefaultExpressionEvaluator |
Default runtime implementation for SpecializedFunction.ExpressionEvaluator .
|
DelegatingAsyncResultFuture |
|
DelegatingResultFuture<OUT> |
|
DoubleHashSet |
Double hash set.
|
DropUpdateBeforeFunction |
A function drops only rows with RowKind.UPDATE_BEFORE changelog kind.
|
DynamicFilteringDataCollectorOperator |
Operator to collect and build the DynamicFilteringData for sources that supports dynamic
filtering.
|
DynamicFilteringDataCollectorOperatorCoordinator |
|
DynamicFilteringDataCollectorOperatorCoordinator.Provider |
|
DynamicFilteringDataCollectorOperatorFactory |
|
ElementTriggers |
A Trigger that fires at some point after a specified number of input elements have
arrived.
|
ElementTriggers.CountElement<W extends Window> |
A Trigger that fires at some point after a specified number of input elements have
arrived.
|
ElementTriggers.EveryElement<W extends Window> |
A Trigger that triggers on every element.
|
EltFunction |
Implementation of BuiltInFunctionDefinitions.ELT .
|
EmptyRowDataKeySelector |
A utility class which key is always empty no matter what the input row is.
|
EndsWithFunction |
Implementation of BuiltInFunctionDefinitions.ENDS_WITH .
|
EqualityAndHashcodeProvider |
This class is used for scalar function, in that it is used for sharing the initialization context
between scalar functions that need code generated hashcode and equals method.
|
EventTimeTriggers |
A Trigger that reacts to event-time timers.
|
EventTimeTriggers.AfterEndOfWindow<W extends Window> |
A Trigger that fires once the watermark passes the end of the window to which a pane
belongs.
|
EventTimeTriggers.AfterEndOfWindowEarlyAndLate<W extends Window> |
A composite Trigger that consist of AfterEndOfWindow and a early trigger and late
trigger.
|
EventTimeTriggers.AfterEndOfWindowNoLate<W extends Window> |
A composite Trigger that consist of AfterEndOfWindow and a late trigger.
|
ExceptionInMultipleInputOperatorException |
|
ExecutionContext |
A ExecutionContext contains information about the context in which functions are executed and the
APIs to create state.
|
ExecutionContextImpl |
Implementation of ExecutionContext.
|
ExternalSerializer<I,E> |
A serializer that can serialize and deserialize all data structures defined by a DataType .
|
ExternalSerializer.ExternalSerializerSnapshot<I,E> |
|
ExternalTypeInfo<T> |
Type information that wraps a serializer that originated from a DataType .
|
FastTop1Function |
|
FastTop1Helper |
|
FileChannelUtil |
File channel util for runtime.
|
FilterAllFlatMapFunction |
Function filtering out all the input records.
|
FilterCondition |
Interface for code generated filter condition function on single RowData.
|
FirstInputOfTwoInput |
Input for the first input of TwoInputStreamOperator .
|
FirstInputOfTwoInputStreamOperatorOutput |
An Output that can be used to emit elements and other messages for the first input of
TwoInputStreamOperator .
|
FirstValueAggFunction<T> |
Built-in FIRST_VALUE aggregate function.
|
FirstValueWithRetractAggFunction<T> |
Built-in FIRST_VALUE with retraction aggregate function.
|
FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T> |
Accumulator for FIRST_VALUE.
|
FlinkJoinType |
Join type for join.
|
FloatHashSet |
Float hash set.
|
FusionStreamOperatorBase |
Base MultipleInputStreamOperator to handle multiple operator fusion codegen in table
module.
|
GeneralWindowProcessFunction<K,W extends Window> |
|
GeneratedAggsHandleFunction |
|
GeneratedClass<T> |
|
GeneratedCollector<C extends org.apache.flink.util.Collector<?>> |
Describes a generated Collector .
|
GeneratedFilterCondition |
|
GeneratedFunction<F extends org.apache.flink.api.common.functions.Function> |
Describes a generated Function .
|
GeneratedHashFunction |
|
GeneratedInput<F extends org.apache.flink.api.common.io.InputFormat<?,?>> |
Describes a generated InputFormat .
|
GeneratedJoinCondition |
|
GeneratedNamespaceAggsHandleFunction<N> |
|
GeneratedNamespaceTableAggsHandleFunction<N> |
|
GeneratedNormalizedKeyComputer |
|
GeneratedOperator<C extends org.apache.flink.streaming.api.operators.StreamOperator<?>> |
Describes a generated StreamOperator .
|
GeneratedProjection |
|
GeneratedRecordComparator |
|
GeneratedRecordEqualiser |
|
GeneratedResultFuture<T extends org.apache.flink.streaming.api.functions.async.ResultFuture<?>> |
Describes a generated ResultFuture .
|
GeneratedTableAggsHandleFunction |
|
GeneratedWatermarkGenerator |
|
GeneratedWatermarkGeneratorSupplier |
|
GeneratedWatermarkGeneratorSupplier.DefaultWatermarkGenerator |
|
GenericRowDataKeySelector |
A KeySelector which will extract key from RowData.
|
GlobalAggCombiner |
An implementation of RecordsCombiner that accumulates local accumulators records into the
window accumulator state.
|
GlobalAggCombiner.Factory |
|
GlobalRuntimeFilterBuilderOperator |
Global runtime filter builder operator.
|
GroupAggFunction |
Aggregate Function used for the groupby (without window) aggregate.
|
GroupAggFunctionBase |
|
GroupAggHelper |
A helper to do the logic of group agg.
|
GroupTableAggFunction |
Aggregate Function used for the groupby (without window) table aggregate.
|
GroupWindowAssigner<W extends Window> |
|
HashFunction |
Interface for code generated hash code of RowData which will select some fields to hash
or ArrayData or MapData .
|
HashJoinOperator |
Hash join base operator.
|
HashJoinType |
Join type for hash table.
|
HeaderlessChannelWriterOutputView |
A DataOutputView that is backed by a BlockChannelWriter , making it effectively a data output stream.
|
HeapWindowsGrouping |
A jvm heap implementation of WindowsGrouping , which uses a linked list to buffer all the
inputs of a keyed group belonging to the same window.
|
HllBuffer |
Buffer used by HyperLogLogPlusPlus and ApproximateCountDistinct.
|
HyperLogLogPlusPlus |
The implement of HyperLogLogPlusPlus is inspired from Apache Spark.
|
IdentityConverter<I> |
No-op converter that just forwards its input.
|
IfNullFunction |
Implementation of BuiltInFunctionDefinitions.IF_NULL .
|
InputBase |
|
InputConversionOperator<E> |
Operator that converts to internal data structures and wraps atomic records if necessary.
|
InputFormatCacheLoader |
CacheLoader that used InputFormat for loading data into the cache.
|
InputSelectionHandler |
|
InputSelectionSpec |
Describe the inputId and read order of MultipleInput operator.
|
InputSideHasNoUniqueKeyBundle |
For the case that input has no uniqueKey.
|
InputSideHasUniqueKeyBundle |
For the case that input has uniqueKey which is not contained by joinKey.
|
InputSpec |
Describe the info of Input .
|
InputSplitCacheLoadTask |
Parallel task that loads data into the cache from InputFormat with specified InputSplit .
|
InsensitiveOverFrame |
The insensitive window frame calculates the statements which shouldn't care the window frame, for
example RANK/DENSE_RANK/PERCENT_RANK/NTILE/ROW_NUMBER.
|
InternalSerializers |
TypeSerializer of LogicalType for internal data structures.
|
InternalTimeWindowAssigner |
The internal time window assigner which has some useful methods.
|
InternalTypeInfo<T> |
Type information that wraps a serializer that originated from a LogicalType .
|
InternalWindowProcessFunction<K,W extends Window> |
The internal interface for functions that process over grouped windows.
|
InternalWindowProcessFunction.Context<K,W extends Window> |
|
IntervalJoinFunction |
|
IntHashSet |
Int hash set.
|
IterativeConditionRunner |
A RichIterativeCondition wrapper to delegate invocation to the code generated RichIterativeCondition .
|
JoinCondition |
Interface for code generated condition function for [[org.apache.calcite.rel.core.Join]].
|
JoinConditionWithNullFilters |
Utility to take null filters into consideration when apply join condition.
|
JoinHelper<STATE_VIEW,OUTER_STATE_VIEW extends STATE_VIEW> |
A helper to do the logic of streaming join.
|
JoinInputSideSpec |
The JoinInputSideSpec is ap specification which describes input side information of a
Join.
|
JoinKeyContainsUniqueKeyBundle |
For the case that input has joinKey contains uniqueKey.
|
JoinRecordAsyncStateView |
|
JoinRecordAsyncStateViews |
|
JoinRecordStateView |
|
JoinRecordStateViews |
|
JsonArrayAggFunction |
Implementation for BuiltInFunctionDefinitions.JSON_ARRAYAGG_ABSENT_ON_NULL / BuiltInFunctionDefinitions.JSON_ARRAYAGG_NULL_ON_NULL .
|
JsonArrayAggFunction.Accumulator |
|
JsonObjectAggFunction |
Implementation for BuiltInFunctionDefinitions.JSON_OBJECTAGG_NULL_ON_NULL / BuiltInFunctionDefinitions.JSON_OBJECTAGG_ABSENT_ON_NULL .
|
JsonObjectAggFunction.Accumulator |
|
JsonPathCache |
The default cache for the jsonpath com.jayway.jsonpath.spi.cache.CacheProvider .
|
JsonQuoteFunction |
Implementation of BuiltInFunctionDefinitions.JSON_QUOTE .
|
JsonUnquoteFunction |
Implementation of BuiltInFunctionDefinitions.JSON_UNQUOTE .
|
KeyedCoProcessOperatorWithWatermarkDelay<K,IN1,IN2,OUT> |
A KeyedCoProcessOperator that supports holding back watermarks with a static delay.
|
KeyedLookupJoinWrapper |
The lookup join handler which holds a LookupJoinRunner to process lookup for insert or
update_after record and directly process delete and update_before record via local state.
|
KeyedMapBundleOperator<K,V,IN,OUT> |
|
KeyedProcessFunctionWithCleanupState<K,IN,OUT> |
A function that processes elements of a stream, and could cleanup state.
|
KeyValueIterator<K,V> |
An internal iterator interface which presents a more restrictive API than Iterator .
|
LagAggFunction<T> |
Lag AggregateFunction .
|
LagAggFunction.LagAcc<T> |
Accumulator for LAG.
|
LastValueAggFunction<T> |
Built-in LAST_VALUE aggregate function.
|
LastValueWithRetractAggFunction<T> |
Built-in LAST_VALUE with retraction aggregate function.
|
LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T> |
Accumulator for LAST_VALUE with retraction.
|
LazyMemorySegmentPool |
|
LegacyInstantTypeInfo |
|
LegacyLocalDateTimeTypeInfo |
|
LegacyTimestampTypeInfo |
|
LimitOperator |
Operator for batch limit.
|
LinkedListSerializer<T> |
|
LinkedListSerializer.LinkedListSerializerSnapshot<T> |
|
ListAggWithRetractAggFunction |
Built-in LISTAGG with retraction aggregate function.
|
ListAggWithRetractAggFunction.ListAggWithRetractAccumulator |
Accumulator for LISTAGG with retraction.
|
ListAggWsWithRetractAggFunction |
Built-in LISTAGGWS with retraction aggregate function.
|
ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator |
Accumulator for LISTAGGWS with retraction.
|
ListenableCollector<T> |
A listenable collector for lookup join that can be called when an original record was collected.
|
ListenableCollector.CollectListener<T> |
An interface can listen on collecting original record.
|
ListMemorySegmentPool |
MemorySegment pool of a MemorySegment list.
|
ListViewSpec |
Specification for a ListView .
|
LocalAggCombiner |
An implementation of RecordsCombiner that accumulates input records into local
accumulators.
|
LocalAggCombiner.Factory |
|
LocalRuntimeFilterBuilderOperator |
Local runtime filter builder operator.
|
LocalSlicingWindowAggOperator |
The operator used for local window aggregation.
|
LocalZonedTimestampInstantConverter |
Converter for LocalZonedTimestampType of Instant external type.
|
LocalZonedTimestampIntConverter |
Converter for LocalZonedTimestampType of Integer external type.
|
LocalZonedTimestampLongConverter |
Converter for LocalZonedTimestampType of Long external type.
|
LocalZonedTimestampTimestampConverter |
Converter for LocalZonedTimestampType of Timestamp external type.
|
LogicalTypeDataTypeConverter |
Deprecated. |
LongHashPartition |
|
LongHashPartitionChannelReaderInputViewIterator |
A simple iterator over the input read though an I/O channel.
|
LongHashSet |
Long hash set.
|
LongHybridHashTable |
Special optimized hashTable with key long.
|
LookupBucketIterator |
Build iterator from bucket to match probe row.
|
LookupCacheManager |
Managing shared caches across different subtasks.
|
LookupCacheManager.RefCountedCache |
A wrapper class of LookupCache which also tracks the reference count of it.
|
LookupFullCache |
Internal implementation of LookupCache for LookupOptions.LookupCacheType.FULL .
|
LookupJoinRunner |
The join runner to lookup the dimension table.
|
LookupJoinWithCalcRunner |
The join runner with an additional calculate function on the dimension table.
|
LookupRuntimeProviderContext |
Implementation of DynamicTableSource.Context .
|
LRUMap<K,V> |
An LRU cache, based on LinkedHashMap .
|
LRUMap.RemovalListener<K,V> |
An object that can receive a notification when an entry is removed from a LRUMap.
|
MapBundleFunction<K,V,IN,OUT> |
Basic interface for map bundle processing.
|
MapBundleOperator<K,V,IN,OUT> |
The MapBundleOperator uses a KeySelector to extract bundle key, thus can be used
with non-keyed-stream.
|
MapDataSerializer |
Serializer for MapData .
|
MapDataSerializer.MapDataSerializerSnapshot |
|
MapDataUtil |
Utilities for MapData .
|
MapEntriesFunction |
Implementation of BuiltInFunctionDefinitions.MAP_ENTRIES .
|
MapFromArraysFunction |
Implementation of BuiltInFunctionDefinitions.MAP_FROM_ARRAYS .
|
MapKeysFunction |
Implementation of BuiltInFunctionDefinitions.MAP_KEYS .
|
MapMapConverter<K,V> |
Converter for MapType / MultisetType of Map external type.
|
MapUnionFunction |
Implementation of BuiltInFunctionDefinitions.MAP_UNION .
|
MapValuesFunction |
Implementation of BuiltInFunctionDefinitions.MAP_VALUES .
|
MapViewSpec |
Specification for a MapView .
|
MaxWithRetractAggFunction<T extends Comparable<T>> |
Built-in MAX with retraction aggregate function.
|
MaxWithRetractAggFunction.MaxWithRetractAccumulator<T> |
Accumulator for MAX with retraction.
|
MemorySegmentPool |
MemorySegment pool to hold pages in memory.
|
MergeCallback<W,R> |
Callback to be used in when merging slices or windows for specifying which slices or windows
should be merged.
|
MergingWindowAssigner<W extends Window> |
A WindowAssigner that can merge windows.
|
MergingWindowProcessFunction<K,W extends Window> |
|
MergingWindowProcessFunction.DefaultAccMergingConsumer<W extends Window> |
A default merging consumer that merges the accumulators in state windows that waiting to be
merged into the target state window.
|
MergingWindowProcessFunction.MergingContext<K,W extends Window> |
|
MergingWindowSet<W extends Window> |
|
MergingWindowSet.MergeFunction<W> |
|
MiniBatchGlobalGroupAggFunction |
Aggregate Function used for the global groupby (without window) aggregate in miniBatch mode.
|
MiniBatchGroupAggFunction |
Aggregate Function used for the groupby (without window) aggregate in miniBatch mode.
|
MiniBatchIncrementalGroupAggFunction |
Aggregate Function used for the incremental groupby (without window) aggregate in miniBatch mode.
|
MiniBatchLocalGroupAggFunction |
Aggregate Function used for the local groupby (without window) aggregate in miniBatch mode.
|
MiniBatchStreamingJoinOperator |
Streaming unbounded Join base operator which support mini-batch join.
|
MinWithRetractAggFunction<T extends Comparable<T>> |
Built-in MIN with retraction aggregate function.
|
MinWithRetractAggFunction.MinWithRetractAccumulator<T> |
Accumulator for MIN with retraction.
|
MultipleInputStreamOperatorBase |
Base MultipleInputStreamOperator to handle multiple inputs in table module.
|
MurmurHashUtil |
Murmur hasher.
|
NamedWindowProperty |
Deprecated.
|
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.
|
NonBufferOverWindowOperator |
The operator for OVER window don't need cache data.
|
NormalizedKeyComputer |
|
NullAwareJoinHelper |
Helper for null aware join.
|
NullAwareMapIterator<K,V> |
An Iterator implementation that iterate on a map iterator and a null entry.
|
NullAwareMapIterator.NullMapEntry<K,V> |
A Map Entry that the entry key is always null.
|
ObjectContainer |
This class is used for scalar function, in that it is used for comparing Objects using code
generated hashCode and equals instead of using the Object#equals/Object#hashcode versions.
|
ObjectHashSet<T> |
Wrap HashSet with hashSet interface.
|
OffsetOverFrame |
The offset window frame calculates frames containing LEAD/LAG statements.
|
OffsetOverFrame.CalcOffsetFunc |
Calc offset from base row.
|
OneInput |
Input for OneInputStreamOperator .
|
OneInputStreamOperatorOutput |
An Output that can be used to emit elements and other messages for OneInputStreamOperator .
|
OperatorFusionCodegenFactory<OUT> |
Stream operator factory for multiple operator fusion codegen.
|
OptimizableHashSet |
A type-specific hash set with with a fast, small-footprint implementation.
|
OuterJoinPaddingUtil |
An utility to generate reusable padding results for outer joins.
|
OuterJoinRecordAsyncStateView |
|
OuterJoinRecordAsyncStateViews |
|
OuterJoinRecordStateView |
|
OuterJoinRecordStateViews |
|
OuterRecord |
An OuterRecord is a composite of record and numOfAssociations .
|
OutputBase |
Base Output that can be used to emit elements and other messages in MultipleInputStreamOperatorBase .
|
OutputConversionOperator |
Operator that converts to external data structures and unwraps atomic records if necessary.
|
OverWindowFrame |
A window frame calculates the results for those records belong to a window frame.
|
PaddingLeftMapFunction |
Function performing left padding.
|
PaddingRightMapFunction |
Function performing right padding.
|
PagedTypeSerializer<T> |
A type serializer which provides paged serialize and deserialize methods.
|
PanedWindowAssigner<W extends Window> |
A WindowAssigner that window can be split into panes.
|
PanedWindowProcessFunction<K,W extends Window> |
|
PatternProcessFunctionRunner |
A PatternProcessFunction wrapper to delegate invocation to the code generated PatternProcessFunction .
|
PercentileAggFunction<T> |
Built-in PERCENTILE aggregate function.
|
PercentileAggFunction.MultiPercentileAggFunction |
Percentile agg function with multiple percentage parameters.
|
PercentileAggFunction.PercentileAccumulator |
Accumulator for PERCENTILE.
|
PercentileAggFunction.SinglePercentileAggFunction |
Percentile agg function with only one percentage parameter.
|
PeriodicWatermarkAssignerWrapper |
Generates periodic watermarks based on a PeriodicWatermarkAssigner .
|
PerKeyStateDataViewStore |
Default implementation of StateDataViewStore that currently forwards state registration
to a RuntimeContext .
|
PerWindowStateDataViewStore |
An implementation of StateDataViewStore for window aggregates which forwards the state
registration to an underlying KeyedStateBackend .
|
PlannerTypeUtils |
Utilities for LogicalType and DataType ..
|
PostProcessAdaptiveJoinStrategy |
The post-processing phase of adaptive join optimization, which must be placed at the end of all
adaptive join optimization strategies.
|
PrintfFunction |
Implementation of BuiltInFunctionDefinitions.PRINTF .
|
ProbeIterator |
Probe iterator from probe or spilled partition.
|
ProcessingTimeTriggers |
A Trigger that reacts to processing-time timers.
|
ProcessingTimeTriggers.AfterEndOfWindow<W extends Window> |
A Trigger that fires once the current system time passes the end of the window to
which a pane belongs.
|
ProcessingTimeTriggers.AfterEndOfWindowNoLate<W extends Window> |
A composite Trigger that consist of AfterEndOfWindow and a early trigger.
|
ProcessingTimeTriggers.AfterFirstElementPeriodic<W extends Window> |
Trigger every a given interval, the first trigger time is interval after the first element in
the pane.
|
ProctimeAttribute |
Deprecated.
|
ProcTimeDeduplicateKeepFirstRowFunction |
This function is used to deduplicate on keys and keeps only first row.
|
ProcTimeDeduplicateKeepLastRowFunction |
This function is used to deduplicate on keys and keeps only last row.
|
ProcTimeIntervalJoin |
The function to execute processing time interval stream inner-join.
|
ProcTimeMiniBatchAssignerOperator |
A stream operator that emits mini-batch marker in a given period.
|
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction |
This function is used to get the first row for every key partition in miniBatch mode.
|
ProcTimeMiniBatchDeduplicateKeepLastRowFunction |
This function is used to get the last row for every key partition in miniBatch mode.
|
ProcTimeRangeBoundedPrecedingFunction<K> |
Process Function used for the aggregate in bounded proc-time OVER window.
|
ProcTimeRowsBoundedPrecedingFunction<K> |
Process Function for ROW clause processing-time bounded OVER window.
|
ProcTimeSortOperator |
Sort on proc-time and additional secondary sort attributes.
|
ProcTimeUnboundedPrecedingFunction<K> |
Process Function for processing-time unbounded OVER window.
|
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.
|
PunctuatedWatermarkStrategyWrapper |
Generates periodic watermarks based on a PunctuatedWatermarkAssigner .
|
RangeSlidingOverFrame |
The range sliding window frame calculates frames with the following SQL form: ...
|
RangeUnboundedFollowingOverFrame |
The range unboundedFollowing window frame calculates frames with the following SQL form: ...
|
RangeUnboundedPrecedingOverFrame |
The range UnboundPreceding window frame calculates frames with the following SQL form: ...
|
RankOperator |
Rank operator to compute top N.
|
RankRange |
RankRange for Rank, including following 3 types : ConstantRankRange, ConstantRankRangeWithoutEnd,
VariableRankRange.
|
RankType |
An enumeration of rank type, usable to show how exactly generate rank number.
|
RawByteArrayConverter<T> |
Converter for RawType of byte[] external type.
|
RawFormatDeserializationSchema |
Deserialization schema from raw (byte based) value to Flink Table/SQL internal data structure
RowData .
|
RawFormatFactory |
Format factory for raw format which allows to read and write raw (byte based) values as a single
column.
|
RawFormatOptions |
Options for the "raw" format.
|
RawFormatSerializationSchema |
Serialization schema that serializes an RowData object into raw (byte based) value.
|
RawObjectConverter<T> |
Converter for RawType of object external type.
|
RawValueDataSerializer<T> |
Serializer for RawValueData .
|
RawValueDataSerializer.RawValueDataSerializerSnapshot<T> |
|
RecordComparator |
|
RecordCounter |
The RecordCounter is used to count the number of input records under the current key.
|
RecordEqualiser |
Record equaliser for RowData which can compare two RowData and returns whether they are equal.
|
RecordsCombiner |
|
RecordsCombiner.Factory |
|
RecordsCombiner.LocalFactory |
A factory that creates a RecordsCombiner used for combining at local stage.
|
RecordsWindowBuffer |
|
RecordsWindowBuffer.Factory |
|
RecordsWindowBuffer.LocalFactory |
|
RegexpCountFunction |
Implementation of BuiltInFunctionDefinitions.REGEXP_COUNT .
|
RegexpExtractAllFunction |
Implementation of BuiltInFunctionDefinitions.REGEXP_EXTRACT_ALL .
|
RegexpInstrFunction |
Implementation of BuiltInFunctionDefinitions.REGEXP_INSTR .
|
RegexpSubstrFunction |
Implementation of BuiltInFunctionDefinitions.REGEXP_SUBSTR .
|
ReloadTriggerContext |
Runtime implementation of CacheReloadTrigger.Context .
|
ReplicateRowsFunction |
Replicate the row N times.
|
ResettableExternalBuffer |
A resettable external buffer for binary row.
|
ResettableRowBuffer |
Resettable buffer that add RowData and return BinaryRowData iterator.
|
ResettableRowBuffer.ResettableIterator |
Row iterator that can be reset.
|
ResultRetryStrategy |
A utility class to wrap the data stream api AsyncRetryStrategy to support both sync and
async retry in table module.
|
RetractableTopNFunction |
A TopN function could handle updating stream.
|
RetryableAsyncLookupFunctionDelegator |
A delegator holds user's AsyncLookupFunction to handle retries.
|
RetryableLookupFunctionDelegator |
A delegator holds user's LookupFunction to handle retries.
|
RetryPredicates |
Contains retry predicates used to determine if a result or error should result in a retry.
|
RetryPredicates.AnyExceptionStrategy |
Returns true for any exception.
|
RetryPredicates.EmptyResponseResultStrategy |
Returns true if the response is null or empty.
|
RowDataCustomStreamPartitioner |
The partitioner used to partition row data by the connector's custom logic.
|
RowDataEventComparator |
|
RowDataKeySelector |
RowDataKeySelector takes an RowData and extracts the deterministic key for the RowData.
|
RowDataSerializer |
Serializer for RowData .
|
RowDataSerializer.RowDataSerializerSnapshot |
|
RowDataUtil |
Utilities for RowData .
|
RowIterator<T extends org.apache.flink.table.data.RowData> |
An internal iterator interface which presents a more restrictive API than Iterator .
|
RowKindSetter |
An operator that sets the row kind of the incoming records to a specific row kind.
|
RowRowConverter |
Converter for RowType of Row external type.
|
RowSlidingOverFrame |
The row sliding window frame calculates frames with the following SQL form: ...
|
RowtimeAttribute |
Deprecated.
|
RowTimeDeduplicateFunction |
This function is used to deduplicate on keys and keeps only first or last row on row time.
|
RowTimeDeduplicateFunctionHelper |
|
RowTimeDeduplicateRecordsCombiner |
An implementation of RecordsCombiner that stores the first/last records of incremental
input records into the window state.
|
RowTimeDeduplicateRecordsCombiner.Factory |
|
RowTimeIntervalJoin |
The function to execute row(event) time interval stream inner-join.
|
RowTimeMiniBatchAssginerOperator |
A stream operator that emits watermark in a given event-time interval.
|
RowTimeMiniBatchDeduplicateFunction |
This function is used to get the first or last row for every key partition in miniBatch mode.
|
RowTimeMiniBatchLatestChangeDeduplicateFunction |
This function is used to get the first or last row for every key partition in miniBatch mode.
|
RowTimeRangeBoundedPrecedingFunction<K> |
Process Function for RANGE clause event-time bounded OVER window.
|
RowTimeRangeUnboundedPrecedingFunction<K> |
A ProcessFunction to support unbounded RANGE window.
|
RowTimeRowsBoundedPrecedingFunction<K> |
Process Function for ROWS clause event-time bounded OVER window.
|
RowTimeRowsUnboundedPrecedingFunction<K> |
A ProcessFunction to support unbounded ROWS window.
|
RowTimeSortOperator |
Sort based on event-time and possibly additional secondary sort attributes.
|
RowTimeSyncStateWindowDeduplicateProcessor |
A rowtime window deduplicate processor.
|
RowTimeWindowDeduplicateOperatorBuilder |
|
RowUnboundedFollowingOverFrame |
The row unboundedFollowing window frame calculates frames with the following SQL form: ...
|
RowUnboundedPrecedingOverFrame |
The row UnboundPreceding window frame calculates frames with the following SQL form: ...
|
RuntimeFilterUtils |
Utilities for runtime filter.
|
ScanRuntimeProviderContext |
Implementation of DynamicTableSource.Context .
|
ScriptTransformIOInfo |
The wrapper class of the input/out schema for script transform.
|
SecondInputOfTwoInput |
Input for the second input of TwoInputStreamOperator .
|
SecondInputOfTwoInputStreamOperatorOutput |
An Output that can be used to emit elements and other messages for the second input of
TwoInputStreamOperator .
|
SegmentsUtil |
Util for data format segments calc.
|
SessionWindowAssigner |
|
ShortHashSet |
Short hash set.
|
SimpleGauge<T> |
A Simple gauge providing method for value updating.
|
SingleElementIterator<E> |
Copied from SingleElementIterator .
|
SinkOperator |
A StreamOperator for executing SinkFunctions .
|
SinkRuntimeProviderContext |
Implementation of DynamicTableSink.Context .
|
SinkUpsertMaterializer |
An operator that maintains incoming records in state corresponding to the upsert keys and
generates an upsert view for the downstream operator.
|
SliceAssigner |
|
SliceAssigners |
|
SliceAssigners.CumulativeSliceAssigner |
|
SliceAssigners.HoppingSliceAssigner |
|
SliceAssigners.SlicedSharedSliceAssigner |
The SliceAssigner for elements have been attached slice end timestamp, and the slices
are shared.
|
SliceAssigners.SlicedUnsharedSliceAssigner |
The SliceAssigner for elements have been attached slice end timestamp, but the slices
are not shared, i.e. the assigned slice is equal to the final window.
|
SliceAssigners.TumblingSliceAssigner |
|
SliceAssigners.WindowedSliceAssigner |
The SliceAssigner for elements have been attached window start and end timestamps.
|
SliceEnd |
Deprecated.
|
SliceSharedAssigner |
A SliceAssigner which shares slices for windows, which means a window is divided into
multiple slices and need to merge the slices into windows when emitting windows.
|
SliceSharedSyncStateWindowAggProcessor |
|
SliceUnsharedAssigner |
A SliceAssigner which doesn't share slices for windows, which means a window is divided
into only one slice and doesn't need to merge the slices when emitting windows.
|
SliceUnsharedSyncStateWindowAggProcessor |
|
SlicingSyncStateWindowProcessor<W> |
|
SlicingWindowTimerServiceImpl |
|
SlidingOverFrame |
The sliding window frame.
|
SlidingWindowAssigner |
A GroupWindowAssigner that windows elements into sliding windows based on the timestamp
of the elements.
|
SortedMapSerializer<K,V> |
|
SortedMapSerializerSnapshot<K,V> |
|
SortedMapTypeInfo<K,V> |
The type information for sorted maps.
|
SortLimitOperator |
Operator for batch sort limit.
|
SortMergeFullOuterJoinIterator |
Gets two matched rows for full outer join.
|
SortMergeInnerJoinIterator |
Gets probeRow and match rows for inner join.
|
SortMergeJoinFunction |
This function is used to process the main logic of sort merge join.
|
SortMergeJoinIterator |
Gets probeRow and match rows for inner/left/right join.
|
SortMergeJoinOperator |
An implementation that realizes the joining through a sort-merge join strategy. 1.In most cases,
its performance is weaker than HashJoin. 2.It is more stable than HashJoin, and most of the data
can be sorted stably. 3.SortMergeJoin should be the best choice if sort can be omitted in the
case of multi-level join cascade with the same key.
|
SortMergeOneSideOuterJoinIterator |
Gets probeRow and match rows for left/right join.
|
SortOperator |
Operator for batch sort.
|
SortUtil |
Util for sort.
|
SourceWatermarkFunction |
Implementation of BuiltInFunctionDefinitions.SOURCE_WATERMARK .
|
SpillChannelManager |
Channel manager to manage the life cycle of spill channels.
|
SplitFunction |
Implementation of BuiltInFunctionDefinitions.SPLIT .
|
SqlDriver |
Driver to load the ScriptRunner and execute the script.
|
SqlFunctionUtils |
Built-in scalar runtime functions.
|
SqlJsonUtils |
Utilities for JSON functions.
|
SqlJsonUtils.JsonQueryReturnType |
|
SqlJsonUtils.PathMode |
Path spec has two different modes: lax mode and strict mode.
|
SqlLikeChainChecker |
String Like util: Matches a chained sequence of checkers.
|
StartsWithFunction |
Implementation of BuiltInFunctionDefinitions.STARTS_WITH .
|
StateConfigUtil |
Utility to create a StateTtlConfig object.
|
StateDataView<N> |
A DataView which is implemented using state backend.
|
StateDataViewStore |
This interface contains methods for registering StateDataView with a managed store.
|
StateKeyContext |
Context to switch current key in state backend.
|
StateListView<N,EE> |
StateListView is a ListView which is implemented using state backends.
|
StateListView.KeyedStateListView<N,T> |
|
StateListView.NamespacedStateListView<N,T> |
|
StateMapView<N,EK,EV> |
MapView which is implemented using state backends.
|
StateMapView.KeyedStateMapViewWithKeysNotNull<N,EK,EV> |
A state MapView which does not support nullable keys and namespace.
|
StateMapView.KeyedStateMapViewWithKeysNullable<N,EK,EV> |
A state MapView which supports nullable keys but does not support namespace.
|
StateMapView.NamespacedStateMapViewWithKeysNotNull<N,EK,EV> |
A state MapView which supports namespace but does not support nullable keys.
|
StateMapView.NamespacedStateMapViewWithKeysNullable<N,EK,EV> |
A state MapView which supports nullable keys and namespace.
|
StreamingJoinOperator |
Streaming unbounded Join operator which supports INNER/LEFT/RIGHT/FULL JOIN.
|
StreamingSemiAntiJoinOperator |
Streaming unbounded Join operator which supports SEMI/ANTI JOIN.
|
StreamRecordCollector<T> |
Wrapper around an Output for wrap T to StreamRecord .
|
StreamRecordTimestampInserter |
Operator which sets the timestamp on the StreamRecord from the corresponding column of each row.
|
StreamSortOperator |
Operator for stream sort.
|
StringByteArrayConverter |
Converter for CharType /VarCharType of byte[] external type.
|
StringDataSerializer |
Serializer for StringData .
|
StringDataSerializer.StringDataSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
StringDataTypeInfo |
TypeInformation for StringData .
|
StringStringConverter |
Converter for CharType / VarCharType of String external type.
|
StringUtf8Utils |
String utf-8 utils.
|
StructuredObjectConverter<T> |
Converter for StructuredType of its implementation class.
|
SyncStateWindowProcessor<W> |
A processor that processes elements for windows.
|
SyncStateWindowProcessor.SyncStateContext<W> |
|
SyncStateWindowRankProcessor |
A rowtime window rank processor.
|
TableAggregateWindowOperator<K,W extends Window> |
|
TableAggsHandleFunction |
The base class for handling table aggregate functions.
|
TableFunctionCollector<T> |
The basic implementation of collector for TableFunction .
|
TableFunctionResultFuture<T> |
The basic implementation of collector for ResultFuture in table joining.
|
TableOperatorWrapper<OP extends org.apache.flink.streaming.api.operators.StreamOperator<org.apache.flink.table.data.RowData>> |
This class handles the close, endInput and other related logic of a StreamOperator .
|
TableOperatorWrapper.Edge |
|
TableOperatorWrapperGenerator |
|
TableStreamOperator<OUT> |
Table operator to invoke close always.
|
TemporalProcessTimeJoinOperator |
The operator to temporal join a stream on processing time.
|
TemporalRowTimeJoinOperator |
The operator for temporal join (FOR SYSTEM_TIME AS OF o.rowtime) on row time, it has no
limitation about message types of the left input and right input, this means the operator deals
changelog well.
|
TimeLocalTimeConverter |
Converter for TimeType of LocalTime external type.
|
TimeLongConverter |
Converter for TimeType of Long external type.
|
TimestampDataSerializer |
Serializer for TimestampData .
|
TimestampDataSerializer.TimestampDataSerializerSnapshot |
|
TimestampDataTypeInfo |
TypeInformation for TimestampData .
|
TimestampLocalDateTimeConverter |
|
TimestampTimestampConverter |
Converter for TimestampType of Timestamp external type.
|
TimeTimeConverter |
Converter for TimeType of Time external type.
|
TimeWindow |
A Window that represents a time interval from start (inclusive) to end
(exclusive).
|
TimeWindow.Serializer |
The serializer used to write the TimeWindow type.
|
TimeWindow.Serializer.TimeWindowSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
TimeWindowUtil |
Time util to deals window start and end in different timezone.
|
TopNBuffer |
TopNBuffer stores mapping from sort key to records list, sortKey is RowData type, each record is
RowData type.
|
TopNBufferCacheRemovalListener<V> |
A common cache removal listener for rank node.
|
TopNRecordsCombiner |
An implementation of RecordsCombiner that save topN records of incremental input records
into the window state.
|
TopNRecordsCombiner.Factory |
|
ToTimestampLtzFunction |
Implementation of BuiltInFunctionDefinitions.TO_TIMESTAMP_LTZ .
|
TranslateFunction |
Implementation of BuiltInFunctionDefinitions.TRANSLATE .
|
Trigger<W extends Window> |
A Trigger determines when a pane of a window should be evaluated to emit the results for
that part of the window.
|
Trigger.OnMergeContext |
|
Trigger.TriggerContext |
A context object that is given to Trigger methods to allow them to register timer
callbacks and deal with state.
|
TumblingWindowAssigner |
A GroupWindowAssigner that windows elements into fixed-size windows based on the
timestamp of the elements.
|
TypeCheckUtils |
Utils for type.
|
TypeInfoDataTypeConverter |
Deprecated.
|
TypeInfoLogicalTypeConverter |
Deprecated. |
TypeOfFunction |
Implementation of BuiltInFunctionDefinitions.TYPE_OF .
|
UnalignedWindowTableFunctionOperator |
The operator for unaligned window table function.
|
UnboundedFollowingOverFrame |
The UnboundedFollowing window frame.
|
UnboundedOverWindowFrame |
The unbounded window frame calculates frames with the following SQL forms: ...
|
UnboundedPrecedingOverFrame |
The UnboundedPreceding window frame.
|
UnhexFunction |
Implementation of BuiltInFunctionDefinitions.UNHEX .
|
UnionStreamOperator |
|
UnnestRowsFunction |
Flattens ARRAY, MAP, and MULTISET using a table function.
|
UnnestRowsFunction.CollectionUnnestTableFunction |
Table function that unwraps the elements of a collection (array or multiset).
|
UnnestRowsFunction.MapUnnestTableFunction |
Table function that unwraps the elements of a map.
|
UnsliceAssigner<W extends Window> |
A UnsliceAssigner assigns each element into a single window and not divides the window
into finite number of non-overlapping slice.
|
UnsliceAssigners |
|
UnsliceAssigners.SessionUnsliceAssigner |
|
UnsliceAssigners.WindowedUnsliceAssigner |
The UnsliceAssigner for elements have been merged into unslicing windows and attached
window start and end timestamps.
|
UnsliceSyncStateWindowAggProcessor |
An window aggregate processor implementation which works for UnsliceAssigner , e.g.
|
UnslicingSyncStateWindowProcessor<W> |
|
UnslicingWindowTimerServiceImpl |
|
UnsupportedStateDataViewStore |
|
UpdatableRowData |
An implementation of RowData which is backed by a RowData and an updated Java
object array.
|
UpdatableTopNFunction |
A TopN function could handle updating stream.
|
UrlDecodeFunction |
Implementation of BuiltInFunctionDefinitions.URL_DECODE .
|
UrlEncodeFunction |
Implementation of BuiltInFunctionDefinitions.URL_ENCODE .
|
ValuesInputFormat |
Generated ValuesInputFormat.
|
VariableRankRange |
changing rank limit depends on input.
|
WatermarkAssignerOperator |
A stream operator that extracts timestamps from stream elements and generates periodic
watermarks.
|
WatermarkAssignerOperatorFactory |
|
WatermarkGenerator |
|
WatermarkGeneratorCodeGeneratorFunctionContextWrapper |
A function wrapper for FunctionContext if the source supports SupportsWatermarkPushDown .
|
Window |
A Window is a grouping of elements into finite buckets.
|
WindowAggOperator<K,W> |
We divide windows into 2 categories: Aligned Windows and Unaligned Windows.
|
WindowAggOperatorBuilder |
|
WindowAggProcessorBase<W,C extends WindowProcessor.Context<W>> |
|
WindowAssigner |
WindowAssigner is used to assign windows to elements.
|
WindowAsyncState<W> |
A base interface for manipulate async state with window namespace.
|
WindowAsyncState<W> |
A base interface for manipulate state with window namespace.
|
WindowAsyncValueState<W> |
A wrapper of ValueState which is easier to update based on window namespace.
|
WindowBuffer |
A buffer that buffers data in memory and flushes many values to state together at a time to avoid
frequently accessing state, or flushes to output to reduce shuffling data.
|
WindowBuffer.Factory |
|
WindowBuffer.LocalFactory |
|
WindowBytesHashMap |
A binary map in the structure like Map<WindowKey, BinaryRowData> .
|
WindowBytesMultiMap |
A binary map in the structure like Map<WindowKey, List<BinaryRowData>> .
|
WindowEnd |
Deprecated.
|
WindowJoinHelper |
|
WindowJoinOperator |
A streaming window join operator implemented by sync state api.
|
WindowJoinOperatorBuilder |
|
WindowKey |
The WindowKey structure represents a combination of key and window.
|
WindowKeySerializer |
Serializer for WindowKey which is composite with a BinaryRowData and a long
value.
|
WindowKeySerializer.WindowKeySerializerSnapshot |
|
WindowListAsyncState<W> |
A wrapper of ListState which is easier to update based on window namespace.
|
WindowListState<W> |
A wrapper of ListState which is easier to update based on window namespace.
|
WindowMapState<W,UV> |
A wrapper of MapState which is easier to update based on window namespace.
|
WindowOperator<K,W extends Window> |
|
WindowOperatorBuilder |
|
WindowOperatorBuilder.AggregateWindowOperatorBuilder |
|
WindowOperatorBuilder.TableAggregateWindowOperatorBuilder |
|
WindowProcessor<W,C extends WindowProcessor.Context<W>> |
|
WindowProcessor.Context<W> |
|
WindowProperty |
Deprecated.
|
WindowRankOperatorBuilder |
|
WindowReference |
Deprecated.
|
WindowsGrouping |
Assigning windows from the sorted input buffers.
|
WindowStart |
Deprecated.
|
WindowState<W> |
A base interface for manipulate state with window namespace.
|
WindowTableFunctionOperatorBase |
|
WindowTimerService<W> |
Interface for working with window time and timers which considers timezone for window splitting.
|
WindowTimerServiceBase<W> |
|
WindowTrigger<W extends Window> |
A WindowTrigger determines when a window should be evaluated to emit the results.
|
WindowValueState<W> |
A wrapper of ValueState which is easier to update based on window namespace.
|
WrappedRowIterator<T extends org.apache.flink.table.data.RowData> |
|
WrappingCollector<T> |
A Collector that wraps another collector.
|
XXH64 |
xxHash64.
|
YearMonthIntervalPeriodConverter |
Converter for YearMonthIntervalType of Period external type.
|