A B C D E F G H I J K L M N O P Q R S T U V W X Y
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- abs(byte) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ABS
operator applied to byte values. - abs(double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ABS
operator applied to double values. - abs(float) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ABS
operator applied to float values. - abs(int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ABS
operator applied to int values. - abs(long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ABS
operator applied to long values. - abs(short) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ABS
operator applied to short values. - abs(DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- abs(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- AbstractAsyncStateSliceWindowAggProcessor - Class in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors
-
A base implementation of
AsyncStateSlicingWindowProcessor
for window aggregate. - AbstractAsyncStateSliceWindowAggProcessor(GeneratedNamespaceAggsHandleFunction<Long>, AsyncStateWindowBuffer.Factory, SliceAssigner, TypeSerializer<RowData>, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- AbstractAsyncStateStreamingJoinOperator - Class in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing
-
Abstract implementation for streaming unbounded Join operator based on async state api, which defines some member fields can be shared between different implementations.
- AbstractAsyncStateStreamingJoinOperator(InternalTypeInfo<RowData>, InternalTypeInfo<RowData>, GeneratedJoinCondition, JoinInputSideSpec, JoinInputSideSpec, boolean[], long, long) - Constructor for class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- AbstractAsyncStateTopNFunction - Class in org.apache.flink.table.runtime.operators.rank.async
-
Base class for TopN Function with async state api.
- AbstractAsyncStateTopNFunction(StateTtlConfig, InternalTypeInfo<RowData>, GeneratedRecordComparator, RowDataKeySelector, RankType, RankRange, boolean, boolean) - Constructor for class org.apache.flink.table.runtime.operators.rank.async.AbstractAsyncStateTopNFunction
- AbstractAsyncStateWindowAggProcessor<W> - Class in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors
-
A base class for window aggregate processors with async state.
- AbstractAsyncStateWindowAggProcessor(GeneratedNamespaceAggsHandleFunction<W>, WindowAssigner, TypeSerializer<RowData>, boolean, int, ZoneId, W) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateWindowAggProcessor
- AbstractAsyncStateWindowAggProcessor.WindowIsEmptyChecker - Class in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors
-
A checker that checks whether the window is empty.
- AbstractBinaryExternalMerger<Entry> - Class in org.apache.flink.table.runtime.operators.sort
-
Spilled files Merger of
BinaryExternalSorter
. - AbstractBinaryExternalMerger(IOManager, int, int, SpillChannelManager, boolean, BlockCompressionFactory, int) - Constructor for class org.apache.flink.table.runtime.operators.sort.AbstractBinaryExternalMerger
- AbstractBytesHashMap<K> - Class in org.apache.flink.table.runtime.util.collections.binary
-
Bytes based hash map.
- AbstractBytesHashMap(Object, MemoryManager, long, PagedTypeSerializer<K>, int) - Constructor for class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
- AbstractBytesHashMap(Object, MemoryManager, long, PagedTypeSerializer<K>, LogicalType[]) - Constructor for class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
- AbstractBytesMultiMap<K> - Class in org.apache.flink.table.runtime.util.collections.binary
-
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. - AbstractBytesMultiMap(Object, MemoryManager, long, PagedTypeSerializer<K>, int) - Constructor for class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
- AbstractBytesMultiMap(Object, MemoryManager, long, PagedTypeSerializer<K>, LogicalType[]) - Constructor for class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
- AbstractMapBundleOperator<K,V,IN,OUT> - Class in org.apache.flink.table.runtime.operators.bundle
-
The
AbstractMapBundleOperator
simply used a java Map to store the input elements in key-value form. - AbstractRowDataConverter(DataType[]) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.AbstractRowDataConverter
- AbstractRowDataSerializer<T extends org.apache.flink.table.data.RowData> - Class in org.apache.flink.table.runtime.typeutils
-
Row serializer, provided paged serialize paged method.
- AbstractRowDataSerializer() - Constructor for class org.apache.flink.table.runtime.typeutils.AbstractRowDataSerializer
- AbstractRowTimeUnboundedPrecedingOver<K> - Class in org.apache.flink.table.runtime.operators.over
-
A basic implementation to support unbounded event-time over-window.
- AbstractRowTimeUnboundedPrecedingOver(long, long, GeneratedAggsHandleFunction, LogicalType[], LogicalType[], int) - Constructor for class org.apache.flink.table.runtime.operators.over.AbstractRowTimeUnboundedPrecedingOver
- AbstractSliceSyncStateWindowAggProcessor - Class in org.apache.flink.table.runtime.operators.aggregate.window.processors
-
A base implementation of
SlicingSyncStateWindowProcessor
for window aggregate. - AbstractSliceSyncStateWindowAggProcessor(GeneratedNamespaceAggsHandleFunction<Long>, WindowBuffer.Factory, SliceAssigner, TypeSerializer<RowData>, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- AbstractStreamingJoinOperator - Class in org.apache.flink.table.runtime.operators.join.stream
-
Abstract implementation for streaming unbounded Join operator which defines some member fields can be shared between different implementations.
- AbstractStreamingJoinOperator(InternalTypeInfo<RowData>, InternalTypeInfo<RowData>, GeneratedJoinCondition, JoinInputSideSpec, JoinInputSideSpec, boolean[], long, long) - Constructor for class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- AbstractSyncStateTopNFunction - Class in org.apache.flink.table.runtime.operators.rank
-
Base class for TopN Function with sync state api.
- AbstractSyncStateTopNFunction(StateTtlConfig, InternalTypeInfo<RowData>, GeneratedRecordComparator, RowDataKeySelector, RankType, RankRange, boolean, boolean) - Constructor for class org.apache.flink.table.runtime.operators.rank.AbstractSyncStateTopNFunction
- AbstractSyncStateWindowAggProcessor<W> - Class in org.apache.flink.table.runtime.operators.aggregate.window.processors
-
A base class for window aggregate processors.
- AbstractSyncStateWindowAggProcessor(GeneratedNamespaceAggsHandleFunction<W>, WindowAssigner, TypeSerializer<RowData>, boolean, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSyncStateWindowAggProcessor
- AbstractSyncStateWindowAggProcessor.WindowIsEmptySupplier - Class in org.apache.flink.table.runtime.operators.aggregate.window.processors
-
A supplier that returns whether the window is empty.
- AbstractTopNFunction - Class in org.apache.flink.table.runtime.operators.rank
-
Base class for TopN Function.
- AbstractTopNFunction(StateTtlConfig, InternalTypeInfo<RowData>, GeneratedRecordComparator, RowDataKeySelector, RankType, RankRange, boolean, boolean) - Constructor for class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- AbstractTopNFunction.AbstractTopNHelper - Class in org.apache.flink.table.runtime.operators.rank
-
An abstract helper to do the logic Top-n used for all top-n functions.
- AbstractTopNHelper(AbstractTopNFunction) - Constructor for class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- AbstractWindowProperty - Class in org.apache.flink.table.runtime.groupwindow
-
Deprecated.The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.
- AbstractWindowProperty(WindowReference) - Constructor for class org.apache.flink.table.runtime.groupwindow.AbstractWindowProperty
-
Deprecated.
- accept(Object, Throwable) - Method in class org.apache.flink.table.runtime.operators.calc.async.DelegatingAsyncResultFuture
- accept(Collection<OUT>, Throwable) - Method in class org.apache.flink.table.runtime.operators.join.lookup.DelegatingResultFuture
- accept(W, Collection<W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowProcessFunction.DefaultAccMergingConsumer
- accHitCount() - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- accRequestCount() - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- accSerializer - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- accTypes - Variable in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
-
The accumulator types.
- accumulate(GenericRowData, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- accumulate(GenericRowData, StringData, Long) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- accumulate(RowData) - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunctionBase
-
Accumulates the input values to the accumulators.
- accumulate(RowData) - Method in interface org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunctionBase
-
Accumulates the input values to the accumulators.
- accumulate(RowData, Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- accumulate(RowData, Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- accumulate(RowData, Object, Long) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- accumulate(RowData, Object, Long) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- accumulate(RowData, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- accumulate(RowData, StringData, Long) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- accumulate(ArrayAggFunction.ArrayAggAccumulator<T>, T) - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction
- accumulate(CollectAggFunction.CollectAccumulator<T>, T) - Method in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction
- accumulate(FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T>, Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- accumulate(FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T>, Object, Long) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- accumulate(FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T>, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- accumulate(FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T>, StringData, Long) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- accumulate(HllBuffer, Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction
- accumulate(JsonArrayAggFunction.Accumulator, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction
- accumulate(JsonObjectAggFunction.Accumulator, StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction
- accumulate(LagAggFunction.LagAcc<T>, T) - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction
- accumulate(LagAggFunction.LagAcc<T>, T, int) - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction
- accumulate(LagAggFunction.LagAcc<T>, T, int, T) - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction
- accumulate(LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T>, Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- accumulate(LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T>, Object, Long) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- accumulate(LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T>, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- accumulate(LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T>, StringData, Long) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- accumulate(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction
- accumulate(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator, StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
- accumulate(MaxWithRetractAggFunction.MaxWithRetractAccumulator<T>, T) - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction
- accumulate(MinWithRetractAggFunction.MinWithRetractAccumulator<T>, T) - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction
- accumulate(PercentileAggFunction.PercentileAccumulator, Object, Double) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- accumulate(PercentileAggFunction.PercentileAccumulator, Object, Double[]) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- accumulate(PercentileAggFunction.PercentileAccumulator, Object, Double[], Number) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- accumulate(PercentileAggFunction.PercentileAccumulator, Object, Double, Number) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- Accumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction.Accumulator
- Accumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction.Accumulator
- accumulatorTypes - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- acos(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- actualSize - Variable in class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
- AdaptiveBroadcastJoinOptimizationStrategy - Class in org.apache.flink.table.runtime.strategy
-
The stream graph optimization strategy of adaptive broadcast join.
- AdaptiveBroadcastJoinOptimizationStrategy() - Constructor for class org.apache.flink.table.runtime.strategy.AdaptiveBroadcastJoinOptimizationStrategy
- AdaptiveJoin - Interface in org.apache.flink.table.runtime.operators.join.adaptive
-
Interface for implementing an adaptive join operator.
- AdaptiveJoinOperatorFactory<OUT> - Class in org.apache.flink.table.runtime.operators.join.adaptive
-
Adaptive join factory.
- AdaptiveJoinOperatorFactory(byte[]) - Constructor for class org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoinOperatorFactory
- AdaptiveJoinOptimizationUtils - Class in org.apache.flink.table.runtime.strategy
-
Utils for adaptive join optimization strategies.
- AdaptiveJoinOptimizationUtils() - Constructor for class org.apache.flink.table.runtime.strategy.AdaptiveJoinOptimizationUtils
- AdaptiveSkewedJoinOptimizationStrategy - Class in org.apache.flink.table.runtime.strategy
-
The stream graph optimization strategy of adaptive skewed join.
- AdaptiveSkewedJoinOptimizationStrategy() - Constructor for class org.apache.flink.table.runtime.strategy.AdaptiveSkewedJoinOptimizationStrategy
- add(byte) - Method in class org.apache.flink.table.runtime.util.collections.ByteHashSet
- add(double) - Method in class org.apache.flink.table.runtime.util.collections.DoubleHashSet
- add(float) - Method in class org.apache.flink.table.runtime.util.collections.FloatHashSet
-
See
Float.equals(Object)
. - add(int) - Method in class org.apache.flink.table.runtime.util.collections.IntHashSet
- add(long) - Method in class org.apache.flink.table.runtime.util.collections.LongHashSet
- add(short) - Method in class org.apache.flink.table.runtime.util.collections.ShortHashSet
- add(EE) - Method in class org.apache.flink.table.runtime.dataview.StateListView
- add(DecimalData, DecimalData, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- add(RowData) - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
- add(RowData) - Method in interface org.apache.flink.table.runtime.util.ResettableRowBuffer
-
Appends the specified row to the end of this buffer.
- add(T) - Method in class org.apache.flink.table.runtime.util.collections.ObjectHashSet
- add(W, RowData) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowListState
-
Updates the operator state accessible by
#get(W)
by adding the given value to the list of values. - addAll(List<EE>) - Method in class org.apache.flink.table.runtime.dataview.StateListView
- addBinaryLengthConstraint(ExecutionConfigOptions.TypeLengthEnforcer, List<ConstraintEnforcer.FieldInfo>, List<String>, String[]) - Method in class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer.Builder
- addChannel(FileIOChannel.ID) - Method in class org.apache.flink.table.runtime.operators.sort.SpillChannelManager
-
Add a new File channel.
- addCharLengthConstraint(ExecutionConfigOptions.TypeLengthEnforcer, List<ConstraintEnforcer.FieldInfo>, List<String>, String[]) - Method in class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer.Builder
- addElement(RowData, long, RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateRecordsWindowBuffer
- addElement(RowData, long, RowData) - Method in interface org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateWindowBuffer
-
Adds an element with associated key into the buffer.
- addElement(RowData, long, RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.buffers.RecordsWindowBuffer
- addElement(RowData, long, RowData) - Method in interface org.apache.flink.table.runtime.operators.aggregate.window.buffers.WindowBuffer
-
Adds an element with associated key into the buffer.
- addInput(List<RowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchGroupAggFunction
- addInput(List<RowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.deduplicate.RowTimeMiniBatchDeduplicateFunction
- addInput(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchGlobalGroupAggFunction
-
The
previousAcc
is accumulator, but input is a row in <key, accumulator> schema, the specific generatedMiniBatchGlobalGroupAggFunction.localAgg
will project theinput
to accumulator in merge method. - addInput(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchIncrementalGroupAggFunction
- addInput(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchLocalGroupAggFunction
- addInput(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeMiniBatchDeduplicateKeepFirstRowFunction
- addInput(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeMiniBatchDeduplicateKeepLastRowFunction
- addInput(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.deduplicate.RowTimeMiniBatchLatestChangeDeduplicateFunction
- addInput(TableOperatorWrapper<?>, int) - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- addInput(V, IN) - Method in class org.apache.flink.table.runtime.operators.bundle.MapBundleFunction
-
Adds the given input to the given value, returning the new bundle value.
- addInputToBuffer(BinaryRowData) - Method in class org.apache.flink.table.runtime.operators.window.grouping.WindowsGrouping
- addIntoBuffer(BinaryRowData) - Method in class org.apache.flink.table.runtime.operators.window.grouping.HeapWindowsGrouping
- addIntoBuffer(BinaryRowData) - Method in class org.apache.flink.table.runtime.operators.window.grouping.WindowsGrouping
- addNotNullConstraint(ExecutionConfigOptions.NotNullEnforcer, int[], List<String>, String[]) - Method in class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer.Builder
- addNull() - Method in class org.apache.flink.table.runtime.util.collections.ByteHashSet
- addNull() - Method in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Add a null key.
- addOpenChannels(List<FileIOChannel>) - Method in class org.apache.flink.table.runtime.operators.sort.SpillChannelManager
-
Open File channels.
- addRecord(RowData) - Method in interface org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.JoinRecordAsyncStateView
-
Add a new record to the state view.
- addRecord(RowData) - Method in interface org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.OuterJoinRecordAsyncStateView
- addRecord(RowData) - Method in interface org.apache.flink.table.runtime.operators.join.stream.state.JoinRecordStateView
-
Add a new record to the state view.
- addRecord(RowData, int) - Method in interface org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.OuterJoinRecordAsyncStateView
-
Adds a new record with the number of associations to the state view.
- addRecord(RowData, int) - Method in interface org.apache.flink.table.runtime.operators.join.stream.state.OuterJoinRecordStateView
-
Adds a new record with the number of associations to the state view.
- addRecord(RowData, RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
-
Adds a record into the bufferBundle when processing element in a stream and this function would return the size of the bufferBundle.
- addRecord(RowData, RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.InputSideHasNoUniqueKeyBundle
-
The structure of the bundle: first-level key is the joinKey while the second-level key is the hash value of the record.
- addRecord(RowData, RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.InputSideHasUniqueKeyBundle
- addRecord(RowData, RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.JoinKeyContainsUniqueKeyBundle
- addRecord(STATE_VIEW, RowData) - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinHelper
- addRecordInOuterSide(OUTER_STATE_VIEW, RowData, int) - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinHelper
- addSynchronousResult(Object) - Method in class org.apache.flink.table.runtime.operators.calc.async.DelegatingAsyncResultFuture
- addWindow(W, MergingWindowSet.MergeFunction<W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowSet
-
Adds a new
Window
to the set of in-flight windows. - advanceNext() - Method in class org.apache.flink.table.runtime.hashtable.BuildSideIterator
- advanceNext() - Method in class org.apache.flink.table.runtime.hashtable.BuildSideIterator.BucketIterator
- advanceNext() - Method in class org.apache.flink.table.runtime.hashtable.LongHashPartition.MatchIterator
- advanceNext() - Method in class org.apache.flink.table.runtime.hashtable.LookupBucketIterator
- advanceNext() - Method in class org.apache.flink.table.runtime.hashtable.WrappedRowIterator
- advanceNext() - Method in interface org.apache.flink.table.runtime.util.KeyValueIterator
-
Advance this iterator by a single kv.
- advanceNext() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer.BufferIterator
- advanceNext() - Method in interface org.apache.flink.table.runtime.util.RowIterator
-
Advance this iterator by a single row.
- advanceNextSuitableBufferedRow() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- advanceNextSuitableProbeRow() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- advanceProgress(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.buffers.RecordsWindowBuffer
- advanceProgress(long) - Method in interface org.apache.flink.table.runtime.operators.aggregate.window.buffers.WindowBuffer
-
Advances the progress time, the progress time is watermark if working in event-time mode, or current processing time if working in processing-time mode.
- advanceProgress(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- advanceProgress(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.UnsliceSyncStateWindowAggProcessor
- advanceProgress(long) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.processors.RowTimeSyncStateWindowDeduplicateProcessor
- advanceProgress(long) - Method in class org.apache.flink.table.runtime.operators.rank.window.processors.SyncStateWindowRankProcessor
- advanceProgress(long) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.SyncStateWindowProcessor
-
Advances the progress time, the progress time is watermark if working in event-time mode, or current processing time if working in processing-time mode.
- advanceProgress(RowData, long) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateRecordsWindowBuffer
- advanceProgress(RowData, long) - Method in interface org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateWindowBuffer
-
Advances the progress time, the progress time is watermark if working in event-time mode, or current processing time if working in processing-time mode.
- advanceProgress(RowData, long) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- advanceProgress(RowData, long) - Method in interface org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowProcessor
-
Advances the progress time, the progress time is watermark if working in event-time mode, or current processing time if working in processing-time mode.
- advanceWatermarkToTriggerAllWindows() - Method in class org.apache.flink.table.runtime.operators.window.grouping.WindowsGrouping
-
Advance the watermark to trigger all the possible windows.
- afterEndOfWindow() - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers
-
Creates a trigger that fires when the watermark passes the end of the window.
- afterEndOfWindow() - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers
-
Creates a trigger that fires when the processing time passes the end of the window.
- AfterEndOfWindow() - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
- AfterEndOfWindow() - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindow
- afterGrow() - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- afterGrow() - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- AggCombiner - Class in org.apache.flink.table.runtime.operators.aggregate.window.combines
-
An implementation of
RecordsCombiner
that accumulates input records into the window accumulator state. - AggCombiner(WindowTimerService<Long>, StateKeyContext, WindowValueState<Long>, NamespaceAggsHandleFunction<Long>, boolean) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.combines.AggCombiner
- AggCombiner.Factory - Class in org.apache.flink.table.runtime.operators.aggregate.window.combines
-
Factory to create
AggCombiner
. - aggregate(GeneratedNamespaceAggsHandleFunction<?>, GeneratedRecordEqualiser, LogicalType[], LogicalType[], LogicalType[]) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- aggregate(GeneratedNamespaceAggsHandleFunction<?>, AbstractRowDataSerializer<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- aggregate(GeneratedNamespaceTableAggsHandleFunction<?>, LogicalType[], LogicalType[], LogicalType[]) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- aggregate(NamespaceAggsHandleFunction<?>, RecordEqualiser, LogicalType[], LogicalType[], LogicalType[]) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- aggregate(NamespaceTableAggsHandleFunction<?>, LogicalType[], LogicalType[], LogicalType[]) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- aggregate(LogicalType[], LogicalType[], LogicalType[]) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- AggregateWindowOperator<K,W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.operator
-
A
WindowOperator
for grouped window aggregates. - AggregateWindowOperatorBuilder(GeneratedNamespaceAggsHandleFunction<?>, GeneratedRecordEqualiser, WindowOperatorBuilder) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder.AggregateWindowOperatorBuilder
- AggregateWindowOperatorBuilder(NamespaceAggsHandleFunction<?>, RecordEqualiser, WindowOperatorBuilder) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder.AggregateWindowOperatorBuilder
- aggregator - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- aggResultTypes - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- AggsHandleFunction - Interface in org.apache.flink.table.runtime.generated
-
The base class for handling aggregate functions.
- AggsHandleFunctionBase - Interface in org.apache.flink.table.runtime.generated
-
The base class for handling aggregate or table aggregate functions.
- AlignedWindowTableFunctionOperator - Class in org.apache.flink.table.runtime.operators.window.tvf.operator
-
The operator for aligned window table function.
- AlignedWindowTableFunctionOperator(GroupWindowAssigner<TimeWindow>, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.operator.AlignedWindowTableFunctionOperator
- allocateReuseBytes(int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
Allocate bytes that is only for temporary usage, it should not be stored in somewhere else.
- allocateReuseChars(int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
- allocateSegments(int) - Method in class org.apache.flink.table.runtime.util.LazyMemorySegmentPool
- allowedLateness - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
- allowedLateness - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- ANTI - org.apache.flink.table.runtime.operators.join.FlinkJoinType
- ANTI - org.apache.flink.table.runtime.operators.join.HashJoinType
- ANY_EXCEPTION - Static variable in class org.apache.flink.table.runtime.operators.calc.async.RetryPredicates
- AnyExceptionStrategy() - Constructor for class org.apache.flink.table.runtime.operators.calc.async.RetryPredicates.AnyExceptionStrategy
- append(BytesMap.LookupInfo<K, Iterator<RowData>>, BinaryRowData) - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
-
Append an value into the hash map's record area.
- append(BytesMap.LookupInfo<K, BinaryRowData>, BinaryRowData) - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
-
Append an value into the hash map's record area.
- AppendOnlyFirstNFunction - Class in org.apache.flink.table.runtime.operators.rank
-
A variant of
AppendOnlyTopNFunction
to handle first-n case. - AppendOnlyFirstNFunction(StateTtlConfig, InternalTypeInfo<RowData>, GeneratedRecordComparator, RowDataKeySelector, RankType, RankRange, boolean, boolean) - Constructor for class org.apache.flink.table.runtime.operators.rank.AppendOnlyFirstNFunction
- AppendOnlyTopNFunction - Class in org.apache.flink.table.runtime.operators.rank
-
A TopN function could handle insert-only stream.
- AppendOnlyTopNFunction(StateTtlConfig, InternalTypeInfo<RowData>, GeneratedRecordComparator, RowDataKeySelector, RankType, RankRange, boolean, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.rank.AppendOnlyTopNFunction
- AppendOnlyTopNHelper - Class in org.apache.flink.table.runtime.operators.rank.utils
-
A helper to help do the logic 'Top-n' for append-only stream in
AppendOnlyTopNFunction
andAsyncStateAppendOnlyTopNFunction
. - AppendOnlyTopNHelper(AbstractTopNFunction, long, long) - Constructor for class org.apache.flink.table.runtime.operators.rank.utils.AppendOnlyTopNHelper
- apply(IN) - Method in interface org.apache.flink.table.runtime.generated.Projection
- apply(RowData) - Method in interface org.apache.flink.table.runtime.generated.FilterCondition
- apply(RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateWindowAggProcessor.WindowIsEmptyChecker
- apply(RowData, RowData) - Method in interface org.apache.flink.table.runtime.generated.JoinCondition
- apply(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.join.JoinConditionWithNullFilters
- ApproxCountDistinctAggFunction(LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction
- array - Variable in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HllBuffer
-
`public` for performance.
- ARRAY - org.apache.flink.table.runtime.functions.SqlJsonUtils.JsonQueryReturnType
- ArrayAggAccumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction.ArrayAggAccumulator
- ArrayAggFunction<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in ARRAY_AGG aggregate function.
- ArrayAggFunction(LogicalType, boolean) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction
- ArrayAggFunction.ArrayAggAccumulator<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for ARRAY_AGG with retraction.
- ArrayAppendFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_APPEND
. - ArrayAppendFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayAppendFunction
- ArrayBooleanArrayConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
ArrayType
ofboolean[]
external type. - ArrayBooleanArrayConverter() - Constructor for class org.apache.flink.table.data.conversion.ArrayBooleanArrayConverter
- ArrayByteArrayConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
ArrayType
ofbyte[]
external type. - ArrayByteArrayConverter() - Constructor for class org.apache.flink.table.data.conversion.ArrayByteArrayConverter
- ArrayConcatFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_CONCAT
. - ArrayConcatFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayConcatFunction
- ArrayContainsFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_CONTAINS
. - ArrayContainsFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayContainsFunction
- ArrayDataSerializer - Class in org.apache.flink.table.runtime.typeutils
-
Serializer for
ArrayData
. - ArrayDataSerializer(LogicalType) - Constructor for class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- ArrayDataSerializer.ArrayDataSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils
-
TypeSerializerSnapshot
forArrayDataSerializer
. - ArrayDataSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer.ArrayDataSerializerSnapshot
- ArrayDistinctFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_DISTINCT
. - ArrayDistinctFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayDistinctFunction
- ArrayDoubleArrayConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
ArrayType
ofdouble[]
external type. - ArrayDoubleArrayConverter() - Constructor for class org.apache.flink.table.data.conversion.ArrayDoubleArrayConverter
- ArrayExceptFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_EXCEPT
. - ArrayExceptFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayExceptFunction
- ArrayFloatArrayConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
ArrayType
offloat[]
external type. - ArrayFloatArrayConverter() - Constructor for class org.apache.flink.table.data.conversion.ArrayFloatArrayConverter
- ArrayIntArrayConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
ArrayType
ofint[]
external type. - ArrayIntArrayConverter() - Constructor for class org.apache.flink.table.data.conversion.ArrayIntArrayConverter
- ArrayIntersectFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_INTERSECT
. - ArrayIntersectFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayIntersectFunction
- ArrayJoinFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_JOIN
. - ArrayJoinFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayJoinFunction
- ArrayListConverter<E> - Class in org.apache.flink.table.data.conversion
-
Converter for
ArrayType
ofList
external type. - ArrayLongArrayConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
ArrayType
oflong[]
external type. - ArrayLongArrayConverter() - Constructor for class org.apache.flink.table.data.conversion.ArrayLongArrayConverter
- ArrayMaxFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_MAX
. - ArrayMaxFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayMaxFunction
- ArrayMinFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_MIN
. - ArrayMinFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayMinFunction
- ArrayObjectArrayConverter<E> - Class in org.apache.flink.table.data.conversion
-
Converter for
ArrayType
of nested primitive or object arrays external types. - ArrayPositionFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_POSITION
. - ArrayPositionFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayPositionFunction
- ArrayPrependFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_PREPEND
. - ArrayPrependFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayPrependFunction
- ArrayRemoveFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_REMOVE
. - ArrayRemoveFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayRemoveFunction
- ArrayReverseFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_REVERSE
. - ArrayReverseFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayReverseFunction
- ArrayShortArrayConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
ArrayType
ofshort[]
external type. - ArrayShortArrayConverter() - Constructor for class org.apache.flink.table.data.conversion.ArrayShortArrayConverter
- arraySize(int, float) - Static method in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Returns the least power of two smaller than or equal to 230 and larger than or equal to
Math.ceil( expected / f )
. - ArraySliceFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_SLICE
. - ArraySliceFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArraySliceFunction
- ArraySortFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of ARRAY_SORT function.
- ArraySortFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArraySortFunction
- ArrayUnionFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ARRAY_UNION
. - ArrayUnionFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ArrayUnionFunction
- asin(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- assignActualWindow(RowData, ClockService, MergingWindowProcessFunction<?, TimeWindow>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.SessionUnsliceAssigner
- assignActualWindow(RowData, ClockService, MergingWindowProcessFunction<?, TimeWindow>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- assignActualWindow(RowData, ClockService, MergingWindowProcessFunction<?, W>) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigner
-
Returns the
Window
that the given element should belong to be used to trigger on. - assignActualWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.GeneralWindowProcessFunction
- assignActualWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
-
Assigns the input element into the actual windows which the
Trigger
should trigger on. - assignActualWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowProcessFunction
- assignActualWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.PanedWindowProcessFunction
- assigner(GroupWindowAssigner<?>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- assigner(WindowAssigner) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- assignPane(Object, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- assignPane(Object, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.PanedWindowAssigner
-
Given the timestamp and element, returns the pane into which it should be placed.
- assignPane(Object, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- assignSliceEnd(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- assignSliceEnd(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- assignSliceEnd(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.TumblingSliceAssigner
- assignSliceEnd(RowData, ClockService) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigner
-
Returns the end timestamp of a slice that the given element should belong.
- assignSliceEnd(RowData, ClockService) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.WindowedSliceAssigner
- assignStateNamespace(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.GeneralWindowProcessFunction
- assignStateNamespace(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
-
Assigns the input element into the state namespace which the input element should be accumulated/retracted into.
- assignStateNamespace(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowProcessFunction
- assignStateNamespace(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.PanedWindowProcessFunction
- assignStateNamespace(RowData, ClockService, MergingWindowProcessFunction<?, TimeWindow>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.SessionUnsliceAssigner
- assignStateNamespace(RowData, ClockService, MergingWindowProcessFunction<?, TimeWindow>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- assignStateNamespace(RowData, ClockService, MergingWindowProcessFunction<?, W>) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigner
-
Returns the
Window
that the given element should belong to be used as a namespace to restore the state. - assignWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountSlidingWindowAssigner
- assignWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountTumblingWindowAssigner
- assignWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- assignWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.GroupWindowAssigner
-
Given the timestamp and element, returns the set of windows into which it should be placed.
- assignWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SessionWindowAssigner
- assignWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- assignWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.TumblingWindowAssigner
- assignWindows(RowData, long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- AssociatedRecords - Class in org.apache.flink.table.runtime.operators.join.stream.utils
-
The
AssociatedRecords
is the records associated to the input row. - asyncAdd(W, RowData) - Method in class org.apache.flink.table.runtime.operators.window.tvf.asyncprocessing.state.WindowListAsyncState
-
Updates the operator state accessible by
#asyncGet(W)
by adding the given value to the list of values. - asyncClear(W) - Method in interface org.apache.flink.table.runtime.operators.window.async.tvf.state.WindowAsyncState
-
Removes the value mapped under current key and the given window.
- asyncClear(W) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.state.WindowAsyncValueState
- asyncClear(W) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.asyncprocessing.state.WindowAsyncState
-
Removes the value mapped under current key and the given window.
- asyncClear(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.asyncprocessing.state.WindowListAsyncState
- asyncCombine(Long, Iterator<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines.AsyncStateAggCombiner
- asyncCombine(Long, Iterator<RowData>) - Method in interface org.apache.flink.table.runtime.operators.window.async.tvf.combines.AsyncStateRecordsCombiner
-
Combines the buffered data into async state based on the given window.
- AsyncFunctionRunner - Class in org.apache.flink.table.runtime.operators.calc.async
-
Async function runner for
AsyncScalarFunction
, which takes the generated function, instantiates it, and then calls its lifecycle methods. - AsyncFunctionRunner(GeneratedFunction<AsyncFunction<RowData, RowData>>) - Constructor for class org.apache.flink.table.runtime.operators.calc.async.AsyncFunctionRunner
- asyncGet(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.asyncprocessing.state.WindowListAsyncState
- asyncInvoke(RowData, ResultFuture<RowData>) - Method in class org.apache.flink.table.runtime.operators.calc.async.AsyncFunctionRunner
- asyncInvoke(RowData, ResultFuture<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinRunner
- asyncLookup(RowData) - Method in class org.apache.flink.table.runtime.functions.table.lookup.CachingAsyncLookupFunction
- asyncLookup(RowData) - Method in class org.apache.flink.table.runtime.operators.join.lookup.RetryableAsyncLookupFunctionDelegator
- AsyncLookupJoinRunner - Class in org.apache.flink.table.runtime.operators.join.lookup
-
The async join runner to lookup the dimension table.
- AsyncLookupJoinRunner(GeneratedFunction<AsyncFunction<RowData, Object>>, DataStructureConverter<RowData, Object>, GeneratedResultFuture<TableFunctionResultFuture<RowData>>, GeneratedFunction<FilterCondition>, RowDataSerializer, boolean, int) - Constructor for class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinRunner
- AsyncLookupJoinWithCalcRunner - Class in org.apache.flink.table.runtime.operators.join.lookup
-
The async join runner with an additional calculate function on the dimension table.
- AsyncLookupJoinWithCalcRunner(GeneratedFunction<AsyncFunction<RowData, Object>>, DataStructureConverter<RowData, Object>, GeneratedFunction<FlatMapFunction<RowData, RowData>>, GeneratedResultFuture<TableFunctionResultFuture<RowData>>, GeneratedFunction<FilterCondition>, RowDataSerializer, boolean, int) - Constructor for class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinWithCalcRunner
- asyncMerge(Long, Iterable<Long>, Long) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AsyncStateSliceSharedWindowAggProcessor
- asyncMerge(W, R, W) - Method in interface org.apache.flink.table.runtime.operators.window.async.AsyncMergeCallback
-
Specifies that states of the given windows or slices should be merged into the result window or slice.
- AsyncMergeCallback<W,R> - Interface in org.apache.flink.table.runtime.operators.window.async
-
Callback to be used in when merging slices or windows for specifying which slices or windows should be merged.
- asyncMergeSlices(long, AsyncMergeCallback<Long, Iterable<Long>>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- asyncMergeSlices(long, AsyncMergeCallback<Long, Iterable<Long>>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- asyncMergeSlices(long, AsyncMergeCallback<Long, Iterable<Long>>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.SlicedSharedSliceAssigner
- asyncMergeSlices(long, AsyncMergeCallback<Long, Iterable<Long>>) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceSharedAssigner
-
Determines which slices (if any) should be merged and then merge them.
- asyncProcessWithKey(RowData, ThrowingRunnable<Exception>) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.state.AsyncStateKeyContext
- AsyncStateAggCombiner - Class in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines
-
An implementation of
RecordsCombiner
that accumulates input records into the window accumulator with async state. - AsyncStateAggCombiner(WindowTimerService<Long>, WindowAsyncValueState<Long>, NamespaceAggsHandleFunction<Long>, boolean) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines.AsyncStateAggCombiner
- AsyncStateAggCombiner.Factory - Class in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines
-
Factory to create
AsyncStateAggCombiner
. - AsyncStateAppendOnlyTopNFunction - Class in org.apache.flink.table.runtime.operators.rank.async
-
A TopN function could handle insert-only stream.
- AsyncStateAppendOnlyTopNFunction(StateTtlConfig, InternalTypeInfo<RowData>, GeneratedRecordComparator, RowDataKeySelector, RankType, RankRange, boolean, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.rank.async.AsyncStateAppendOnlyTopNFunction
- AsyncStateFastTop1Function - Class in org.apache.flink.table.runtime.operators.rank.async
-
A more concise implementation for
AppendOnlyTopNFunction
andUpdatableTopNFunction
when only Top-1 is desired. - AsyncStateFastTop1Function(StateTtlConfig, InternalTypeInfo<RowData>, GeneratedRecordComparator, RowDataKeySelector, RankType, RankRange, boolean, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.rank.async.AsyncStateFastTop1Function
- AsyncStateGroupAggFunction - Class in org.apache.flink.table.runtime.operators.aggregate.async
-
Aggregate Function used for the groupby (without window) aggregate with async state api.
- AsyncStateGroupAggFunction(GeneratedAggsHandleFunction, GeneratedRecordEqualiser, LogicalType[], int, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.async.AsyncStateGroupAggFunction
-
Creates a
AsyncStateGroupAggFunction
. - AsyncStateKeyContext - Class in org.apache.flink.table.runtime.operators.window.async.tvf.state
-
Context to switch current key in async state backend.
- AsyncStateKeyContext(AbstractAsyncStateStreamOperator<RowData>, AsyncKeyedStateBackend<?>) - Constructor for class org.apache.flink.table.runtime.operators.window.async.tvf.state.AsyncStateKeyContext
- AsyncStateRecordsCombiner - Interface in org.apache.flink.table.runtime.operators.window.async.tvf.combines
-
The
AsyncStateRecordsCombiner
is used to combine buffered records into async state. - AsyncStateRecordsCombiner.Factory - Interface in org.apache.flink.table.runtime.operators.window.async.tvf.combines
-
A factory that creates a
AsyncStateRecordsCombiner
. - AsyncStateRecordsWindowBuffer - Class in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers
-
An implementation of
AsyncStateWindowBuffer
that buffers input elements in aWindowBytesMultiMap
and combines buffered elements into async state when flushing. - AsyncStateRecordsWindowBuffer(Object, MemoryManager, long, AsyncStateRecordsCombiner, PagedTypeSerializer<RowData>, AbstractRowDataSerializer<RowData>, RecordEqualiser, AsyncStateKeyContext, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateRecordsWindowBuffer
- AsyncStateRecordsWindowBuffer.Factory - Class in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers
-
Factory to create
AsyncStateRecordsWindowBuffer
withAsyncStateRecordsCombiner.Factory
. - AsyncStateRowTimeDeduplicateFunction - Class in org.apache.flink.table.runtime.operators.deduplicate.asyncprocessing
-
This function is used to deduplicate on keys and keeps only first or last row on row time.
- AsyncStateRowTimeDeduplicateFunction(InternalTypeInfo<RowData>, long, int, boolean, boolean, boolean) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.asyncprocessing.AsyncStateRowTimeDeduplicateFunction
- AsyncStateSliceSharedWindowAggProcessor - Class in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors
-
A window aggregate processor implementation which works for
SliceSharedAssigner
with async state api, e.g. hopping windows and cumulative windows. - AsyncStateSliceSharedWindowAggProcessor(GeneratedNamespaceAggsHandleFunction<Long>, AsyncStateWindowBuffer.Factory, SliceSharedAssigner, TypeSerializer<RowData>, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AsyncStateSliceSharedWindowAggProcessor
- AsyncStateSliceUnsharedWindowAggProcessor - Class in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors
-
A window aggregate processor implementation which works for
SliceUnsharedAssigner
with async state, e.g. tumbling windows. - AsyncStateSliceUnsharedWindowAggProcessor(GeneratedNamespaceAggsHandleFunction<Long>, AsyncStateWindowBuffer.Factory, SliceUnsharedAssigner, TypeSerializer<RowData>, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AsyncStateSliceUnsharedWindowAggProcessor
- AsyncStateSlicingWindowProcessor<W> - Interface in org.apache.flink.table.runtime.operators.window.async.tvf.slicing
-
The
AsyncStateSlicingWindowProcessor
is an optimized processing for aligned windows which can apply the slicing optimization. - AsyncStateStreamingJoinOperator - Class in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing
-
Streaming unbounded Join operator based on async state api, which supports INNER/LEFT/RIGHT/FULL JOIN.
- AsyncStateStreamingJoinOperator(InternalTypeInfo<RowData>, InternalTypeInfo<RowData>, GeneratedJoinCondition, JoinInputSideSpec, JoinInputSideSpec, boolean, boolean, boolean[], long, long) - Constructor for class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AsyncStateStreamingJoinOperator
- AsyncStateTableStreamOperator<OUT> - Class in org.apache.flink.table.runtime.operators
-
Table operator to invoke close always.
- AsyncStateTableStreamOperator() - Constructor for class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator
- AsyncStateTableStreamOperator.ContextImpl - Class in org.apache.flink.table.runtime.operators
-
Information available in an invocation of processElement.
- AsyncStateUtils - Class in org.apache.flink.table.runtime.util
-
Utils for processing with async state.
- AsyncStateUtils() - Constructor for class org.apache.flink.table.runtime.util.AsyncStateUtils
- AsyncStateWindowAggOperator<K,W> - Class in org.apache.flink.table.runtime.operators.window.async.tvf.common
-
A processor that processes elements for windows with async state api.
- AsyncStateWindowAggOperator(AsyncStateWindowProcessor<W>, boolean) - Constructor for class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- AsyncStateWindowBuffer - Interface in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers
-
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 - Interface in org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers
-
A factory that creates a
WindowBuffer
with async state. - AsyncStateWindowJoinOperator - Class in org.apache.flink.table.runtime.operators.join.window.asyncprocessing
-
A
AsyncStateWindowJoinOperator
implemented by async state api. - AsyncStateWindowJoinOperator(TypeSerializer<RowData>, TypeSerializer<RowData>, GeneratedJoinCondition, int, int, boolean[], ZoneId, FlinkJoinType) - Constructor for class org.apache.flink.table.runtime.operators.join.window.asyncprocessing.AsyncStateWindowJoinOperator
- AsyncStateWindowProcessor<W> - Interface in org.apache.flink.table.runtime.operators.window.async.tvf.common
-
A processor that processes elements for windows with async state.
- AsyncStateWindowProcessor.AsyncStateContext<W> - Interface in org.apache.flink.table.runtime.operators.window.async.tvf.common
-
Information available in an invocation of methods of
AsyncStateWindowProcessor
. - asyncUpdate(W, RowData) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.state.WindowAsyncValueState
-
Update the state with the given value under current key and the given window.
- asyncValue(W) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.state.WindowAsyncValueState
-
Returns the current value for the state under current key and the given window.
- atan(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- atan2(DecimalData, DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- awaitFirstLoad() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
B
- BaseAdaptiveJoinOperatorOptimizationStrategy - Class in org.apache.flink.table.runtime.strategy
-
The base stream graph optimization strategy class for adaptive join operator.
- BaseAdaptiveJoinOperatorOptimizationStrategy() - Constructor for class org.apache.flink.table.runtime.strategy.BaseAdaptiveJoinOperatorOptimizationStrategy
- BaseHybridHashTable - Class in org.apache.flink.table.runtime.hashtable
-
Base table for
LongHybridHashTable
andBinaryHashTable
. - BaseHybridHashTable(Object, boolean, int, MemoryManager, long, IOManager, int, long, boolean) - Constructor for class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- BaseTwoInputStreamOperatorWithStateRetention - Class in org.apache.flink.table.runtime.operators.join.temporal
-
An abstract
TwoInputStreamOperator
that allows its subclasses to clean up their state based on a TTL. - BaseTwoInputStreamOperatorWithStateRetention(long, long) - Constructor for class org.apache.flink.table.runtime.operators.join.temporal.BaseTwoInputStreamOperatorWithStateRetention
- BatchApproxCountDistinctAggFunctions - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in APPROX_COUNT_DISTINCT aggregate function for Batch sql.
- BatchApproxCountDistinctAggFunctions() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions
- BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Base function for APPROX_COUNT_DISTINCT aggregate.
- BatchApproxCountDistinctAggFunctions.ByteApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in byte APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.DateApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in Date APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.DecimalApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in decimal APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.DoubleApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in double APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.FloatApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in float APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.IntApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in int APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.LongApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in long APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.ShortApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in Short APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.StringApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in string APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.TimeApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in Time APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.TimestampApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in Timestamp APPROX_COUNT_DISTINCT aggregate function.
- BatchApproxCountDistinctAggFunctions.TimestampLtzApproxCountDistinctAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in TimestampLtz APPROX_COUNT_DISTINCT aggregate function.
- BatchMultipleInputStreamOperator - Class in org.apache.flink.table.runtime.operators.multipleinput
-
A
MultipleInputStreamOperatorBase
to handle batch operators. - BatchMultipleInputStreamOperator(StreamOperatorParameters<RowData>, List<InputSpec>, List<TableOperatorWrapper<?>>, TableOperatorWrapper<?>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.BatchMultipleInputStreamOperator
- BatchMultipleInputStreamOperatorFactory - Class in org.apache.flink.table.runtime.operators.multipleinput
-
The factory to create
BatchMultipleInputStreamOperator
. - BatchMultipleInputStreamOperatorFactory(List<InputSpec>, List<TableOperatorWrapper<?>>, TableOperatorWrapper<?>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.BatchMultipleInputStreamOperatorFactory
- BIG_ENDIAN - Static variable in class org.apache.flink.formats.raw.RawFormatOptions
- BigDecimalConverter(int, int) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.BigDecimalConverter
- BigDecimalTypeInfo - Class in org.apache.flink.table.runtime.typeutils
-
TypeInformation
forBigDecimal
. - BigDecimalTypeInfo(int, int) - Constructor for class org.apache.flink.table.runtime.typeutils.BigDecimalTypeInfo
- BinaryArrayWriter - Class in org.apache.flink.table.data.writer
-
Writer for binary array.
- BinaryArrayWriter(BinaryArrayData, int, int) - Constructor for class org.apache.flink.table.data.writer.BinaryArrayWriter
- BinaryArrayWriter.NullSetter - Interface in org.apache.flink.table.data.writer
-
Accessor for setting the elements of an array writer to
null
during runtime. - BinaryExternalMerger - Class in org.apache.flink.table.runtime.operators.sort
-
Record merger for sort of BinaryRowData.
- BinaryExternalMerger(IOManager, int, int, SpillChannelManager, BinaryRowDataSerializer, RecordComparator, boolean, BlockCompressionFactory, int) - Constructor for class org.apache.flink.table.runtime.operators.sort.BinaryExternalMerger
- BinaryExternalSorter - Class in org.apache.flink.table.runtime.operators.sort
-
The
BinaryExternalSorter
is a full fledged sorter for binary format. - BinaryExternalSorter(Object, MemoryManager, long, IOManager, AbstractRowDataSerializer<RowData>, BinaryRowDataSerializer, NormalizedKeyComputer, RecordComparator, int, boolean, int, boolean) - Constructor for class org.apache.flink.table.runtime.operators.sort.BinaryExternalSorter
- BinaryExternalSorter(Object, MemoryManager, long, IOManager, AbstractRowDataSerializer<RowData>, BinaryRowDataSerializer, NormalizedKeyComputer, RecordComparator, int, boolean, int, boolean, float) - Constructor for class org.apache.flink.table.runtime.operators.sort.BinaryExternalSorter
- BinaryHashBucketArea - Class in org.apache.flink.table.runtime.hashtable
-
Bucket area for hash table.
- BinaryHashPartition - Class in org.apache.flink.table.runtime.hashtable
-
A partition.
- BinaryHashPartition.BuildSideBuffer - Class in org.apache.flink.table.runtime.hashtable
-
Build side buffer.
- BinaryHashPartitioner - Class in org.apache.flink.table.runtime.partitioner
-
Hash partitioner for
BinaryRowData
. - BinaryHashPartitioner(GeneratedHashFunction, String[]) - Constructor for class org.apache.flink.table.runtime.partitioner.BinaryHashPartitioner
- BinaryHashTable - Class in org.apache.flink.table.runtime.hashtable
-
An implementation of a Hybrid Hash Join.
- BinaryHashTable(Object, boolean, int, AbstractRowDataSerializer, AbstractRowDataSerializer, Projection<RowData, BinaryRowData>, Projection<RowData, BinaryRowData>, MemoryManager, long, IOManager, int, long, boolean, HashJoinType, JoinCondition, boolean, boolean[], boolean) - Constructor for class org.apache.flink.table.runtime.hashtable.BinaryHashTable
- BinaryIndexedSortable - Class in org.apache.flink.table.runtime.operators.sort
-
abstract sortable, provide basic compare and swap.
- BinaryIndexedSortable(NormalizedKeyComputer, BinaryRowDataSerializer, RecordComparator, ArrayList<MemorySegment>, MemorySegmentPool) - Constructor for class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- BinaryInMemorySortBuffer - Class in org.apache.flink.table.runtime.operators.sort
-
In memory sort buffer for binary row.
- BinaryKVExternalMerger - Class in org.apache.flink.table.runtime.operators.sort
-
Key-Value style record merger for sort.
- BinaryKVExternalMerger(IOManager, int, int, SpillChannelManager, BinaryRowDataSerializer, BinaryRowDataSerializer, RecordComparator, boolean, BlockCompressionFactory, int) - Constructor for class org.apache.flink.table.runtime.operators.sort.BinaryKVExternalMerger
- BinaryKVInMemorySortBuffer - Class in org.apache.flink.table.runtime.operators.sort
-
In memory KV sortable buffer for binary row, it already has records in memory.
- BinaryMergeIterator<Entry> - Class in org.apache.flink.table.runtime.operators.sort
-
Binary version of
MergeIterator
. - BinaryMergeIterator(List<MutableObjectIterator<Entry>>, List<Entry>, Comparator<Entry>) - Constructor for class org.apache.flink.table.runtime.operators.sort.BinaryMergeIterator
- BinaryRowChannelInputViewIterator - Class in org.apache.flink.table.runtime.io
-
A simple iterator over the input read though an I/O channel.
- BinaryRowChannelInputViewIterator(ChannelReaderInputView, List<MemorySegment>, BinaryRowDataSerializer) - Constructor for class org.apache.flink.table.runtime.io.BinaryRowChannelInputViewIterator
- BinaryRowChannelInputViewIterator(ChannelReaderInputView, BinaryRowDataSerializer) - Constructor for class org.apache.flink.table.runtime.io.BinaryRowChannelInputViewIterator
- BinaryRowDataKeySelector - Class in org.apache.flink.table.runtime.keyselector
-
A KeySelector which will extract key from RowData.
- BinaryRowDataKeySelector(InternalTypeInfo<RowData>, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.keyselector.BinaryRowDataKeySelector
- BinaryRowDataSerializer - Class in org.apache.flink.table.runtime.typeutils
-
Serializer for
BinaryRowData
. - BinaryRowDataSerializer(int) - Constructor for class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils
-
TypeSerializerSnapshot
forBinaryRowDataSerializer
. - BinaryRowDataSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot
- BinaryRowDataUtil - Class in org.apache.flink.table.data.binary
-
Utilities for
BinaryRowData
. - BinaryRowDataUtil() - Constructor for class org.apache.flink.table.data.binary.BinaryRowDataUtil
- BinaryRowWriter - Class in org.apache.flink.table.data.writer
-
Writer for
BinaryRowData
. - BinaryRowWriter(BinaryRowData) - Constructor for class org.apache.flink.table.data.writer.BinaryRowWriter
- BinaryRowWriter(BinaryRowData, int) - Constructor for class org.apache.flink.table.data.writer.BinaryRowWriter
- BinaryStringDataUtil - Class in org.apache.flink.table.data.binary
-
Util for
BinaryStringData
. - BinaryStringDataUtil() - Constructor for class org.apache.flink.table.data.binary.BinaryStringDataUtil
- BinaryWriter - Interface in org.apache.flink.table.data.writer
-
Writer to write a composite data format, like row, array. 1.
- BinaryWriter.ValueSetter - Interface in org.apache.flink.table.data.writer
-
Accessor for setting the elements of an array writer during runtime.
- bitAnd(Byte, Byte) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitAnd(Integer, Integer) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitAnd(Long, Long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitAnd(Short, Short) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitGet(MemorySegment[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
read bit from segments.
- bitGet(MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
read bit.
- bitNot(Byte) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitNot(Integer) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitNot(Long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitNot(Short) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitOr(Byte, Byte) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitOr(Integer, Integer) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitOr(Long, Long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitOr(Short, Short) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitSet(MemorySegment[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
set bit from segments.
- bitSet(MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
set bit.
- bitUnSet(MemorySegment[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
unset bit from segments.
- bitUnSet(MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
unset bit.
- bitXor(Byte, Byte) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitXor(Integer, Integer) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitXor(Long, Long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- bitXor(Short, Short) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- BoundedOutOfOrderWatermarkGenerator - Class in org.apache.flink.table.runtime.operators.wmassigners
-
A watermark generator for rowtime attributes which are out-of-order by a bounded time interval.
- BoundedOutOfOrderWatermarkGenerator(int, long) - Constructor for class org.apache.flink.table.runtime.operators.wmassigners.BoundedOutOfOrderWatermarkGenerator
- BoxedWrapperRowData - Class in org.apache.flink.table.data
-
An implementation of
RowData
which also is also backed by an array of JavaObject
, just similar toGenericRowData
. - BoxedWrapperRowData(int) - Constructor for class org.apache.flink.table.data.BoxedWrapperRowData
- BroadcastingOutput - Class in org.apache.flink.table.runtime.operators.multipleinput.output
-
An
Output
that can be used to emit elements and other messages to multiple outputs. - BroadcastingOutput(Output<StreamRecord<RowData>>[]) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.output.BroadcastingOutput
- BTrimFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.BTRIM
. - BTrimFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.BTrimFunction
- BUCKET_SIZE - Static variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- BUCKET_SIZE_BITS - Static variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- bucketSegments - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- buffer - Variable in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction.LagAcc
- BufferBundle<T> - Class in org.apache.flink.table.runtime.operators.join.stream.bundle
-
A
BufferBundle
is a bundle to buffer the input records in memory and fold data based on specified pattern to reduce state access. - BufferBundle() - Constructor for class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
- BufferDataOverWindowOperator - Class in org.apache.flink.table.runtime.operators.over
-
the operator for OVER window need cache data by ResettableExternalBuffer for
OverWindowFrame
. - BufferDataOverWindowOperator(StreamOperatorParameters<RowData>, OverWindowFrame[], GeneratedRecordComparator, boolean) - Constructor for class org.apache.flink.table.runtime.operators.over.BufferDataOverWindowOperator
- BufferDataOverWindowOperator(OverWindowFrame[], GeneratedRecordComparator, boolean) - Constructor for class org.apache.flink.table.runtime.operators.over.BufferDataOverWindowOperator
- bufferedKey - Variable in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- BufferedKVExternalSorter - Class in org.apache.flink.table.runtime.operators.sort
-
Sorter for buffered input in the form of Key-Value Style.
- BufferedKVExternalSorter(IOManager, BinaryRowDataSerializer, BinaryRowDataSerializer, NormalizedKeyComputer, RecordComparator, int, int, boolean, int) - Constructor for class org.apache.flink.table.runtime.operators.sort.BufferedKVExternalSorter
- bufferedRow - Variable in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- bufferMatchingRows() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- build() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- build() - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.RowTimeWindowDeduplicateOperatorBuilder
- build() - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- build() - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- build() - Method in class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer.Builder
-
If neither of NOT NULL or CHAR/VARCHAR length or BINARY/VARBINARY enforcers are configured, null is returned.
- build() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder.AggregateWindowOperatorBuilder
- build() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder.TableAggregateWindowOperatorBuilder
- BUILD_LEFT_ANTI - org.apache.flink.table.runtime.operators.join.HashJoinType
- BUILD_LEFT_SEMI - org.apache.flink.table.runtime.operators.join.HashJoinType
- BUILD_OUTER - org.apache.flink.table.runtime.operators.join.HashJoinType
- builder() - Static method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- builder() - Static method in class org.apache.flink.table.runtime.operators.deduplicate.window.RowTimeWindowDeduplicateOperatorBuilder
- builder() - Static method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- builder() - Static method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- builder() - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- Builder() - Constructor for class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer.Builder
- buildLeftSemiOrAnti() - Method in enum org.apache.flink.table.runtime.operators.join.HashJoinType
- buildRowCount - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- BuildSideIterator - Class in org.apache.flink.table.runtime.hashtable
-
Iterate all the elements in memory which has not been(or has been) probed during probe phase.
- BuildSideIterator.BucketIterator - Class in org.apache.flink.table.runtime.hashtable
-
Partition bucket iterator.
- buildSpillRetBufferNumbers - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The number of buffers in the build spill return buffer queue that are actually not write behind buffers, but regular buffers that only have not yet returned.
- buildSpillReturnBuffers - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The queue of buffers that can be used for write-behind.
- buildTriggerWindowElementsIterator() - Method in class org.apache.flink.table.runtime.operators.window.grouping.WindowsGrouping
- BuiltInAggregateFunction<T,ACC> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Base class for runtime implementation represented as
AggregateFunction
that is constructed fromBuiltInFunctionDefinition.specialize(SpecializedContext)
. - BuiltInAggregateFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
- BuiltInAggregateFunction(BuiltInFunctionDefinition, SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
- BuiltInScalarFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Base class for runtime implementation represented as
ScalarFunction
that is constructed fromBuiltInFunctionDefinition.specialize(SpecializedContext)
. - BuiltInScalarFunction() - Constructor for class org.apache.flink.table.runtime.functions.scalar.BuiltInScalarFunction
- BuiltInScalarFunction(BuiltInFunctionDefinition, SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.BuiltInScalarFunction
- BuiltInSpecializedFunction - Class in org.apache.flink.table.runtime.functions
-
Base class for built-in functions that need another level of specialization via
BuiltInFunctionDefinition.specialize(SpecializedContext)
. - BuiltInSpecializedFunction(BuiltInFunctionDefinition) - Constructor for class org.apache.flink.table.runtime.functions.BuiltInSpecializedFunction
- BuiltInTableFunction<T> - Class in org.apache.flink.table.runtime.functions.table
-
Base class for runtime implementation represented as
TableFunction
that is constructed fromBuiltInFunctionDefinition.specialize(SpecializedContext)
. - BuiltInTableFunction() - Constructor for class org.apache.flink.table.runtime.functions.table.BuiltInTableFunction
- BuiltInTableFunction(BuiltInFunctionDefinition, SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.table.BuiltInTableFunction
- bundle - Variable in class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
- BundleTrigger<T> - Interface in org.apache.flink.table.runtime.operators.bundle.trigger
-
A
BundleTrigger
determines when a bundle of input elements should be evaluated and trigger the callback which registered previously. - BundleTriggerCallback - Interface in org.apache.flink.table.runtime.operators.bundle.trigger
-
Interface for bundle trigger callbacks that can be registered to a
BundleTrigger
. - BYTE_ARRAY_BASE_OFFSET - Static variable in class org.apache.flink.table.data.binary.BinaryRowDataUtil
- ByteApproxCountDistinctAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ByteApproxCountDistinctAggFunction
- byteArrayCompare(byte[], byte[]) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Compares two byte arrays in lexicographical order.
- byteArrayEquals(byte[], byte[], int) - Static method in class org.apache.flink.table.data.binary.BinaryRowDataUtil
- byteArrayEquals(Object, long, Object, long, int) - Static method in class org.apache.flink.table.data.binary.BinaryRowDataUtil
- ByteHashSet - Class in org.apache.flink.table.runtime.util.collections
-
Byte hash set.
- ByteHashSet(int) - Constructor for class org.apache.flink.table.runtime.util.collections.ByteHashSet
- BytesHashMap - Class in org.apache.flink.table.runtime.util.collections.binary
-
A binary map in the structure like
Map<BinaryRowData, BinaryRowData>
. - BytesHashMap(Object, MemoryManager, long, LogicalType[], LogicalType[]) - Constructor for class org.apache.flink.table.runtime.util.collections.binary.BytesHashMap
- BytesHashMapSpillMemorySegmentPool - Class in org.apache.flink.table.runtime.operators.aggregate
-
MemorySegmentPool for
BytesHashMap
to fall back to sort agg. - BytesHashMapSpillMemorySegmentPool(List<MemorySegment>) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.BytesHashMapSpillMemorySegmentPool
- BytesMap<K,V> - Class in org.apache.flink.table.runtime.util.collections.binary
-
Base class for
BytesHashMap
andBytesMultiMap
. - BytesMap(Object, MemoryManager, long, TypeSerializer<K>) - Constructor for class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- BytesMap.LookupInfo<K,V> - Class in org.apache.flink.table.runtime.util.collections.binary
-
Result fetched when looking up a key.
- BytesMultiMap - Class in org.apache.flink.table.runtime.util.collections.binary
-
A binary map in the structure like
Map<BinaryRowData, List<BinaryRowData>>
. - BytesMultiMap(Object, MemoryManager, long, LogicalType[], LogicalType[]) - Constructor for class org.apache.flink.table.runtime.util.collections.binary.BytesMultiMap
C
- cache - Variable in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
- CacheLoader - Class in org.apache.flink.table.runtime.functions.table.lookup.fullcache
-
Abstract task that loads data in Full cache from source provided by
ScanTableSource.ScanRuntimeProvider
. - CacheLoader() - Constructor for class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
- CachingAsyncLookupFunction - Class in org.apache.flink.table.runtime.functions.table.lookup
-
A wrapper function around user-provided async lookup function with a cache layer.
- CachingAsyncLookupFunction(LookupCache, AsyncLookupFunction) - Constructor for class org.apache.flink.table.runtime.functions.table.lookup.CachingAsyncLookupFunction
- CachingLookupFunction - Class in org.apache.flink.table.runtime.functions.table.lookup
-
A wrapper function around user-provided lookup function with a cache layer.
- CachingLookupFunction(LookupCache, LookupFunction) - Constructor for class org.apache.flink.table.runtime.functions.table.lookup.CachingLookupFunction
-
Create a
CachingLookupFunction
. - calc(RowData) - Method in interface org.apache.flink.table.runtime.operators.over.frame.OffsetOverFrame.CalcOffsetFunc
- calcSecondHashCode(int) - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- canEqual(Object) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- canEqual(Object) - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- canEqual(Object) - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- canEqual(Object) - Method in class org.apache.flink.table.runtime.typeutils.SortedMapTypeInfo
- canEqual(Object) - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- canEqual(Object) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- canMerge() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.CountElement
- canMerge() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.EveryElement
- canMerge() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
- canMerge() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowEarlyAndLate
- canMerge() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowNoLate
- canMerge() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindow
- canMerge() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindowNoLate
- canMerge() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterFirstElementPeriodic
- canMerge() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger
-
Returns true if this trigger supports merging of trigger state and can therefore.
- canRetry(int) - Method in class org.apache.flink.table.runtime.operators.join.lookup.ResultRetryStrategy
- CaseClassConverter(TupleTypeInfoBase, DataType[]) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.CaseClassConverter
- castFrom(double, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- castFrom(long, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- castFrom(String, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- castFrom(DecimalData, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- castToBoolean(DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- castToDecimal(DecimalData, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- castToIntegral(DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- ceil(double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- ceil(float) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- ceil(int, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
CEIL
operator applied to int values. - ceil(long, long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
CEIL
operator applied to long values. - ceil(DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- ceil(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- channelReaderInputViewIterator(AbstractChannelReaderInputView) - Method in class org.apache.flink.table.runtime.operators.sort.AbstractBinaryExternalMerger
- channelReaderInputViewIterator(AbstractChannelReaderInputView) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalMerger
- channelReaderInputViewIterator(AbstractChannelReaderInputView) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryKVExternalMerger
- ChannelReaderKVInputViewIterator<K,V> - Class in org.apache.flink.table.runtime.operators.sort
-
Key-Value style channel reader input view iterator.
- ChannelReaderKVInputViewIterator(AbstractChannelReaderInputView, List<MemorySegment>, TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.table.runtime.operators.sort.ChannelReaderKVInputViewIterator
- ChannelWithMeta - Class in org.apache.flink.table.runtime.io
-
Channel with block count and numBytesInLastBlock of file.
- ChannelWithMeta(FileIOChannel.ID, int, int) - Constructor for class org.apache.flink.table.runtime.io.ChannelWithMeta
- CHARSET - Static variable in class org.apache.flink.formats.raw.RawFormatOptions
- check(BinaryStringData) - Method in class org.apache.flink.table.runtime.functions.SqlLikeChainChecker
- checkAllReleased() - Method in class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager
- checkAndGetNextWatermark(RowData, long) - Method in class org.apache.flink.table.runtime.operators.wmassigners.PunctuatedWatermarkStrategyWrapper
- checkInsertOnly(RowData) - Static method in class org.apache.flink.table.runtime.operators.deduplicate.utils.DeduplicateFunctionHelper
-
check message should be insert only.
- checkNextIndexOffset() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
-
check if we need request next index memory.
- checkpointCoordinator(long, CompletableFuture<byte[]>) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- checkSkipReadForFixLengthPart(AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
-
We need skip bytes to read when the remain bytes of current segment is not enough to write binary row fixed part.
- checkSortKeyInBufferRange(RowData, long) - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Checks whether the record should be put into the buffer.
- checkSortKeyInBufferRange(RowData, TopNBuffer) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
-
Checks whether the record should be put into the buffer.
- chr(long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- ClassDataTypeConverter - Class in org.apache.flink.table.runtime.types
-
Utils for get
DataType
from a Class. - ClassDataTypeConverter() - Constructor for class org.apache.flink.table.runtime.types.ClassDataTypeConverter
- ClassLogicalTypeConverter - Class in org.apache.flink.table.runtime.types
-
Get internal(sql engine execution data formats) and default external class for
LogicalType
. - ClassLogicalTypeConverter() - Constructor for class org.apache.flink.table.runtime.types.ClassLogicalTypeConverter
- cleanCache() - Method in class org.apache.flink.table.runtime.util.LazyMemorySegmentPool
- cleanup() - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunctionBase
-
Cleanup for the retired accumulators state.
- cleanup(N) - Method in interface org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunctionBase
-
Cleanup for the retired accumulators state.
- cleanUp() - Static method in class org.apache.flink.table.runtime.generated.CompileUtils
-
Triggers internal garbage collection of expired cache entries.
- cleanupLastTimer() - Method in class org.apache.flink.table.runtime.operators.join.temporal.BaseTwoInputStreamOperatorWithStateRetention
- cleanupState(long) - Method in class org.apache.flink.table.runtime.operators.join.temporal.BaseTwoInputStreamOperatorWithStateRetention
-
The method to be called when a cleanup timer fires.
- cleanupState(long) - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalProcessTimeJoinOperator
-
The method to be called when a cleanup timer fires.
- cleanupState(long) - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalRowTimeJoinOperator
-
The method to be called when a cleanup timer fires.
- cleanupState(State...) - Method in class org.apache.flink.table.runtime.functions.KeyedProcessFunctionWithCleanupState
- CleanupState - Interface in org.apache.flink.table.runtime.functions
-
Base interface for clean up state, both for
ProcessFunction
andCoProcessFunction
. - cleanWindowIfNeeded(W, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.GeneralWindowProcessFunction
- cleanWindowIfNeeded(W, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
-
Cleans the given window if needed.
- cleanWindowIfNeeded(W, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowProcessFunction
- cleanWindowIfNeeded(W, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.PanedWindowProcessFunction
- clear() - Method in class org.apache.flink.table.runtime.dataview.StateListView
- clear() - Method in class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager
- clear() - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
-
Clear this bufferBundle.
- clear() - Method in class org.apache.flink.table.runtime.operators.sort.ListMemorySegmentPool
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.CountElement
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.EveryElement
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowEarlyAndLate
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowNoLate
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindow
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindowNoLate
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterFirstElementPeriodic
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger
-
Clears any state that the trigger might still hold for the given window.
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowListState
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
- clear(W) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.state.WindowState
-
Removes the value mapped under current key and the given window.
- clear(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowValueState
- clearAccumulatorsState() - Method in class org.apache.flink.table.runtime.operators.aggregate.utils.GroupAggHelper
- clearPartitions() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- clearPartitions() - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
-
This method clears all partitions currently residing (partially) in memory.
- clearPartitions() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- clearPreviousState(W) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Clear previous agg state (used for retraction) of the given window.
- clearState(long, boolean) - Method in class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
- clearTrigger(W) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Call
Trigger.clear(Window)
} on trigger. - clearWindow(long, Long) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- clearWindow(long, Long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- clearWindow(long, Long) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.processors.RowTimeSyncStateWindowDeduplicateProcessor
- clearWindow(long, Long) - Method in class org.apache.flink.table.runtime.operators.rank.window.processors.SyncStateWindowRankProcessor
- clearWindow(long, TimeWindow) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.UnsliceSyncStateWindowAggProcessor
- clearWindow(long, W) - Method in interface org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowProcessor
-
Clear state and resources associated with the given window namespace.
- clearWindow(long, W) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.SyncStateWindowProcessor
-
Clear state and resources associated with the given window namespace.
- clearWindowState(W) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Clear window state of the given window.
- clockService - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- ClockService - Interface in org.apache.flink.table.runtime.operators.window.tvf.common
-
A clock service which can get current processing time.
- close() - Method in class org.apache.flink.table.runtime.collector.TableFunctionCollector
- close() - Method in class org.apache.flink.table.runtime.collector.WrappingCollector
- close() - Method in class org.apache.flink.table.runtime.functions.DefaultExpressionEvaluator
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayContainsFunction
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayDistinctFunction
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayExceptFunction
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayIntersectFunction
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayMaxFunction
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayMinFunction
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayPositionFunction
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayRemoveFunction
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.ArraySortFunction
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayUnionFunction
- close() - Method in class org.apache.flink.table.runtime.functions.scalar.MapUnionFunction
- close() - Method in class org.apache.flink.table.runtime.functions.table.lookup.CachingAsyncLookupFunction
- close() - Method in class org.apache.flink.table.runtime.functions.table.lookup.CachingLookupFunction
- close() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
- close() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.LookupFullCache
- close() - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunctionBase
-
Tear-down method for this function.
- close() - Method in interface org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunctionBase
-
Tear-down method for this function.
- close() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
Closes the hash table.
- close() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- close() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- close() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- close() - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelReaderInputView
- close() - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelWriterOutputView
- close() - Method in class org.apache.flink.table.runtime.io.HeaderlessChannelWriterOutputView
-
Closes this OutputView, closing the underlying writer.
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateRecordsWindowBuffer
- close() - Method in interface org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateWindowBuffer
-
Release resources allocated by this buffer.
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines.AsyncStateAggCombiner
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.GroupTableAggFunction
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchGlobalGroupAggFunction
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchGroupAggFunction
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchIncrementalGroupAggFunction
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchLocalGroupAggFunction
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.buffers.RecordsWindowBuffer
- close() - Method in interface org.apache.flink.table.runtime.operators.aggregate.window.buffers.WindowBuffer
-
Release resources allocated by this buffer.
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.combines.AggCombiner
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.combines.GlobalAggCombiner
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.combines.LocalAggCombiner
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.LocalSlicingWindowAggOperator
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- close() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- close() - Method in class org.apache.flink.table.runtime.operators.bundle.AbstractMapBundleOperator
- close() - Method in class org.apache.flink.table.runtime.operators.bundle.MapBundleFunction
- close() - Method in class org.apache.flink.table.runtime.operators.calc.async.AsyncFunctionRunner
- close() - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.combines.RowTimeDeduplicateRecordsCombiner
- close() - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.processors.RowTimeSyncStateWindowDeduplicateProcessor
- close() - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperator
- close() - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- close() - Method in class org.apache.flink.table.runtime.operators.join.HashJoinOperator
- close() - Method in class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinRunner
- close() - Method in class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinWithCalcRunner
- close() - Method in class org.apache.flink.table.runtime.operators.join.lookup.KeyedLookupJoinWrapper
- close() - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- close() - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinWithCalcRunner
- close() - Method in class org.apache.flink.table.runtime.operators.join.lookup.RetryableAsyncLookupFunctionDelegator
- close() - Method in class org.apache.flink.table.runtime.operators.join.lookup.RetryableLookupFunctionDelegator
- close() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeFullOuterJoinIterator
- close() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinFunction
- close() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- close() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinOperator
- close() - Method in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- close() - Method in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- close() - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- close() - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalProcessTimeJoinOperator
- close() - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalRowTimeJoinOperator
- close() - Method in class org.apache.flink.table.runtime.operators.join.window.asyncprocessing.AsyncStateWindowJoinOperator
- close() - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperator
- close() - Method in class org.apache.flink.table.runtime.operators.match.IterativeConditionRunner
- close() - Method in class org.apache.flink.table.runtime.operators.match.PatternProcessFunctionRunner
- close() - Method in class org.apache.flink.table.runtime.operators.multipleinput.MultipleInputStreamOperatorBase
-
Closes all sub-operators in a multiple input operator effect way.
- close() - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.BroadcastingOutput
- close() - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.OutputBase
- close() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- close() - Method in class org.apache.flink.table.runtime.operators.over.AbstractRowTimeUnboundedPrecedingOver
- close() - Method in class org.apache.flink.table.runtime.operators.over.BufferDataOverWindowOperator
- close() - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeRangeBoundedPrecedingFunction
- close() - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeRowsBoundedPrecedingFunction
- close() - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeUnboundedPrecedingFunction
- close() - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRangeBoundedPrecedingFunction
- close() - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRowsBoundedPrecedingFunction
- close() - Method in class org.apache.flink.table.runtime.operators.rank.window.combines.TopNRecordsCombiner
- close() - Method in class org.apache.flink.table.runtime.operators.rank.window.processors.SyncStateWindowRankProcessor
- close() - Method in class org.apache.flink.table.runtime.operators.sort.AbstractBinaryExternalMerger
- close() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalSorter
-
Shuts down all the threads initiated by this sorter.
- close() - Method in class org.apache.flink.table.runtime.operators.sort.BufferedKVExternalSorter
- close() - Method in class org.apache.flink.table.runtime.operators.sort.SortOperator
- close() - Method in class org.apache.flink.table.runtime.operators.sort.SpillChannelManager
- close() - Method in interface org.apache.flink.table.runtime.operators.window.async.tvf.combines.AsyncStateRecordsCombiner
-
Release resources allocated by this combine function.
- close() - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- close() - Method in class org.apache.flink.table.runtime.operators.window.grouping.HeapWindowsGrouping
- close() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
-
The tear-down method of the function.
- close() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- close() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.combines.RecordsCombiner
-
Release resources allocated by this combine function.
- close() - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- close() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowProcessor
-
The tear-down method of the function.
- close() - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.UnalignedWindowTableFunctionOperator
- close() - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.WindowTableFunctionOperatorBase
- close() - Method in class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperator
- close() - Method in class org.apache.flink.table.runtime.util.EqualityAndHashcodeProvider
- close() - Method in class org.apache.flink.table.runtime.util.LazyMemorySegmentPool
- close() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer.BufferIterator
- close() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
-
Delete all files and release the memory.
- close() - Method in class org.apache.flink.table.runtime.util.StreamRecordCollector
- closeAndDelete() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- closeAndDelete() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- closed - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
Flag indicating that the closing logic has been invoked.
- CoalesceFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.COALESCE
. - CoalesceFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.CoalesceFunction
- CoBundleTrigger<IN1,IN2> - Interface in org.apache.flink.table.runtime.operators.bundle.trigger
-
A
CoBundleTrigger
is similar withBundleTrigger
, and the only differences isCoBundleTrigger
can handle two inputs. - CodeGenOperatorFactory<OUT> - Class in org.apache.flink.table.runtime.operators
-
Stream operator factory for code gen operator.
- CodeGenOperatorFactory(GeneratedClass<? extends StreamOperator<OUT>>) - Constructor for class org.apache.flink.table.runtime.operators.CodeGenOperatorFactory
- collect(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.BroadcastingOutput
- collect(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingBroadcastingOutput
- collect(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingSecondInputOfTwoInputStreamOperatorOutput
- collect(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.FirstInputOfTwoInputStreamOperatorOutput
- collect(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.OneInputStreamOperatorOutput
- collect(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.SecondInputOfTwoInputStreamOperatorOutput
- collect(RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSyncStateWindowAggProcessor
- collect(RowData, Collection<TimeWindow>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.WindowTableFunctionOperatorBase
- collect(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
-
Send result to downstream.
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.BroadcastingOutput
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingBroadcastingOutput
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingSecondInputOfTwoInputStreamOperatorOutput
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.FirstInputOfTwoInputStreamOperatorOutput
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.OneInputStreamOperatorOutput
- collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.SecondInputOfTwoInputStreamOperatorOutput
- collect(T) - Method in class org.apache.flink.table.runtime.util.StreamRecordCollector
- CollectAccumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction.CollectAccumulator
- CollectAggFunction<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in COLLECT aggregate function.
- CollectAggFunction(LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction
- CollectAggFunction.CollectAccumulator<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for COLLECT.
- collectDelete(Collector<RowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- collectDelete(Collector<RowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- collectDelete(Collector<RowData>, RowData, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractSyncStateTopNFunction
- collectDelete(Collector<RowData>, RowData, long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- collectDelete(Collector<RowData>, RowData, long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- collectInsert(Collector<RowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- collectInsert(Collector<RowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- collectInsert(Collector<RowData>, RowData, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractSyncStateTopNFunction
- collectInsert(Collector<RowData>, RowData, long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- collectInsert(Collector<RowData>, RowData, long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- CollectionUnnestTableFunction(SpecializedFunction.SpecializedContext, LogicalType, ArrayData.ElementGetter) - Constructor for class org.apache.flink.table.runtime.functions.table.UnnestRowsFunction.CollectionUnnestTableFunction
- collector - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.LocalSlicingWindowAggOperator
-
This is used for emitting elements with a given timestamp.
- collector - Variable in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- collector - Variable in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- collector - Variable in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- collector - Variable in class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
-
This is used for emitting elements with a given timestamp.
- collector - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
-
This is used for emitting elements with a given timestamp.
- collectUpdateAfter(Collector<RowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- collectUpdateAfter(Collector<RowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- collectUpdateAfter(Collector<RowData>, RowData, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractSyncStateTopNFunction
- collectUpdateAfter(Collector<RowData>, RowData, long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- collectUpdateAfter(Collector<RowData>, RowData, long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- collectUpdateBefore(Collector<RowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- collectUpdateBefore(Collector<RowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- collectUpdateBefore(Collector<RowData>, RowData, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractSyncStateTopNFunction
- collectUpdateBefore(Collector<RowData>, RowData, long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- collectUpdateBefore(Collector<RowData>, RowData, long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- combine(WindowKey, Iterator<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.combines.AggCombiner
- combine(WindowKey, Iterator<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.combines.GlobalAggCombiner
- combine(WindowKey, Iterator<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.combines.LocalAggCombiner
- combine(WindowKey, Iterator<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.combines.RowTimeDeduplicateRecordsCombiner
- combine(WindowKey, Iterator<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.window.combines.TopNRecordsCombiner
- combine(WindowKey, Iterator<RowData>) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.combines.RecordsCombiner
-
Combines the buffered data into state based on the given window-key pair.
- ComparableRecordComparator - Class in org.apache.flink.table.runtime.operators.rank
-
Because it's impossible to restore a
RecordComparator
instance generated byGeneratedRecordComparator
from checkpoint snapshot. - ComparableRecordComparator(GeneratedRecordComparator, int[], LogicalType[], boolean[], boolean[]) - Constructor for class org.apache.flink.table.runtime.operators.rank.ComparableRecordComparator
- compare(double, DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- compare(int, int) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- compare(int, int, int, int) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- compare(long, DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- compare(DecimalData, double) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- compare(DecimalData, long) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- compare(DecimalData, DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- compare(RowData, RowData) - Method in interface org.apache.flink.table.runtime.generated.RecordComparator
- compare(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.match.RowDataEventComparator
- compare(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.ComparableRecordComparator
- compareBinary(byte[], byte[]) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
- compareBinary(byte[], int, int, byte[], int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
- compareKey(MemorySegment, int, MemorySegment, int) - Method in interface org.apache.flink.table.runtime.generated.NormalizedKeyComputer
-
Compares two normalized keys in respective
MemorySegment
. - compareTo(Window) - Method in class org.apache.flink.table.runtime.operators.window.CountWindow
- compareTo(Window) - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow
- compile(ClassLoader) - Method in class org.apache.flink.table.runtime.generated.GeneratedClass
-
Compiles the generated code, the compiled class will be cached in the
GeneratedClass
. - compile(ClassLoader, String, String) - Static method in class org.apache.flink.table.runtime.generated.CompileUtils
-
Compiles a generated code to a Class.
- compileExpression(String, List<String>, List<Class<?>>, Class<?>) - Static method in class org.apache.flink.table.runtime.generated.CompileUtils
-
Compiles an expression code to a janino
ExpressionEvaluator
. - compileGeneratedCode() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.AggregateWindowOperator
- compileGeneratedCode() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.TableAggregateWindowOperator
- compileGeneratedCode() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- CompileUtils - Class in org.apache.flink.table.runtime.generated
-
Utilities to compile a generated code to a Class.
- CompileUtils() - Constructor for class org.apache.flink.table.runtime.generated.CompileUtils
- complete() - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
-
Finally, complete write to set real size to row.
- complete() - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- complete() - Method in interface org.apache.flink.table.data.writer.BinaryWriter
-
Finally, complete write to set real size to binary.
- complete() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
- complete() - Method in interface org.apache.flink.table.runtime.util.ResettableRowBuffer
-
Finally, complete add.
- completeExceptionally(Throwable) - Method in class org.apache.flink.table.runtime.collector.TableFunctionResultFuture
- CompressedBlockChannelReader - Class in org.apache.flink.table.runtime.io
-
Compressed block channel reader provides a scenario where MemorySegment must be maintained.
- CompressedBlockChannelReader(IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>, BlockCompressionFactory, int, int) - Constructor for class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- CompressedBlockChannelWriter - Class in org.apache.flink.table.runtime.io
-
Compressed block channel writer provides a scenario where MemorySegment must be maintained.
- CompressedBlockChannelWriter(IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>, BlockCompressionFactory, int, int) - Constructor for class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- CompressedHeaderlessChannelReaderInputView - Class in org.apache.flink.table.runtime.io
-
A
DataInputView
that is backed by aBufferFileReader
, making it effectively a data input stream. - CompressedHeaderlessChannelReaderInputView(FileIOChannel.ID, IOManager, BlockCompressionFactory, int, int) - Constructor for class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelReaderInputView
- CompressedHeaderlessChannelWriterOutputView - Class in org.apache.flink.table.runtime.io
-
A
DataOutputView
that is backed by aFileIOChannel
, making it effectively a data output stream. - CompressedHeaderlessChannelWriterOutputView(BufferFileWriter, BlockCompressionFactory, int) - Constructor for class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelWriterOutputView
- compressionBlockSize - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- compressionBlockSize() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- compressionCodecFactory - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- compressionCodecFactory() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- compressionEnabled - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- compressionEnabled() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- computeMemorySize() - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator
-
Compute memory size from memory faction.
- computeMemorySize() - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator
-
Compute memory size from memory faction.
- computeMemorySize(double) - Method in class org.apache.flink.table.runtime.operators.fusion.FusionStreamOperatorBase
- concat(Iterable<BinaryStringData>) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- concat(BinaryStringData...) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Concatenates input strings together into a single string.
- concatWs(BinaryStringData, Iterable<BinaryStringData>) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- concatWs(BinaryStringData, BinaryStringData...) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Concatenates input strings together into a single string using the separator.
- constantRankEnd - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- ConstantRankRange - Class in org.apache.flink.table.runtime.operators.rank
-
rankStart and rankEnd are inclusive, rankStart always start from one.
- ConstantRankRange(long, long) - Constructor for class org.apache.flink.table.runtime.operators.rank.ConstantRankRange
- ConstantRankRangeWithoutEnd - Class in org.apache.flink.table.runtime.operators.rank
-
ConstantRankRangeWithoutEnd is a RankRange which not specify RankEnd.
- ConstantRankRangeWithoutEnd(long) - Constructor for class org.apache.flink.table.runtime.operators.rank.ConstantRankRangeWithoutEnd
- ConstraintEnforcer - Class in org.apache.flink.table.runtime.operators.sink
-
Processes
RowData
to enforce the following constraints:NOT NULL
column constraint of a sink tableCHAR(length)
/@{code VARCHAR(length)}: trim string values to comply with thelength
defined in their corresponding types. - ConstraintEnforcer.Builder - Class in org.apache.flink.table.runtime.operators.sink
-
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 - Class in org.apache.flink.table.runtime.operators.sink
-
Helper POJO to keep info about CHAR/VARCHAR/BINARY/VARBINARY fields, used to determine if trimming or padding is needed.
- contains(byte) - Method in class org.apache.flink.table.runtime.util.collections.ByteHashSet
- contains(double) - Method in class org.apache.flink.table.runtime.util.collections.DoubleHashSet
- contains(float) - Method in class org.apache.flink.table.runtime.util.collections.FloatHashSet
-
See
Float.equals(Object)
. - contains(int) - Method in class org.apache.flink.table.runtime.util.collections.IntHashSet
- contains(long) - Method in class org.apache.flink.table.runtime.util.collections.LongHashSet
- contains(short) - Method in class org.apache.flink.table.runtime.util.collections.ShortHashSet
- contains(T) - Method in class org.apache.flink.table.runtime.util.collections.ObjectHashSet
- contains(W, RowData) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
-
Returns whether there exists the given mapping.
- containsKey(RowData) - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Returns
true
if the buffer contains a mapping for the specified key. - containsNull - Variable in class org.apache.flink.table.runtime.util.collections.ByteHashSet
- containsNull - Variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Is this set has a null key.
- containsNull() - Method in class org.apache.flink.table.runtime.util.collections.ByteHashSet
- containsNull() - Method in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Is there a null key.
- containsNullKey() - Method in class org.apache.flink.table.runtime.dataview.MapViewSpec
- containsZero - Variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Is this set has a zero key.
- convertBloomFilterToRowData(int, byte[]) - Static method in class org.apache.flink.table.runtime.operators.runtimefilter.util.RuntimeFilterUtils
- convertBloomFilterToRowData(int, BloomFilter) - Static method in class org.apache.flink.table.runtime.operators.runtimefilter.util.RuntimeFilterUtils
- converters - Variable in class org.apache.flink.table.data.util.DataFormatConverters.AbstractRowDataConverter
- convertToJavaMap(MapData, LogicalType, LogicalType) - Static method in class org.apache.flink.table.data.util.MapDataUtil
-
Converts a
MapData
into JavaMap
, the keys and values of the Java map still holds objects of internal data structures. - copy() - Method in class org.apache.flink.table.runtime.keyselector.GenericRowDataKeySelector
- copy() - Method in class org.apache.flink.table.runtime.partitioner.BinaryHashPartitioner
- copy() - Method in class org.apache.flink.table.runtime.partitioner.RowDataCustomStreamPartitioner
- copy(E) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- copy(E, E) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- copy(LinkedList<T>) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- copy(LinkedList<T>, LinkedList<T>) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- copy(ArrayData) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- copy(ArrayData, ArrayData) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- copy(BinaryRowData) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- copy(BinaryRowData, BinaryRowData) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- copy(DecimalData) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- copy(DecimalData, DecimalData) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- copy(MapData) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
-
NOTE: Map should be a HashMap, when we insert the key/value pairs of the TreeMap into a HashMap, problems maybe occur.
- copy(MapData, MapData) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- copy(RawValueData<T>) - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- copy(RawValueData<T>, RawValueData<T>) - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- copy(RowData) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- copy(RowData, RowData) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- copy(StringData) - Method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- copy(StringData, StringData) - Method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- copy(TimestampData) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- copy(TimestampData, TimestampData) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- copy(CountWindow) - Method in class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- copy(CountWindow, CountWindow) - Method in class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- copy(TimeWindow) - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- copy(TimeWindow, TimeWindow) - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- copy(WindowKey) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- copy(WindowKey, WindowKey) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- copyFromBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
Copy target segments from source byte[].
- copyFromPagesToView(AbstractPagedInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
-
Copy a binaryRow which stored in paged input view to output view.
- CopyingBroadcastingOutput - Class in org.apache.flink.table.runtime.operators.multipleinput.output
-
Special version of
BroadcastingOutput
that performs a shallow copy of theStreamRecord
to ensure that multi-output works correctly. - CopyingBroadcastingOutput(Output<StreamRecord<RowData>>[]) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingBroadcastingOutput
- CopyingFirstInputOfTwoInputStreamOperatorOutput - Class in org.apache.flink.table.runtime.operators.multipleinput.output
-
An
Output
that can be used to emit copying elements and other messages for the first input ofTwoInputStreamOperator
. - CopyingFirstInputOfTwoInputStreamOperatorOutput(TwoInputStreamOperator<RowData, RowData, RowData>, TypeSerializer<RowData>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingFirstInputOfTwoInputStreamOperatorOutput
- CopyingOneInputStreamOperatorOutput - Class in org.apache.flink.table.runtime.operators.multipleinput.output
-
An
Output
that can be used to emit copying elements and other messages forOneInputStreamOperator
. - CopyingOneInputStreamOperatorOutput(OneInputStreamOperator<RowData, RowData>, TypeSerializer<RowData>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingOneInputStreamOperatorOutput
- CopyingSecondInputOfTwoInputStreamOperatorOutput - Class in org.apache.flink.table.runtime.operators.multipleinput.output
-
An
Output
that can be used to emit copying elements and other messages for the second input ofTwoInputStreamOperator
. - CopyingSecondInputOfTwoInputStreamOperatorOutput(TwoInputStreamOperator<RowData, RowData, RowData>, TypeSerializer<RowData>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingSecondInputOfTwoInputStreamOperatorOutput
- copyMultiSegmentsToBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
- copyToBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
Copy segments to target byte[].
- copyToBytes(MemorySegment[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
Copy segments to a new byte[].
- copyToUnsafe(MemorySegment[], int, Object, int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
Copy segments to target unsafe pointer.
- copyToView(MemorySegment[], int, int, DataOutputView) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
Copy bytes of segments to output view.
- cos(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- cosh(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- cot(double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
COT
operator applied to double values. - cot(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- count - Variable in class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
- count(long) - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers
-
Creates a trigger that fires when the pane contains at lease
countElems
elements. - CountBundleTrigger<T> - Class in org.apache.flink.table.runtime.operators.bundle.trigger
-
A
BundleTrigger
that fires once the count of elements in a bundle reaches the given count. - CountBundleTrigger(long) - Constructor for class org.apache.flink.table.runtime.operators.bundle.trigger.CountBundleTrigger
- CountCoBundleTrigger<IN1,IN2> - Class in org.apache.flink.table.runtime.operators.bundle.trigger
-
A
CoBundleTrigger
that fires once the count of elements in a bundle reaches the given count. - CountCoBundleTrigger(long) - Constructor for class org.apache.flink.table.runtime.operators.bundle.trigger.CountCoBundleTrigger
- CountSlidingWindowAssigner - Class in org.apache.flink.table.runtime.operators.window.groupwindow.assigners
-
A
GroupWindowAssigner
that windows elements into sliding windows based on the count number of the elements. - countStarIndex(int) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
-
Specify the index position of the COUNT(*) value in the accumulator buffer.
- CountTumblingWindowAssigner - Class in org.apache.flink.table.runtime.operators.window.groupwindow.assigners
-
A
GroupWindowAssigner
that windows elements into fixed-size windows based on the count number of the elements. - countWindow(long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- countWindow(long, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- CountWindow - Class in org.apache.flink.table.runtime.operators.window
-
A
Window
that represents a count window. - CountWindow(long) - Constructor for class org.apache.flink.table.runtime.operators.window.CountWindow
- CountWindow.Serializer - Class in org.apache.flink.table.runtime.operators.window
-
The serializer used to write the CountWindow type.
- CountWindow.Serializer.CountWindowSerializerSnapshot - Class in org.apache.flink.table.runtime.operators.window
-
Serializer configuration snapshot for compatibility and format evolution.
- CountWindowSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer.CountWindowSerializerSnapshot
- cover(TimeWindow) - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow
-
Returns the minimal window covers both this window and the given window.
- create(Object, MemoryManager, long, RuntimeContext, WindowTimerService<Long>, KeyedStateBackend<RowData>, WindowState<Long>, boolean, ZoneId) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.buffers.RecordsWindowBuffer.Factory
- create(Object, MemoryManager, long, RuntimeContext, WindowTimerService<Long>, KeyedStateBackend<RowData>, WindowState<Long>, boolean, ZoneId) - Method in interface org.apache.flink.table.runtime.operators.aggregate.window.buffers.WindowBuffer.Factory
-
Creates a
WindowBuffer
that buffers elements in memory before flushing. - create(Object, MemoryManager, long, RuntimeContext, WindowTimerService<Long>, AsyncStateKeyContext, WindowAsyncState<Long>, boolean, ZoneId) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateRecordsWindowBuffer.Factory
- create(Object, MemoryManager, long, RuntimeContext, WindowTimerService<Long>, AsyncStateKeyContext, WindowAsyncState<Long>, boolean, ZoneId) - Method in interface org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateWindowBuffer.Factory
-
Creates a
WindowBuffer
that buffers elements in memory before flushing. - create(Object, MemoryManager, long, RuntimeContext, Collector<RowData>, ZoneId) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.buffers.RecordsWindowBuffer.LocalFactory
- create(Object, MemoryManager, long, RuntimeContext, Collector<RowData>, ZoneId) - Method in interface org.apache.flink.table.runtime.operators.aggregate.window.buffers.WindowBuffer.LocalFactory
-
Creates a
WindowBuffer
for local window that buffers elements in memory before flushing. - create(RuntimeContext, String, JoinInputSideSpec, InternalTypeInfo<RowData>, long) - Static method in class org.apache.flink.table.runtime.operators.join.stream.state.JoinRecordStateViews
-
Creates a
JoinRecordStateView
depends onJoinInputSideSpec
. - create(RuntimeContext, String, JoinInputSideSpec, InternalTypeInfo<RowData>, long) - Static method in class org.apache.flink.table.runtime.operators.join.stream.state.OuterJoinRecordStateViews
-
Creates a
OuterJoinRecordStateView
depends onJoinInputSideSpec
. - create(StreamingRuntimeContext, String, JoinInputSideSpec, InternalTypeInfo<RowData>, long) - Static method in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.JoinRecordAsyncStateViews
-
Creates a
JoinRecordAsyncStateView
depends onJoinInputSideSpec
. - create(StreamingRuntimeContext, String, JoinInputSideSpec, InternalTypeInfo<RowData>, long) - Static method in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.OuterJoinRecordAsyncStateViews
-
Creates a
OuterJoinRecordAsyncStateView
depends onJoinInputSideSpec
. - create(DataType) - Static method in class org.apache.flink.table.data.conversion.ArrayListConverter
- create(DataType) - Static method in class org.apache.flink.table.data.conversion.ArrayObjectArrayConverter
- create(DataType) - Static method in class org.apache.flink.table.data.conversion.RawByteArrayConverter
- create(DataType) - Static method in class org.apache.flink.table.data.conversion.RawObjectConverter
- create(DataType) - Static method in class org.apache.flink.table.data.conversion.RowRowConverter
- create(DataType) - Static method in class org.apache.flink.table.data.conversion.StructuredObjectConverter
- create(DataType) - Static method in class org.apache.flink.table.data.conversion.YearMonthIntervalPeriodConverter
- create(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.InternalSerializers
-
Creates a
TypeSerializer
for internal data structures of the givenLogicalType
. - create(RowType) - Static method in class org.apache.flink.table.runtime.typeutils.InternalSerializers
-
Creates a
TypeSerializer
for internal data structures of the givenRowType
. - create(YearMonthIntervalType) - Static method in class org.apache.flink.table.data.conversion.YearMonthIntervalPeriodConverter
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction
- createAccumulator() - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- createAccumulators() - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunctionBase
-
Initializes the accumulators and save them to a accumulators row.
- createAccumulators() - Method in interface org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunctionBase
-
Initializes the accumulators and save them to a accumulators row.
- createArrayNode() - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
-
Returns a new
ArrayNode
. - createAsyncFuture(DataStructureConverter<Object, Object>) - Method in class org.apache.flink.table.runtime.operators.calc.async.DelegatingAsyncResultFuture
- createBlockChannelReader(IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>, boolean, BlockCompressionFactory, int, int) - Static method in class org.apache.flink.table.runtime.util.FileChannelUtil
- createBlockChannelWriter(IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>, boolean, BlockCompressionFactory, int, int) - Static method in class org.apache.flink.table.runtime.util.FileChannelUtil
- createBuffer(NormalizedKeyComputer, AbstractRowDataSerializer<RowData>, BinaryRowDataSerializer, RecordComparator, MemorySegmentPool) - Static method in class org.apache.flink.table.runtime.operators.sort.BinaryInMemorySortBuffer
-
Create a memory sorter in `insert` way.
- createBuffer(NormalizedKeyComputer, BinaryRowDataSerializer, BinaryRowDataSerializer, RecordComparator, ArrayList<MemorySegment>, long, MemorySegmentPool) - Static method in class org.apache.flink.table.runtime.operators.sort.BinaryKVInMemorySortBuffer
- createDataStructureConverter(DataType) - Method in class org.apache.flink.table.runtime.connector.sink.SinkRuntimeProviderContext
- createDataStructureConverter(DataType) - Method in class org.apache.flink.table.runtime.connector.source.LookupRuntimeProviderContext
- createDataStructureConverter(DataType) - Method in class org.apache.flink.table.runtime.connector.source.ScanRuntimeProviderContext
- createDecodingFormat(DynamicTableFactory.Context, ReadableConfig) - Method in class org.apache.flink.formats.raw.RawFormatFactory
- createEncodingFormat(DynamicTableFactory.Context, ReadableConfig) - Method in class org.apache.flink.formats.raw.RawFormatFactory
- createFetcherResultFuture(Configuration) - Method in class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinRunner
- createFetcherResultFuture(Configuration) - Method in class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinWithCalcRunner
- createForElement(DataType) - Static method in class org.apache.flink.table.data.conversion.ArrayObjectArrayConverter
- createForMapType(DataType) - Static method in class org.apache.flink.table.data.conversion.MapMapConverter
- createForMultisetType(DataType) - Static method in class org.apache.flink.table.data.conversion.MapMapConverter
- createInputView(FileIOChannel.ID, int, int) - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- createInputView(IOManager, ChannelWithMeta, List<FileIOChannel>, boolean, BlockCompressionFactory, int, int) - Static method in class org.apache.flink.table.runtime.util.FileChannelUtil
- createInstance() - Method in class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- createInstance() - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- createInstance() - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- createNullSetter(LogicalType) - Static method in class org.apache.flink.table.data.writer.BinaryArrayWriter
-
Creates an for accessor setting the elements of an array writer to
null
during runtime. - createObjectNode() - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
-
Returns a new
ObjectNode
. - createOnHeapBloomFilter(int) - Static method in class org.apache.flink.table.runtime.operators.runtimefilter.util.RuntimeFilterUtils
- createOperator(StreamOperatorParameters<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer.ExternalSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer.LinkedListSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer.RawValueDataSerializerSnapshot
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer.WindowKeySerializerSnapshot
- createOutputView(IOManager, FileIOChannel.ID, boolean, BlockCompressionFactory, int, int) - Static method in class org.apache.flink.table.runtime.util.FileChannelUtil
- createRecordsCombiner(RuntimeContext, WindowTimerService<Long>, KeyedStateBackend<RowData>, WindowState<Long>, boolean) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.combines.AggCombiner.Factory
- createRecordsCombiner(RuntimeContext, WindowTimerService<Long>, KeyedStateBackend<RowData>, WindowState<Long>, boolean) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.combines.GlobalAggCombiner.Factory
- createRecordsCombiner(RuntimeContext, WindowTimerService<Long>, KeyedStateBackend<RowData>, WindowState<Long>, boolean) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.combines.RowTimeDeduplicateRecordsCombiner.Factory
- createRecordsCombiner(RuntimeContext, WindowTimerService<Long>, KeyedStateBackend<RowData>, WindowState<Long>, boolean) - Method in class org.apache.flink.table.runtime.operators.rank.window.combines.TopNRecordsCombiner.Factory
- createRecordsCombiner(RuntimeContext, WindowTimerService<Long>, KeyedStateBackend<RowData>, WindowState<Long>, boolean) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.combines.RecordsCombiner.Factory
-
Creates a
RecordsCombiner
that can combine buffered data into states. - createRecordsCombiner(RuntimeContext, WindowTimerService<Long>, WindowAsyncState<Long>, boolean) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines.AsyncStateAggCombiner.Factory
- createRecordsCombiner(RuntimeContext, WindowTimerService<Long>, WindowAsyncState<Long>, boolean) - Method in interface org.apache.flink.table.runtime.operators.window.async.tvf.combines.AsyncStateRecordsCombiner.Factory
-
Creates a
AsyncStateRecordsCombiner
that can combine buffered data into async states. - createRecordsCombiner(RuntimeContext, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.combines.LocalAggCombiner.Factory
- createRecordsCombiner(RuntimeContext, Collector<RowData>) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.combines.RecordsCombiner.LocalFactory
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.runtime.typeutils.SortedMapTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- createStreamConfig(StreamOperatorParameters<RowData>, TableOperatorWrapper<?>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.BatchMultipleInputStreamOperator
- createStreamConfig(StreamOperatorParameters<RowData>, TableOperatorWrapper<?>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.MultipleInputStreamOperatorBase
- createStreamOperator(StreamOperatorParameters) - Method in class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperatorFactory
- createStreamOperator(StreamOperatorParameters<Object>) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorFactory
- createStreamOperator(StreamOperatorParameters<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.BatchMultipleInputStreamOperatorFactory
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.table.runtime.operators.CodeGenOperatorFactory
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.table.runtime.operators.fusion.OperatorFusionCodegenFactory
- createStreamOperator(StreamOperatorParameters<OUT>) - Method in class org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoinOperatorFactory
- createTtlConfig(long) - Static method in class org.apache.flink.table.runtime.util.StateConfigUtil
-
Creates a
StateTtlConfig
depends on retentionTime parameter. - createTypeInformation(DataType) - Method in class org.apache.flink.table.runtime.connector.sink.SinkRuntimeProviderContext
- createTypeInformation(DataType) - Method in class org.apache.flink.table.runtime.connector.source.LookupRuntimeProviderContext
- createTypeInformation(DataType) - Method in class org.apache.flink.table.runtime.connector.source.ScanRuntimeProviderContext
- createTypeInformation(LogicalType) - Method in class org.apache.flink.table.runtime.connector.sink.SinkRuntimeProviderContext
- createTypeInformation(LogicalType) - Method in class org.apache.flink.table.runtime.connector.source.LookupRuntimeProviderContext
- createTypeInformation(LogicalType) - Method in class org.apache.flink.table.runtime.connector.source.ScanRuntimeProviderContext
- createValueSetter(LogicalType) - Static method in interface org.apache.flink.table.data.writer.BinaryWriter
-
Creates an accessor for setting the elements of an array writer during runtime.
- createWatermarkGenerator(WatermarkGeneratorSupplier.Context) - Method in class org.apache.flink.table.runtime.generated.GeneratedWatermarkGeneratorSupplier
- createWindowSerializer() - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- createWindowSerializer() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- createWindowSerializer() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.UnsliceSyncStateWindowAggProcessor
- createWindowSerializer() - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.processors.RowTimeSyncStateWindowDeduplicateProcessor
- createWindowSerializer() - Method in class org.apache.flink.table.runtime.operators.rank.window.processors.SyncStateWindowRankProcessor
- createWindowSerializer() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowProcessor
-
Returns the serializer of the window type.
- ctx - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- ctx - Variable in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator
- ctx - Variable in class org.apache.flink.table.runtime.operators.bundle.MapBundleFunction
- ctx - Variable in class org.apache.flink.table.runtime.operators.TableStreamOperator
- ctx - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
- ctx - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.WindowTrigger
-
The
Trigger.TriggerContext
of the window trigger. - cumulative(int, ZoneId, Duration, Duration) - Static method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners
-
Creates a cumulative window
SliceAssigner
that assigns elements to slices of cumulative windows. - cumulative(Duration, Duration) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- CumulativeSliceAssigner(int, ZoneId, long, long, long) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- CumulativeWindowAssigner - Class in org.apache.flink.table.runtime.operators.window.groupwindow.assigners
-
A
GroupWindowAssigner
that windows elements into cumulative windows based on the timestamp of the elements. - CumulativeWindowAssigner(long, long, long, boolean) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- current() - Method in class org.apache.flink.table.runtime.hashtable.ProbeIterator
- currentEnumerator - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The channel enumerator that is used while processing the current partition to create channels for the spill partitions it requires.
- currentKey() - Method in interface org.apache.flink.table.runtime.context.ExecutionContext
- currentKey() - Method in class org.apache.flink.table.runtime.context.ExecutionContextImpl
- currentKey() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
- currentProcessingTime() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.ReloadTriggerContext
- currentProcessingTime() - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator.ContextImpl
- currentProcessingTime() - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator.ContextImpl
- currentProcessingTime() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Returns the current processing time.
- currentProcessingTime() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.ClockService
-
Returns the current processing time.
- currentProcessingTime() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerService
-
Returns the current processing time.
- currentProcessingTime() - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerServiceBase
- currentProgress - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- currentRecursionDepth - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The recursion depth of the partition that is currently processed.
- currentSortIndexOffset - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- currentSortIndexSegment - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- currentSpilledBuildSide - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The reader for the spilled-file of the build partition that is currently read.
- currentSpilledProbeSide - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The reader for the spilled-file of the probe partition that is currently read.
- currentWatermark - Variable in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator
-
We listen to this ourselves because we don't have an
InternalTimerService
. - currentWatermark - Variable in class org.apache.flink.table.runtime.operators.TableStreamOperator
-
We listen to this ourselves because we don't have an
InternalTimerService
. - currentWatermark() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.ReloadTriggerContext
- currentWatermark() - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator.ContextImpl
- currentWatermark() - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator.ContextImpl
- currentWatermark() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Returns the current event-time watermark.
- currentWatermark() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerService
-
Returns the current event-time watermark.
- currentWatermark() - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerServiceBase
- currentWatermark(RowData) - Method in class org.apache.flink.table.runtime.generated.WatermarkGenerator
-
Returns the watermark for the current row or null if no watermark should be generated.
- currentWatermark(RowData) - Method in class org.apache.flink.table.runtime.operators.wmassigners.BoundedOutOfOrderWatermarkGenerator
D
- DataFormatConverter() - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.DataFormatConverter
- DataFormatConverters - Class in org.apache.flink.table.data.util
-
Converters between internal data format and java format.
- DataFormatConverters() - Constructor for class org.apache.flink.table.data.util.DataFormatConverters
- DataFormatConverters.AbstractRowDataConverter<E> - Class in org.apache.flink.table.data.util
-
Abstract converter for internal base row.
- DataFormatConverters.ArrayDataConverter - Class in org.apache.flink.table.data.util
-
Converter for ArrayData.
- DataFormatConverters.BigDecimalConverter - Class in org.apache.flink.table.data.util
-
Converter for BigDecimal.
- DataFormatConverters.BooleanConverter - Class in org.apache.flink.table.data.util
-
Converter for boolean.
- DataFormatConverters.ByteConverter - Class in org.apache.flink.table.data.util
-
Converter for byte.
- DataFormatConverters.CaseClassConverter - Class in org.apache.flink.table.data.util
-
Converter for case class.
- DataFormatConverters.DataFormatConverter<Internal,External> - Class in org.apache.flink.table.data.util
-
Converter between internal data format and java format.
- DataFormatConverters.DateConverter - Class in org.apache.flink.table.data.util
-
Converter for date.
- DataFormatConverters.DecimalDataConverter - Class in org.apache.flink.table.data.util
-
Converter for DecimalData.
- DataFormatConverters.DoubleConverter - Class in org.apache.flink.table.data.util
-
Converter for double.
- DataFormatConverters.FloatConverter - Class in org.apache.flink.table.data.util
-
Converter for float.
- DataFormatConverters.GenericConverter<T> - Class in org.apache.flink.table.data.util
-
Converter for
RawValueData
. - DataFormatConverters.IdentityConverter<T> - Class in org.apache.flink.table.data.util
-
Identity converter.
- DataFormatConverters.InstantConverter - Class in org.apache.flink.table.data.util
-
Converter for Instant.
- DataFormatConverters.IntConverter - Class in org.apache.flink.table.data.util
-
Converter for int.
- DataFormatConverters.LocalDateConverter - Class in org.apache.flink.table.data.util
-
Converter for LocalDate.
- DataFormatConverters.LocalDateTimeConverter - Class in org.apache.flink.table.data.util
-
Converter for LocalDateTime.
- DataFormatConverters.LocalTimeConverter - Class in org.apache.flink.table.data.util
-
Converter for LocalTime.
- DataFormatConverters.LongConverter - Class in org.apache.flink.table.data.util
-
Converter for long.
- DataFormatConverters.LongTimestampDataConverter - Class in org.apache.flink.table.data.util
-
Converter for Long and TimestampData.
- DataFormatConverters.MapConverter - Class in org.apache.flink.table.data.util
-
Converter for map.
- DataFormatConverters.MapDataConverter - Class in org.apache.flink.table.data.util
-
Converter for MapData.
- DataFormatConverters.ObjectArrayConverter<T> - Class in org.apache.flink.table.data.util
-
Converter for object array.
- DataFormatConverters.PojoConverter<T> - Class in org.apache.flink.table.data.util
-
Converter for pojo.
- DataFormatConverters.PrimitiveBooleanArrayConverter - Class in org.apache.flink.table.data.util
-
Converter for primitive boolean array.
- DataFormatConverters.PrimitiveByteArrayConverter - Class in org.apache.flink.table.data.util
-
Converter for primitive byte array.
- DataFormatConverters.PrimitiveDoubleArrayConverter - Class in org.apache.flink.table.data.util
-
Converter for primitive double array.
- DataFormatConverters.PrimitiveFloatArrayConverter - Class in org.apache.flink.table.data.util
-
Converter for primitive float array.
- DataFormatConverters.PrimitiveIntArrayConverter - Class in org.apache.flink.table.data.util
-
Converter for primitive int array.
- DataFormatConverters.PrimitiveLongArrayConverter - Class in org.apache.flink.table.data.util
-
Converter for primitive long array.
- DataFormatConverters.PrimitiveShortArrayConverter - Class in org.apache.flink.table.data.util
-
Converter for primitive short array.
- DataFormatConverters.RawValueDataConverter - Class in org.apache.flink.table.data.util
-
Converter for RawValueData.
- DataFormatConverters.RowConverter - Class in org.apache.flink.table.data.util
-
Converter for row.
- DataFormatConverters.RowDataConverter - Class in org.apache.flink.table.data.util
-
Converter for base row.
- DataFormatConverters.ShortConverter - Class in org.apache.flink.table.data.util
-
Converter for short.
- DataFormatConverters.StringConverter - Class in org.apache.flink.table.data.util
-
Converter for String.
- DataFormatConverters.StringDataConverter - Class in org.apache.flink.table.data.util
-
Converter for StringData.
- DataFormatConverters.TimeConverter - Class in org.apache.flink.table.data.util
-
Converter for time.
- DataFormatConverters.TimestampConverter - Class in org.apache.flink.table.data.util
-
Converter for timestamp.
- DataFormatConverters.TimestampDataConverter - Class in org.apache.flink.table.data.util
-
Converter for
TimestampData
class. - DataFormatConverters.TimestampLtzConverter - Class in org.apache.flink.table.data.util
-
Converter for timestamp which doesn't consider the time zone.
- DataFormatConverters.TupleConverter - Class in org.apache.flink.table.data.util
-
Converter for flink tuple.
- DataStructureConverter<I,E> - Interface in org.apache.flink.table.data.conversion
-
Converter between internal and external data structure.
- DataStructureConverters - Class in org.apache.flink.table.data.conversion
-
Registry of available data structure converters.
- DataStructureConverters() - Constructor for class org.apache.flink.table.data.conversion.DataStructureConverters
- DataTypePrecisionFixer - Class in org.apache.flink.table.runtime.types
-
The data type visitor used to fix the precision for data type with the given logical type which carries the correct precisions.
- DataTypePrecisionFixer(LogicalType) - Constructor for class org.apache.flink.table.runtime.types.DataTypePrecisionFixer
-
Creates a new instance with the given logical type.
- DataViewSpec - Class in org.apache.flink.table.runtime.dataview
-
Information about a
DataView
stored in state. - DateApproxCountDistinctAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.DateApproxCountDistinctAggFunction
- DateDateConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
DateType
ofDate
external type. - DateDateConverter() - Constructor for class org.apache.flink.table.data.conversion.DateDateConverter
- DateLocalDateConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
DateType
ofLocalDate
external type. - DateLocalDateConverter() - Constructor for class org.apache.flink.table.data.conversion.DateLocalDateConverter
- DayTimeIntervalDurationConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
DayTimeIntervalType
ofDuration
external type. - DayTimeIntervalDurationConverter() - Constructor for class org.apache.flink.table.data.conversion.DayTimeIntervalDurationConverter
- DECIMAL_SYSTEM_DEFAULT - Static variable in class org.apache.flink.table.data.DecimalDataUtils
- DecimalApproxCountDistinctAggFunction(DecimalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.DecimalApproxCountDistinctAggFunction
- DecimalBigDecimalConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
DecimalType
ofBigDecimal
external type. - DecimalDataConverter(int, int) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.DecimalDataConverter
- DecimalDataSerializer - Class in org.apache.flink.table.runtime.typeutils
-
Serializer for
DecimalData
. - DecimalDataSerializer(int, int) - Constructor for class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- DecimalDataSerializer.DecimalSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils
-
TypeSerializerSnapshot
forDecimalDataSerializer
. - DecimalDataTypeInfo - Class in org.apache.flink.table.runtime.typeutils
-
TypeInformation for
DecimalData
. - DecimalDataTypeInfo(int, int) - Constructor for class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- DecimalDataUtils - Class in org.apache.flink.table.data
-
Utilities for
DecimalData
. - DecimalDataUtils() - Constructor for class org.apache.flink.table.data.DecimalDataUtils
- DecimalSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer.DecimalSerializerSnapshot
- decodeUTF8(byte[], int, int) - Static method in class org.apache.flink.table.runtime.util.StringUtf8Utils
- decodeUTF8(MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.util.StringUtf8Utils
- decodeUTF8Strict(byte[], int, int, char[]) - Static method in class org.apache.flink.table.runtime.util.StringUtf8Utils
- decodeUTF8Strict(MemorySegment, int, int, char[]) - Static method in class org.apache.flink.table.runtime.util.StringUtf8Utils
- DeduplicateFunctionBase<T,K,IN,OUT> - Class in org.apache.flink.table.runtime.operators.deduplicate
-
Base class for deduplicate function.
- DeduplicateFunctionBase(TypeInformation<T>, TypeSerializer<OUT>, long) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.DeduplicateFunctionBase
- DeduplicateFunctionHelper - Class in org.apache.flink.table.runtime.operators.deduplicate.utils
-
Utility for deduplicate function.
- deduplicateOnRowTime(RowData, RowData, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.utils.RowTimeDeduplicateFunctionHelper
-
Processes element to deduplicate on keys with row time semantic, sends current element if it is last or first row, retracts previous element if needed.
- DEFAULT_INITIAL_SIZE - Static variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
The initial default size of a hash table.
- DEFAULT_LOAD_FACTOR - Static variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
The default load factor of a hash table.
- DEFAULT_SEED - Static variable in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.XXH64
- DEFAULT_SEED - Static variable in class org.apache.flink.table.runtime.util.MurmurHashUtil
- DefaultAccMergingConsumer(InternalWindowProcessFunction.Context<?, W>, NamespaceAggsHandleFunctionBase<W>) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowProcessFunction.DefaultAccMergingConsumer
- defaultDecodeUTF8(byte[], int, int) - Static method in class org.apache.flink.table.runtime.util.StringUtf8Utils
- defaultEncodeUTF8(String, byte[]) - Static method in class org.apache.flink.table.runtime.util.StringUtf8Utils
- DefaultExpressionEvaluator - Class in org.apache.flink.table.runtime.functions
-
Default runtime implementation for
SpecializedFunction.ExpressionEvaluator
. - DefaultExpressionEvaluator(GeneratedFunction<RichFunction>, Class<?>, Class<?>[], String) - Constructor for class org.apache.flink.table.runtime.functions.DefaultExpressionEvaluator
- defaultValue - Variable in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction.LagAcc
- DefaultWatermarkGenerator(WatermarkGenerator, WatermarkEmitStrategy) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedWatermarkGeneratorSupplier.DefaultWatermarkGenerator
- degrees(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- DelegatingAsyncResultFuture - Class in org.apache.flink.table.runtime.operators.calc.async
-
Inspired by
DelegatingResultFuture
forAsyncScalarFunction
. - DelegatingAsyncResultFuture(ResultFuture<Object>) - Constructor for class org.apache.flink.table.runtime.operators.calc.async.DelegatingAsyncResultFuture
- DelegatingResultFuture<OUT> - Class in org.apache.flink.table.runtime.operators.join.lookup
-
Delegates actions of
CompletableFuture
toResultFuture
. - DelegatingResultFuture(ResultFuture<OUT>) - Constructor for class org.apache.flink.table.runtime.operators.join.lookup.DelegatingResultFuture
- deleteChannel() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- deleteChannel() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- deleteCleanupTimer(W) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Deletes the cleanup timer set for the contents of the provided window.
- deleteEventTimeTimer(long) - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator.ContextImpl
- deleteEventTimeTimer(long) - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator.ContextImpl
- deleteEventTimeTimer(long) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger.TriggerContext
-
Delete the event-time trigger for the given time.
- deleteProcessingTimeTimer(long) - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator.ContextImpl
- deleteProcessingTimeTimer(long) - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator.ContextImpl
- deleteProcessingTimeTimer(long) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger.TriggerContext
-
Delete the processing time trigger for the given time.
- delimiter - Variable in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator
- DENSE_RANK - org.apache.flink.table.runtime.operators.rank.RankType
-
is similar to the RANK by generating a unique rank number for each distinct row within the partition based on the order, starting at 1 for the first row in each partition, ranking the rows with equal values with the same rank number, except that it does not skip any rank, leaving no gaps between the ranks.
- DENSE_THRESHOLD - Static variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Decide whether to convert to dense mode if it does not require more memory or could fit within L1 cache.
- deserialize(byte[]) - Method in class org.apache.flink.formats.raw.RawFormatDeserializationSchema
- deserialize(E, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- deserialize(LinkedList<T>, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- deserialize(ArrayData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- deserialize(BinaryRowData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- deserialize(DecimalData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- deserialize(MapData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- deserialize(RawValueData<T>, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- deserialize(RowData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- deserialize(StringData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- deserialize(TimestampData, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- deserialize(CountWindow, DataInputView) - Method in class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- deserialize(TimeWindow, DataInputView) - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- deserialize(WindowKey, DataInputView) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- deserializeFromPages(AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- deserializeFromPages(AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.PagedTypeSerializer
-
De-serializes a record from the given source paged input view.
- deserializeFromPages(AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- deserializeFromPages(AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- deserializeFromPages(BinaryRowData, ChannelReaderInputView, BinaryRowDataSerializer) - Static method in class org.apache.flink.table.runtime.hashtable.LongHashPartition
- deserializeFromPages(BinaryRowData, AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- deserializeFromPages(RowData, AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- deserializeFromPages(WindowKey, AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- deserializeFromPages(T, AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.PagedTypeSerializer
-
Reuse version of
PagedTypeSerializer.deserializeFromPages(AbstractPagedInputView)
. - deserializeInternal(DataInputView) - Static method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- disableTestMode() - Static method in class org.apache.flink.table.runtime.application.SqlDriver
- dispose() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryInMemorySortBuffer
- divide(DecimalData, DecimalData, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- divideInt(int, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- divideToIntegralValue(DecimalData, DecimalData, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
-
Returns a
DecimalData
whose value is the integer part of the quotient(this / divisor)
rounded down. - doFetch(RowData) - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- DoubleApproxCountDistinctAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.DoubleApproxCountDistinctAggFunction
- DoubleHashSet - Class in org.apache.flink.table.runtime.util.collections
-
Double hash set.
- DoubleHashSet() - Constructor for class org.apache.flink.table.runtime.util.collections.DoubleHashSet
- DoubleHashSet(int) - Constructor for class org.apache.flink.table.runtime.util.collections.DoubleHashSet
- DoubleHashSet(int, float) - Constructor for class org.apache.flink.table.runtime.util.collections.DoubleHashSet
- doubleValue(DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- DropUpdateBeforeFunction - Class in org.apache.flink.table.runtime.operators.misc
-
A function drops only rows with
RowKind.UPDATE_BEFORE
changelog kind. - DropUpdateBeforeFunction() - Constructor for class org.apache.flink.table.runtime.operators.misc.DropUpdateBeforeFunction
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- duplicate() - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- DynamicFilteringDataCollectorOperator - Class in org.apache.flink.table.runtime.operators.dynamicfiltering
-
Operator to collect and build the
DynamicFilteringData
for sources that supports dynamic filtering. - DynamicFilteringDataCollectorOperator(StreamOperatorParameters<Object>, RowType, List<Integer>, long, OperatorEventGateway) - Constructor for class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperator
- DynamicFilteringDataCollectorOperatorCoordinator - Class in org.apache.flink.table.runtime.operators.dynamicfiltering
-
The operator coordinator for
DynamicFilteringDataCollectorOperator
. - DynamicFilteringDataCollectorOperatorCoordinator(OperatorCoordinator.Context, List<String>) - Constructor for class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- DynamicFilteringDataCollectorOperatorCoordinator.Provider - Class in org.apache.flink.table.runtime.operators.dynamicfiltering
-
Provider for
DynamicFilteringDataCollectorOperatorCoordinator
. - DynamicFilteringDataCollectorOperatorFactory - Class in org.apache.flink.table.runtime.operators.dynamicfiltering
-
The factory class for
DynamicFilteringDataCollectorOperator
. - DynamicFilteringDataCollectorOperatorFactory(RowType, List<Integer>, long) - Constructor for class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorFactory
E
- Edge(TableOperatorWrapper<?>, TableOperatorWrapper<?>, int) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper.Edge
- element - Variable in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator.ContextImpl
- element - Variable in class org.apache.flink.table.runtime.operators.TableStreamOperator.ContextImpl
- ELEMENT_POINT_LENGTH - Static variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- ElementTriggers - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A
Trigger
that fires at some point after a specified number of input elements have arrived. - ElementTriggers.CountElement<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A
Trigger
that fires at some point after a specified number of input elements have arrived. - ElementTriggers.EveryElement<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A
Trigger
that triggers on every element. - EltFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ELT
. - EltFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.EltFunction
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.BroadcastingOutput
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingSecondInputOfTwoInputStreamOperatorOutput
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.FirstInputOfTwoInputStreamOperatorOutput
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.OneInputStreamOperatorOutput
- emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.SecondInputOfTwoInputStreamOperatorOutput
- emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.BroadcastingOutput
- emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingSecondInputOfTwoInputStreamOperatorOutput
- emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.FirstInputOfTwoInputStreamOperatorOutput
- emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.OneInputStreamOperatorOutput
- emitRecordAttributes(RecordAttributes) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.SecondInputOfTwoInputStreamOperatorOutput
- emitValue(N, RowData, Collector<RowData>) - Method in interface org.apache.flink.table.runtime.generated.NamespaceTableAggsHandleFunction
-
Emits the result of the aggregation from the current accumulators and namespace properties (like window start).
- emitValue(Collector<RowData>, RowData, boolean) - Method in interface org.apache.flink.table.runtime.generated.TableAggsHandleFunction
-
Emit the result of the table aggregation through the collector.
- emitWatermark(WatermarkEvent) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.BroadcastingOutput
- emitWatermark(WatermarkEvent) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingSecondInputOfTwoInputStreamOperatorOutput
- emitWatermark(WatermarkEvent) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.FirstInputOfTwoInputStreamOperatorOutput
- emitWatermark(WatermarkEvent) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.OneInputStreamOperatorOutput
- emitWatermark(WatermarkEvent) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.SecondInputOfTwoInputStreamOperatorOutput
- emitWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.BroadcastingOutput
- emitWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingSecondInputOfTwoInputStreamOperatorOutput
- emitWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.FirstInputOfTwoInputStreamOperatorOutput
- emitWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.OneInputStreamOperatorOutput
- emitWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.SecondInputOfTwoInputStreamOperatorOutput
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.BroadcastingOutput
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingSecondInputOfTwoInputStreamOperatorOutput
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.FirstInputOfTwoInputStreamOperatorOutput
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.OneInputStreamOperatorOutput
- emitWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.SecondInputOfTwoInputStreamOperatorOutput
- emitWindowResult(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.AggregateWindowOperator
- emitWindowResult(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.TableAggregateWindowOperator
- emitWindowResult(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
-
Emits the window result of the given window.
- EMPTY_RESPONSE - Static variable in class org.apache.flink.table.runtime.operators.calc.async.RetryPredicates
- EMPTY_ROW - Static variable in class org.apache.flink.table.data.binary.BinaryRowDataUtil
- EMPTY_STRING_ARRAY - Static variable in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- emptyChecker - Variable in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateWindowAggProcessor
- EmptyResponseResultStrategy() - Constructor for class org.apache.flink.table.runtime.operators.calc.async.RetryPredicates.EmptyResponseResultStrategy
- EmptyRowDataKeySelector - Class in org.apache.flink.table.runtime.keyselector
-
A utility class which key is always empty no matter what the input row is.
- EmptyRowDataKeySelector() - Constructor for class org.apache.flink.table.runtime.keyselector.EmptyRowDataKeySelector
- emptySupplier - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSyncStateWindowAggProcessor
- enableAsyncState() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- enableAsyncState() - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- enableTestMode(OutputStream) - Static method in class org.apache.flink.table.runtime.application.SqlDriver
- encodeUTF8(String) - Static method in class org.apache.flink.table.runtime.util.StringUtf8Utils
-
This method must have the same result with JDK's String.getBytes.
- encodeUTF8(String, byte[]) - Static method in class org.apache.flink.table.runtime.util.StringUtf8Utils
- END_OF_LIST - Static variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- endBuild() - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
-
End build phase.
- endBuild() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- ENDIANNESS - Static variable in class org.apache.flink.formats.raw.RawFormatOptions
- endInput() - Method in class org.apache.flink.table.runtime.operators.over.BufferDataOverWindowOperator
- endInput() - Method in class org.apache.flink.table.runtime.operators.runtimefilter.GlobalRuntimeFilterBuilderOperator
- endInput() - Method in class org.apache.flink.table.runtime.operators.runtimefilter.LocalRuntimeFilterBuilderOperator
- endInput() - Method in class org.apache.flink.table.runtime.operators.sort.SortLimitOperator
- endInput() - Method in class org.apache.flink.table.runtime.operators.sort.SortOperator
- endInput(int) - Method in class org.apache.flink.table.runtime.operators.join.HashJoinOperator
- endInput(int) - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinFunction
- endInput(int) - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinOperator
- endInput(int) - Method in class org.apache.flink.table.runtime.operators.multipleinput.BatchMultipleInputStreamOperator
- endInput(int) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSelectionHandler
- endInput(int) - Method in class org.apache.flink.table.runtime.operators.multipleinput.UnionStreamOperator
- endOperatorInput(int) - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- EndsWithFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.ENDS_WITH
. - EndsWithFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.EndsWithFunction
- ensureNumBuffersReturned(int) - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
This method makes sure that at least a certain number of memory segments is in the list of free segments.
- entries(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
-
Returns all the mappings in the state.
- entrySet() - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Returns a
Set
view of the mappings contained in the buffer. - equaliser - Variable in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
- equaliser - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.AggregateWindowOperator
-
The util to compare two RowData equals to each other.
- EqualityAndHashcodeProvider - Class in org.apache.flink.table.runtime.util
-
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.
- EqualityAndHashcodeProvider(SpecializedFunction.SpecializedContext, DataType) - Constructor for class org.apache.flink.table.runtime.util.EqualityAndHashcodeProvider
- equals(Object) - Method in class org.apache.flink.formats.raw.RawFormatDeserializationSchema
- equals(Object) - Method in class org.apache.flink.formats.raw.RawFormatSerializationSchema
- equals(Object) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction.ArrayAggAccumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction.CollectAccumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HllBuffer
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction.Accumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction.Accumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction.LagAcc
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction.LastValueWithRetractAccumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction.ListAggWithRetractAccumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction.MaxWithRetractAccumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction.MinWithRetractAccumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.PercentileAccumulator
- equals(Object) - Method in class org.apache.flink.table.runtime.groupwindow.WindowReference
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSelectionSpec
- equals(Object) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSpec
- equals(Object) - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper.Edge
- equals(Object) - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- equals(Object) - Method in class org.apache.flink.table.runtime.operators.rank.ComparableRecordComparator
- equals(Object) - Method in class org.apache.flink.table.runtime.operators.window.CountWindow
- equals(Object) - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow
- equals(Object) - Method in class org.apache.flink.table.runtime.operators.window.Window
- equals(Object) - Method in class org.apache.flink.table.runtime.partitioner.BinaryHashPartitioner
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.BigDecimalTypeInfo
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.LegacyInstantTypeInfo
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.LegacyLocalDateTimeTypeInfo
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.LegacyTimestampTypeInfo
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.SortedMapTypeInfo
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- equals(Object) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- equals(Object) - Method in class org.apache.flink.table.runtime.util.ObjectContainer
- equals(Object) - Method in class org.apache.flink.table.runtime.util.WindowKey
- equals(Object, Object) - Method in class org.apache.flink.table.runtime.util.EqualityAndHashcodeProvider
- equals(MemorySegment[], int, MemorySegment[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
Equals two memory segments regions.
- equals(RowData, RowData) - Method in interface org.apache.flink.table.runtime.generated.RecordEqualiser
-
Returns
true
if the rows are equal to each other andfalse
otherwise. - ERROR_MESSAGE - Static variable in class org.apache.flink.table.runtime.functions.scalar.SourceWatermarkFunction
- estimateBias(double) - Method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HyperLogLogPlusPlus
-
Estimate the bias using the raw estimates with their respective biases from the HLL++ appendix.
- eval() - Method in class org.apache.flink.table.runtime.functions.scalar.SourceWatermarkFunction
- eval(byte[], byte[]) - Method in class org.apache.flink.table.runtime.functions.scalar.EndsWithFunction
- eval(byte[], byte[]) - Method in class org.apache.flink.table.runtime.functions.scalar.StartsWithFunction
- eval(Number) - Method in class org.apache.flink.table.runtime.functions.scalar.ToTimestampLtzFunction
- eval(Number, Integer) - Method in class org.apache.flink.table.runtime.functions.scalar.ToTimestampLtzFunction
- eval(Number, Object...) - Method in class org.apache.flink.table.runtime.functions.scalar.EltFunction
- eval(Object) - Method in class org.apache.flink.table.runtime.functions.scalar.JsonQuoteFunction
- eval(Object) - Method in class org.apache.flink.table.runtime.functions.scalar.JsonUnquoteFunction
- eval(Object...) - Method in class org.apache.flink.table.runtime.functions.scalar.CoalesceFunction
- eval(Object...) - Method in class org.apache.flink.table.runtime.functions.scalar.TypeOfFunction
- eval(Object...) - Method in class org.apache.flink.table.runtime.functions.table.ReplicateRowsFunction
- eval(Object, Object) - Method in class org.apache.flink.table.runtime.functions.scalar.IfNullFunction
- eval(ArrayData) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayDistinctFunction
- eval(ArrayData) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayMaxFunction
- eval(ArrayData) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayMinFunction
- eval(ArrayData) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayReverseFunction
- eval(ArrayData) - Method in class org.apache.flink.table.runtime.functions.scalar.ArraySortFunction
- eval(ArrayData) - Method in class org.apache.flink.table.runtime.functions.table.UnnestRowsFunction.CollectionUnnestTableFunction
- eval(ArrayData...) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayConcatFunction
- eval(ArrayData, Boolean) - Method in class org.apache.flink.table.runtime.functions.scalar.ArraySortFunction
- eval(ArrayData, Boolean, Boolean) - Method in class org.apache.flink.table.runtime.functions.scalar.ArraySortFunction
- eval(ArrayData, Integer) - Method in class org.apache.flink.table.runtime.functions.scalar.ArraySliceFunction
- eval(ArrayData, Integer, Integer) - Method in class org.apache.flink.table.runtime.functions.scalar.ArraySliceFunction
- eval(ArrayData, Object) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayAppendFunction
- eval(ArrayData, Object) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayContainsFunction
- eval(ArrayData, Object) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayPositionFunction
- eval(ArrayData, Object) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayPrependFunction
- eval(ArrayData, Object) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayRemoveFunction
- eval(ArrayData, ArrayData) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayExceptFunction
- eval(ArrayData, ArrayData) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayIntersectFunction
- eval(ArrayData, ArrayData) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayUnionFunction
- eval(ArrayData, ArrayData) - Method in class org.apache.flink.table.runtime.functions.scalar.MapFromArraysFunction
- eval(ArrayData, StringData, StringData...) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayJoinFunction
- eval(DecimalData) - Method in class org.apache.flink.table.runtime.functions.scalar.ToTimestampLtzFunction
- eval(DecimalData, Integer) - Method in class org.apache.flink.table.runtime.functions.scalar.ToTimestampLtzFunction
- eval(MapData) - Method in class org.apache.flink.table.runtime.functions.scalar.MapEntriesFunction
- eval(MapData) - Method in class org.apache.flink.table.runtime.functions.scalar.MapKeysFunction
- eval(MapData) - Method in class org.apache.flink.table.runtime.functions.scalar.MapValuesFunction
- eval(MapData) - Method in class org.apache.flink.table.runtime.functions.table.UnnestRowsFunction.CollectionUnnestTableFunction
- eval(MapData) - Method in class org.apache.flink.table.runtime.functions.table.UnnestRowsFunction.MapUnnestTableFunction
- eval(MapData...) - Method in class org.apache.flink.table.runtime.functions.scalar.MapUnionFunction
- eval(StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.BTrimFunction
- eval(StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.ToTimestampLtzFunction
- eval(StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.UnhexFunction
- eval(StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.UrlDecodeFunction
- eval(StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.UrlEncodeFunction
- eval(StringData, Object...) - Method in class org.apache.flink.table.runtime.functions.scalar.PrintfFunction
- eval(StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.BTrimFunction
- eval(StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.EndsWithFunction
- eval(StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.RegexpCountFunction
- eval(StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.RegexpExtractAllFunction
- eval(StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.RegexpInstrFunction
- eval(StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.RegexpSubstrFunction
- eval(StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.SplitFunction
- eval(StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.StartsWithFunction
- eval(StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.ToTimestampLtzFunction
- eval(StringData, StringData, Number) - Method in class org.apache.flink.table.runtime.functions.scalar.RegexpExtractAllFunction
- eval(StringData, StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.ToTimestampLtzFunction
- eval(StringData, StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.scalar.TranslateFunction
- EventTimeTriggers - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A
Trigger
that reacts to event-time timers. - EventTimeTriggers.AfterEndOfWindow<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A
Trigger
that fires once the watermark passes the end of the window to which a pane belongs. - EventTimeTriggers.AfterEndOfWindowEarlyAndLate<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A composite
Trigger
that consist of AfterEndOfWindow and a early trigger and late trigger. - EventTimeTriggers.AfterEndOfWindowNoLate<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A composite
Trigger
that consist of AfterEndOfWindow and a late trigger. - every() - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers
-
Creates a new trigger that triggers on receiving of every element.
- every(Duration) - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers
-
Creates a trigger that fires by a certain interval after reception of the first element.
- EveryElement() - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.EveryElement
- ExceptionInMultipleInputOperatorException - Exception in org.apache.flink.table.runtime.operators.multipleinput.output
-
A special exception that signifies that the cause exception came from a
MultipleInputStreamOperatorBase
. - ExceptionInMultipleInputOperatorException(String, Throwable) - Constructor for exception org.apache.flink.table.runtime.operators.multipleinput.output.ExceptionInMultipleInputOperatorException
- ExceptionInMultipleInputOperatorException(Throwable) - Constructor for exception org.apache.flink.table.runtime.operators.multipleinput.output.ExceptionInMultipleInputOperatorException
- executionAttemptFailed(int, int, Throwable) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- executionAttemptReady(int, int, OperatorCoordinator.SubtaskGateway) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- ExecutionContext - Interface in org.apache.flink.table.runtime.context
-
A ExecutionContext contains information about the context in which functions are executed and the APIs to create state.
- ExecutionContextImpl - Class in org.apache.flink.table.runtime.context
-
Implementation of ExecutionContext.
- ExecutionContextImpl(AbstractStreamOperator<?>, RuntimeContext) - Constructor for class org.apache.flink.table.runtime.context.ExecutionContextImpl
- exp(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- expiredSlices(long) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigner
-
Returns an iterator of slices to expire when the given window is emitted.
- expiredSlices(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- expiredSlices(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- expiredSlices(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.TumblingSliceAssigner
- expiredSlices(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.WindowedSliceAssigner
- explain() - Method in interface org.apache.flink.table.runtime.operators.bundle.trigger.BundleTrigger
- explain() - Method in interface org.apache.flink.table.runtime.operators.bundle.trigger.CoBundleTrigger
- explain() - Method in class org.apache.flink.table.runtime.operators.bundle.trigger.CountBundleTrigger
- explain() - Method in class org.apache.flink.table.runtime.operators.bundle.trigger.CountCoBundleTrigger
- ExternalSerializer<I,E> - Class in org.apache.flink.table.runtime.typeutils
-
A serializer that can serialize and deserialize all data structures defined by a
DataType
. - ExternalSerializer.ExternalSerializerSnapshot<I,E> - Class in org.apache.flink.table.runtime.typeutils
-
TypeSerializerSnapshot
forExternalSerializer
. - ExternalSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.ExternalSerializer.ExternalSerializerSnapshot
- ExternalSerializerSnapshot(ExternalSerializer<I, E>) - Constructor for class org.apache.flink.table.runtime.typeutils.ExternalSerializer.ExternalSerializerSnapshot
- ExternalTypeInfo<T> - Class in org.apache.flink.table.runtime.typeutils
-
Type information that wraps a serializer that originated from a
DataType
. - extractTimestamp(RowData, long) - Method in class org.apache.flink.table.runtime.operators.wmassigners.PeriodicWatermarkAssignerWrapper
- extractTimestamp(RowData, long) - Method in class org.apache.flink.table.runtime.operators.wmassigners.PunctuatedWatermarkStrategyWrapper
F
- f - Variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
The acceptable load factor.
- Factory(TypeSerializer<RowData>, int, boolean) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.window.combines.RowTimeDeduplicateRecordsCombiner.Factory
- Factory(GeneratedNamespaceAggsHandleFunction<Long>) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines.AsyncStateAggCombiner.Factory
- Factory(GeneratedNamespaceAggsHandleFunction<Long>) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.combines.AggCombiner.Factory
- Factory(GeneratedNamespaceAggsHandleFunction<Long>) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.combines.LocalAggCombiner.Factory
- Factory(GeneratedNamespaceAggsHandleFunction<Long>, GeneratedNamespaceAggsHandleFunction<Long>) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.combines.GlobalAggCombiner.Factory
- Factory(GeneratedRecordComparator, RowDataKeySelector, TypeSerializer<RowData>, long) - Constructor for class org.apache.flink.table.runtime.operators.rank.window.combines.TopNRecordsCombiner.Factory
- Factory(PagedTypeSerializer<RowData>, AbstractRowDataSerializer<RowData>, AsyncStateRecordsCombiner.Factory, GeneratedRecordEqualiser) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateRecordsWindowBuffer.Factory
- Factory(PagedTypeSerializer<RowData>, AbstractRowDataSerializer<RowData>, RecordsCombiner.Factory) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.buffers.RecordsWindowBuffer.Factory
- factoryIdentifier() - Method in class org.apache.flink.formats.raw.RawFormatFactory
- FALSE_STRING - Static variable in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- FastTop1Function - Class in org.apache.flink.table.runtime.operators.rank
-
A more concise implementation for
AppendOnlyTopNFunction
andUpdatableTopNFunction
when only Top-1 is desired. - FastTop1Function(StateTtlConfig, InternalTypeInfo<RowData>, GeneratedRecordComparator, RowDataKeySelector, RankType, RankRange, boolean, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.rank.FastTop1Function
- FastTop1Helper - Class in org.apache.flink.table.runtime.operators.rank.utils
-
A helper to help do the logic 'Top-1' in
FastTop1Function
andAsyncStateFastTop1Function
. - FastTop1Helper(AbstractTopNFunction, TypeSerializer<RowData>, long, long) - Constructor for class org.apache.flink.table.runtime.operators.rank.utils.FastTop1Helper
- FIELD_NAME_END - Static variable in class org.apache.flink.table.runtime.operators.rank.ConstantRankRange
- FIELD_NAME_END_INDEX - Static variable in class org.apache.flink.table.runtime.operators.rank.VariableRankRange
- FIELD_NAME_NAME - Static variable in class org.apache.flink.table.runtime.groupwindow.NamedWindowProperty
-
Deprecated.
- FIELD_NAME_PROPERTY - Static variable in class org.apache.flink.table.runtime.groupwindow.NamedWindowProperty
-
Deprecated.
- FIELD_NAME_REFERENCE - Static variable in class org.apache.flink.table.runtime.groupwindow.AbstractWindowProperty
-
Deprecated.
- FIELD_NAME_START - Static variable in class org.apache.flink.table.runtime.operators.rank.ConstantRankRange
- fieldIdx() - Method in class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer.FieldInfo
- FieldInfo(int, Integer, boolean) - Constructor for class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer.FieldInfo
- fields - Variable in class org.apache.flink.table.data.BoxedWrapperRowData
- FileChannelUtil - Class in org.apache.flink.table.runtime.util
-
File channel util for runtime.
- FileChannelUtil() - Constructor for class org.apache.flink.table.runtime.util.FileChannelUtil
- filter(RowData) - Method in class org.apache.flink.table.runtime.operators.misc.DropUpdateBeforeFunction
- filter(RowData, IterativeCondition.Context<RowData>) - Method in class org.apache.flink.table.runtime.operators.match.IterativeConditionRunner
- FilterAllFlatMapFunction - Class in org.apache.flink.table.runtime.operators.join.interval
-
Function filtering out all the input records.
- FilterAllFlatMapFunction(InternalTypeInfo<RowData>) - Constructor for class org.apache.flink.table.runtime.operators.join.interval.FilterAllFlatMapFunction
- FilterCondition - Interface in org.apache.flink.table.runtime.generated
-
Interface for code generated filter condition function on single RowData.
- filterEdges(List<ImmutableStreamEdge>, int) - Static method in class org.apache.flink.table.runtime.strategy.AdaptiveJoinOptimizationUtils
- filterNullKeys(boolean[]) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- find(MemorySegment[], int, int, MemorySegment[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
Find equal segments2 in segments1.
- findMatchedRecords(Function<RowData, Boolean>) - Method in interface org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.JoinRecordAsyncStateView
-
Find all the records matched the condition under the current context (i.e. join key).
- findMatchedRecords(Function<RowData, Boolean>) - Method in interface org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.OuterJoinRecordAsyncStateView
- findMatchedRecordsAndNumOfAssociations(Function<RowData, Boolean>) - Method in interface org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.OuterJoinRecordAsyncStateView
-
Find all the records matched the condition and the corresponding number of associations under the current context (i.e. join key).
- finish() - Method in class org.apache.flink.table.runtime.operators.bundle.AbstractMapBundleOperator
- finish() - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperator
- finish() - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- finish() - Method in class org.apache.flink.table.runtime.operators.multipleinput.MultipleInputStreamOperatorBase
-
Finish all sub-operators in a multiple input operator effect way.
- finish() - Method in class org.apache.flink.table.runtime.operators.sort.StreamSortOperator
- finish() - Method in class org.apache.flink.table.runtime.operators.wmassigners.RowTimeMiniBatchAssginerOperator
- finish() - Method in class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperator
- finishBundle() - Method in class org.apache.flink.table.runtime.operators.bundle.AbstractMapBundleOperator
- finishBundle() - Method in interface org.apache.flink.table.runtime.operators.bundle.trigger.BundleTriggerCallback
-
This method is invoked to finish current bundle and start a new one when the trigger was fired.
- finishBundle() - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- finishBundle(Map<K, V>, Collector<OUT>) - Method in class org.apache.flink.table.runtime.operators.bundle.MapBundleFunction
-
Called when a bundle is finished.
- finishBundle(Map<RowData, List<RowData>>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchGroupAggFunction
- finishBundle(Map<RowData, List<RowData>>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.RowTimeMiniBatchDeduplicateFunction
- finishBundle(Map<RowData, RowData>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchGlobalGroupAggFunction
- finishBundle(Map<RowData, RowData>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchIncrementalGroupAggFunction
- finishBundle(Map<RowData, RowData>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchLocalGroupAggFunction
- finishBundle(Map<RowData, RowData>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeMiniBatchDeduplicateKeepFirstRowFunction
- finishBundle(Map<RowData, RowData>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeMiniBatchDeduplicateKeepLastRowFunction
- finishBundle(Map<RowData, RowData>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.RowTimeMiniBatchLatestChangeDeduplicateFunction
- fireWindow(long, Long) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AsyncStateSliceSharedWindowAggProcessor
- fireWindow(long, Long) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AsyncStateSliceUnsharedWindowAggProcessor
- fireWindow(long, Long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.SliceSharedSyncStateWindowAggProcessor
- fireWindow(long, Long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.SliceUnsharedSyncStateWindowAggProcessor
- fireWindow(long, Long) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.processors.RowTimeSyncStateWindowDeduplicateProcessor
- fireWindow(long, Long) - Method in class org.apache.flink.table.runtime.operators.rank.window.processors.SyncStateWindowRankProcessor
- fireWindow(long, TimeWindow) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.UnsliceSyncStateWindowAggProcessor
- fireWindow(long, W) - Method in interface org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowProcessor
-
Emit results of the given window.
- fireWindow(long, W) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.SyncStateWindowProcessor
-
Emit results of the given window.
- FirstInputOfTwoInput - Class in org.apache.flink.table.runtime.operators.multipleinput.input
-
Input
for the first input ofTwoInputStreamOperator
. - FirstInputOfTwoInput(TwoInputStreamOperator<RowData, RowData, RowData>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.input.FirstInputOfTwoInput
- FirstInputOfTwoInputStreamOperatorOutput - Class in org.apache.flink.table.runtime.operators.multipleinput.output
-
An
Output
that can be used to emit elements and other messages for the first input ofTwoInputStreamOperator
. - FirstInputOfTwoInputStreamOperatorOutput(TwoInputStreamOperator<RowData, RowData, RowData>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.output.FirstInputOfTwoInputStreamOperatorOutput
- firstOrder - Variable in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator
- firstValue - Variable in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator
- FirstValueAggFunction<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in FIRST_VALUE aggregate function.
- FirstValueAggFunction(LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- FirstValueWithRetractAccumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator
- FirstValueWithRetractAggFunction<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in FIRST_VALUE with retraction aggregate function.
- FirstValueWithRetractAggFunction(LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for FIRST_VALUE.
- fixedDelayRetry(int, long, Predicate<Collection<RowData>>) - Static method in class org.apache.flink.table.runtime.operators.join.lookup.ResultRetryStrategy
-
Create a fixed-delay retry strategy by given params.
- flatMap(RowData, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.interval.FilterAllFlatMapFunction
- FlinkJoinType - Enum in org.apache.flink.table.runtime.operators.join
-
Join type for join.
- FloatApproxCountDistinctAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.FloatApproxCountDistinctAggFunction
- FloatHashSet - Class in org.apache.flink.table.runtime.util.collections
-
Float hash set.
- FloatHashSet() - Constructor for class org.apache.flink.table.runtime.util.collections.FloatHashSet
- FloatHashSet(int) - Constructor for class org.apache.flink.table.runtime.util.collections.FloatHashSet
- FloatHashSet(int, float) - Constructor for class org.apache.flink.table.runtime.util.collections.FloatHashSet
- floor(double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- floor(float) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- floor(int, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
FLOOR
operator applied to int values. - floor(long, long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
FLOOR
operator applied to long values. - floor(DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- floor(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- flush() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.buffers.RecordsWindowBuffer
- flush() - Method in interface org.apache.flink.table.runtime.operators.aggregate.window.buffers.WindowBuffer
-
Flushes all intermediate buffered data to the underlying backend or output stream.
- flush(RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateRecordsWindowBuffer
- flush(RowData) - Method in interface org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers.AsyncStateWindowBuffer
-
Flushes all intermediate buffered data to the underlying backend or output stream.
- flushAllCacheToState() - Method in class org.apache.flink.table.runtime.operators.rank.utils.FastTop1Helper
- flushBufferToState(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.utils.FastTop1Helper
- fmix(int) - Static method in class org.apache.flink.table.runtime.util.MurmurHashUtil
- fmix(long) - Static method in class org.apache.flink.table.runtime.util.MurmurHashUtil
- free() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- free() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- free() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
-
release the map's record and bucket area's memory segments.
- free() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
-
release the map's record and bucket area's memory segments.
- free(boolean) - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
- free(boolean) - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
- free(boolean) - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- freeCurrent() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
Free the memory not used.
- freeMemTarget - Variable in class org.apache.flink.table.runtime.io.BinaryRowChannelInputViewIterator
- freePages() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- freePages() - Method in class org.apache.flink.table.runtime.operators.aggregate.BytesHashMapSpillMemorySegmentPool
- freePages() - Method in class org.apache.flink.table.runtime.operators.sort.ListMemorySegmentPool
- freePages() - Method in class org.apache.flink.table.runtime.util.LazyMemorySegmentPool
- freePages() - Method in interface org.apache.flink.table.runtime.util.MemorySegmentPool
- frequencyType - Variable in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- fromAsyncStateView(RowData, boolean, JoinRecordAsyncStateView, JoinCondition) - Static method in class org.apache.flink.table.runtime.operators.join.stream.utils.AssociatedRecords
-
Creates an
AssociatedRecords
which represents the records associated to the input row. - fromBase64(byte[]) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- fromBase64(BinaryStringData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- fromClassToDataType(Class<?>) - Static method in class org.apache.flink.table.runtime.types.ClassDataTypeConverter
- fromDataTypeToLogicalType(DataType) - Static method in class org.apache.flink.table.runtime.types.LogicalTypeDataTypeConverter
-
Deprecated.
- fromDataTypeToTypeInfo(DataType) - Static method in class org.apache.flink.table.runtime.types.TypeInfoDataTypeConverter
-
Deprecated.
- fromInputSpecs(List<InputSpec>) - Static method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSelectionHandler
- fromLogicalTypeToDataType(LogicalType) - Static method in class org.apache.flink.table.runtime.types.LogicalTypeDataTypeConverter
-
Deprecated.
- fromLogicalTypeToTypeInfo(LogicalType) - Static method in class org.apache.flink.table.runtime.types.TypeInfoLogicalTypeConverter
-
Deprecated.Use
BigDecimalTypeInfo
to retain precision and scale of decimal. - fromSyncStateView(RowData, boolean, JoinRecordStateView, JoinCondition) - Static method in class org.apache.flink.table.runtime.operators.join.stream.utils.AssociatedRecords
-
Creates an
AssociatedRecords
which represents the records associated to the input row. - fromTypeInfoToLogicalType(TypeInformation) - Static method in class org.apache.flink.table.runtime.types.TypeInfoLogicalTypeConverter
-
Deprecated.It will lose some information.
- FULL - org.apache.flink.table.runtime.operators.join.FlinkJoinType
- FULL_OUTER - org.apache.flink.table.runtime.operators.join.HashJoinType
- function - Variable in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
- function - Variable in class org.apache.flink.table.runtime.operators.over.AbstractRowTimeUnboundedPrecedingOver
- FusionStreamOperatorBase - Class in org.apache.flink.table.runtime.operators.fusion
-
Base
MultipleInputStreamOperator
to handle multiple operator fusion codegen in table module. - FusionStreamOperatorBase(StreamOperatorParameters<RowData>, int) - Constructor for class org.apache.flink.table.runtime.operators.fusion.FusionStreamOperatorBase
G
- genAggsHandler - Variable in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
-
The code generated function used to handle aggregates.
- genAggsHandler - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- GeneralWindowProcessFunction<K,W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.internal
-
The general implementation of
InternalWindowProcessFunction
. - GeneralWindowProcessFunction(GroupWindowAssigner<W>, NamespaceAggsHandleFunctionBase<W>, long) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.internal.GeneralWindowProcessFunction
- generate() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- GeneratedAggsHandleFunction - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
AggsHandleFunction
. - GeneratedAggsHandleFunction(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedAggsHandleFunction
- GeneratedAggsHandleFunction(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedAggsHandleFunction
- GeneratedClass<T> - Class in org.apache.flink.table.runtime.generated
-
A wrapper for generated class, defines a
GeneratedClass.newInstance(ClassLoader)
method to get an instance by reference objects easily. - GeneratedClass(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedClass
- GeneratedCollector<C extends org.apache.flink.util.Collector<?>> - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
Collector
. - GeneratedCollector(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedCollector
- GeneratedCollector(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedCollector
-
Creates a GeneratedCollector.
- GeneratedFilterCondition - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
FilterCondition
. - GeneratedFilterCondition(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedFilterCondition
- GeneratedFilterCondition(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedFilterCondition
-
Creates a GeneratedFilterCondition.
- GeneratedFunction<F extends org.apache.flink.api.common.functions.Function> - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
Function
. - GeneratedFunction(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedFunction
- GeneratedFunction(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedFunction
-
Creates a GeneratedFunction.
- GeneratedHashFunction - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
HashFunction
. - GeneratedHashFunction(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedHashFunction
-
Creates a GeneratedHashFunction.
- GeneratedInput<F extends org.apache.flink.api.common.io.InputFormat<?,?>> - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
InputFormat
. - GeneratedInput(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedInput
-
Creates a GeneratedInput.
- generatedJoinCondition(GeneratedJoinCondition) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- GeneratedJoinCondition - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
JoinCondition
. - GeneratedJoinCondition(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedJoinCondition
- GeneratedJoinCondition(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedJoinCondition
-
Creates a GeneratedJoinCondition.
- generatedKeyEqualiser(GeneratedRecordEqualiser) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- GeneratedNamespaceAggsHandleFunction<N> - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
NamespaceAggsHandleFunction
. - GeneratedNamespaceAggsHandleFunction(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedNamespaceAggsHandleFunction
- GeneratedNamespaceAggsHandleFunction(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedNamespaceAggsHandleFunction
- GeneratedNamespaceTableAggsHandleFunction<N> - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
NamespaceTableAggsHandleFunction
. - GeneratedNamespaceTableAggsHandleFunction(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedNamespaceTableAggsHandleFunction
- GeneratedNamespaceTableAggsHandleFunction(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedNamespaceTableAggsHandleFunction
- GeneratedNormalizedKeyComputer - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
NormalizedKeyComputer
. - GeneratedNormalizedKeyComputer(String, String) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedNormalizedKeyComputer
- GeneratedNormalizedKeyComputer(String, String, ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedNormalizedKeyComputer
-
Creates a GeneratedNormalizedKeyComputer.
- GeneratedOperator<C extends org.apache.flink.streaming.api.operators.StreamOperator<?>> - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
StreamOperator
. - GeneratedOperator(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedOperator
-
Creates a GeneratedOperator.
- GeneratedProjection - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
Projection
. - GeneratedProjection(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedProjection
- GeneratedProjection(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedProjection
-
Creates a GeneratedProjection.
- GeneratedRecordComparator - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
RecordComparator
. - GeneratedRecordComparator(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedRecordComparator
- GeneratedRecordComparator(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedRecordComparator
-
Creates a GeneratedRecordComparator.
- GeneratedRecordEqualiser - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
RecordEqualiser
. - GeneratedRecordEqualiser(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedRecordEqualiser
- GeneratedRecordEqualiser(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedRecordEqualiser
-
Creates a GeneratedRecordEqualiser.
- GeneratedResultFuture<T extends org.apache.flink.streaming.api.functions.async.ResultFuture<?>> - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
ResultFuture
. - GeneratedResultFuture(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedResultFuture
- GeneratedResultFuture(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedResultFuture
-
Creates a GeneratedResultFuture.
- GeneratedTableAggsHandleFunction - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
TableAggsHandleFunction
. - GeneratedTableAggsHandleFunction(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedTableAggsHandleFunction
- GeneratedWatermarkGenerator - Class in org.apache.flink.table.runtime.generated
-
Describes a generated
WatermarkGenerator
. - GeneratedWatermarkGenerator(String, String, Object[]) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedWatermarkGenerator
- GeneratedWatermarkGenerator(String, String, Object[], ReadableConfig) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedWatermarkGenerator
- GeneratedWatermarkGeneratorSupplier - Class in org.apache.flink.table.runtime.generated
-
Wrapper of the
GeneratedWatermarkGenerator
that is used to createWatermarkGenerator
. - GeneratedWatermarkGeneratorSupplier(GeneratedWatermarkGenerator, WatermarkParams) - Constructor for class org.apache.flink.table.runtime.generated.GeneratedWatermarkGeneratorSupplier
- GeneratedWatermarkGeneratorSupplier.DefaultWatermarkGenerator - Class in org.apache.flink.table.runtime.generated
-
Wrapper of the code-generated
WatermarkGenerator
. - generateUpdateBefore - Variable in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
-
Whether this operator will generate UPDATE_BEFORE messages.
- GenericConverter(TypeSerializer<T>) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.GenericConverter
- GenericRowDataKeySelector - Class in org.apache.flink.table.runtime.keyselector
-
A KeySelector which will extract key from RowData.
- GenericRowDataKeySelector(InternalTypeInfo<RowData>, RowDataSerializer, GeneratedProjection) - Constructor for class org.apache.flink.table.runtime.keyselector.GenericRowDataKeySelector
- genOperatorFactory(ClassLoader, ReadableConfig) - Method in interface org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoin
-
Generates a StreamOperatorFactory for this join operator using the provided ClassLoader and config.
- genOperatorFactory(ClassLoader, ReadableConfig) - Method in class org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoinOperatorFactory
- genRecordEqualiser - Variable in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
-
The code generated equaliser used to equal RowData.
- get() - Method in class org.apache.flink.table.runtime.dataview.StateListView
- get() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSyncStateWindowAggProcessor.WindowIsEmptySupplier
- get(long) - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
-
This method is only used for operator fusion codegen to get build row from hash table.
- get(long, int) - Method in class org.apache.flink.table.runtime.hashtable.LongHashPartition
-
Returns an iterator for all the values for the given key, or null if no value found.
- get(String) - Method in class org.apache.flink.table.runtime.functions.JsonPathCache
- get(RowData) - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Gets the record list from the buffer under the sortKey.
- get(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowListState
- get(W, RowData) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
-
Returns the current value associated with the given key.
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction
- getAccumulatorDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- getAccumulators() - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunctionBase
-
Gets the current accumulators (saved in a row) which contains the current aggregated results.
- getAccumulators() - Method in interface org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunctionBase
-
Gets the current accumulators (saved in a row) which contains the current aggregated results.
- getAllInputTypes() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- getAllResultFutures() - Method in class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinRunner
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.MultiPercentileAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.SinglePercentileAggFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.scalar.BuiltInScalarFunction
- getArgumentDataTypes() - Method in class org.apache.flink.table.runtime.functions.table.BuiltInTableFunction
- getArity() - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getArity() - Method in class org.apache.flink.table.data.UpdatableRowData
- getArity() - Method in class org.apache.flink.table.runtime.typeutils.AbstractRowDataSerializer
-
Get the number of fields.
- getArity() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- getArity() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- getArity() - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- getArity() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- getArity() - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- getArity() - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- getArity() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- getArray(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getArray(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getAsyncKeyContext() - Method in interface org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowProcessor.AsyncStateContext
-
Returns the current
AsyncStateKeyContext
. - getAsyncKeyedStateBackend() - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.state.AsyncStateKeyContext
- getBackoffTimeMillis(int) - Method in class org.apache.flink.table.runtime.operators.join.lookup.ResultRetryStrategy
- getBinary(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getBinary(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getBlockCount() - Method in class org.apache.flink.table.runtime.io.ChannelWithMeta
- getBlockCount() - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelWriterOutputView
- getBlockCount() - Method in class org.apache.flink.table.runtime.io.HeaderlessChannelWriterOutputView
- getBoolean(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getBoolean(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getBoolean(MemorySegment[], int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
get boolean from segments.
- getBucketAreaMemorySegments() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
- getBuckets() - Method in class org.apache.flink.table.runtime.hashtable.LongHashPartition
- getBuffer1() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeFullOuterJoinIterator
- getBuffer2() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeFullOuterJoinIterator
- getBuildLongKey(RowData) - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
-
For code gen get build side long key.
- getBuildSideIterator() - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
- getBuildSideIterator() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- getByte(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getByte(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getByte(MemorySegment[], int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
get byte from segments.
- getBytes(MemorySegment[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
Maybe not copied, if want copy, please use copyTo.
- getCache() - Method in class org.apache.flink.table.runtime.functions.table.lookup.CachingAsyncLookupFunction
- getCache() - Method in class org.apache.flink.table.runtime.functions.table.lookup.CachingLookupFunction
- getCache() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
- getCache() - Method in class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager.RefCountedCache
- getCapacity() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryInMemorySortBuffer
- getChannel() - Method in class org.apache.flink.table.runtime.io.ChannelWithMeta
- getChannel() - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelReaderInputView
- getChannel() - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelWriterOutputView
- getChannel() - Method in class org.apache.flink.table.runtime.io.HeaderlessChannelWriterOutputView
- getChannelID() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- getChannelID() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- getClass(ClassLoader) - Method in class org.apache.flink.table.runtime.generated.GeneratedClass
- getClassName() - Method in class org.apache.flink.table.runtime.generated.GeneratedClass
- getCode() - Method in class org.apache.flink.table.runtime.generated.GeneratedClass
- getCollectListener() - Method in class org.apache.flink.table.runtime.collector.ListenableCollector
- getComparator() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializer
-
Returns the comparator for the keys in the map.
- getCompletableFuture() - Method in class org.apache.flink.table.runtime.operators.join.lookup.DelegatingResultFuture
- getContainingTask() - Method in class org.apache.flink.table.runtime.operators.fusion.FusionStreamOperatorBase
- getConverter(DataType) - Static method in class org.apache.flink.table.data.conversion.DataStructureConverters
-
Returns a converter for the given
DataType
. - getConverterForDataType(DataType) - Static method in class org.apache.flink.table.data.util.DataFormatConverters
-
Get
DataFormatConverters.DataFormatConverter
forDataType
. - getCoordinator(OperatorCoordinator.Context) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator.Provider
- getCoordinatorProvider(String, OperatorID) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorFactory
- getCounter() - Method in class org.apache.flink.table.runtime.operators.over.AbstractRowTimeUnboundedPrecedingOver
- getCounter() - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRangeBoundedPrecedingFunction
- getCounter() - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRowsBoundedPrecedingFunction
- getCurrentKey() - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.state.AsyncStateKeyContext
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer.ExternalSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer.LinkedListSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer.RawValueDataSerializerSnapshot
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer.WindowKeySerializerSnapshot
- getCurrentProbeRow() - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
- getCurrentProbeRow() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- getCurrentProcessingTime() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger.TriggerContext
-
Returns the current processing time.
- getCurrentTopNum() - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Gets number of total records.
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer.ArrayDataSerializerSnapshot
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer.DecimalSerializerSnapshot
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer.MapDataSerializerSnapshot
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer.RowDataSerializerSnapshot
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializerSnapshot
- getCurrentVersion() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer.TimestampDataSerializerSnapshot
- getCurrentWatermark() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger.TriggerContext
-
Returns the current watermark time.
- getCurrentWatermark() - Method in class org.apache.flink.table.runtime.operators.wmassigners.PeriodicWatermarkAssignerWrapper
- getDataType() - Method in class org.apache.flink.table.runtime.dataview.DataViewSpec
- getDataType() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- getDataType() - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- getDataType() - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- getDataType() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getDefaultExternalClassForType(LogicalType) - Static method in class org.apache.flink.table.runtime.types.ClassLogicalTypeConverter
-
Deprecated.
- getDefaultTopNSize() - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
-
Gets default topN size.
- getDescription() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowAssigner
-
Returns a description of this window assigner.
- getDescription() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- getDescription() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- getDescription() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.SlicedSharedSliceAssigner
- getDescription() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.SlicedUnsharedSliceAssigner
- getDescription() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.TumblingSliceAssigner
- getDescription() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.WindowedSliceAssigner
- getDescription() - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.SessionUnsliceAssigner
- getDescription() - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- getDouble(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getDouble(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getDouble(MemorySegment[], int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
get double from segments.
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.table.runtime.partitioner.BinaryHashPartitioner
- getDownstreamSubtaskStateMapper() - Method in class org.apache.flink.table.runtime.partitioner.RowDataCustomStreamPartitioner
- getElement(int) - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Gets record which rank is given value.
- getElementDataType() - Method in class org.apache.flink.table.runtime.dataview.ListViewSpec
- getElementSerializer() - Method in class org.apache.flink.table.runtime.dataview.ListViewSpec
- getElementSerializer() - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
-
Gets the serializer for the elements of the list.
- getEleSer() - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- getEnd() - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow
-
Gets the end timestamp of this window.
- getEndedInputCount() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- getEntryIterator(boolean) - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
-
Returns an iterator for iterating over the entries of this map.
- getEntryIterator(boolean) - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
- getFetcherCollector() - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- getFetcherCollector() - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinWithCalcRunner
- getFieldIndex() - Method in class org.apache.flink.table.runtime.dataview.DataViewSpec
- getFieldOffset(int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- getFieldOffset(int) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- getFixedLengthPartSize() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- getFloat(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getFloat(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getFloat(MemorySegment[], int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
get float from segments.
- getGeneratedClass() - Method in class org.apache.flink.table.runtime.operators.CodeGenOperatorFactory
- getGeneratedRecordComparator() - Method in class org.apache.flink.table.runtime.operators.rank.ComparableRecordComparator
- getHeadWrappers() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- getId() - Method in class org.apache.flink.table.runtime.operators.window.CountWindow
-
Gets the id (0-based) of the window.
- getIfPresent(RowData) - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.LookupFullCache
- getInnerSerializer() - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- getInput() - Method in class org.apache.flink.table.runtime.collector.TableFunctionCollector
-
Gets the input value from left table, which will be used to cross join with the result of table function.
- getInput() - Method in class org.apache.flink.table.runtime.collector.TableFunctionResultFuture
-
Gets the input value from left table, which will be used to cross join with the result of right table.
- getInputEdges() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- getInputId() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper.Edge
- getInputs() - Method in class org.apache.flink.table.runtime.operators.multipleinput.MultipleInputStreamOperatorBase
- getInputSelection() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSelectionHandler
- getInputSelectionSpec() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSpec
- getInputSerdeClass() - Method in class org.apache.flink.table.runtime.script.ScriptTransformIOInfo
- getInputSerdeProps() - Method in class org.apache.flink.table.runtime.script.ScriptTransformIOInfo
- getInputTransformAndInputSpecPairs() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- getInputWrappers() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- getInstance() - Static method in class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager
-
Get the shared instance of
LookupCacheManager
. - getInt(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getInt(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getInt(MemorySegment[], int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
get int from segments.
- getIterator() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalSorter
- getIterator() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryInMemorySortBuffer
-
Gets an iterator over all records in this buffer in their logical order.
- getIterator() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryKVInMemorySortBuffer
-
Gets an iterator over all KV records in this buffer in their logical order.
- getJoinKeys() - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
-
Get the joinKeys in bufferBundle.
- getJoinKeys() - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.InputSideHasUniqueKeyBundle
- getJoinType() - Method in interface org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoin
-
Get the join type of the join operator.
- getJoinType() - Method in class org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoinOperatorFactory
- getKey() - Method in interface org.apache.flink.table.runtime.dataview.NullAwareMapIterator.NullMapEntry
- getKey() - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap.LookupInfo
- getKey() - Method in interface org.apache.flink.table.runtime.util.KeyValueIterator
-
Retrieve the key from this iterator.
- getKey() - Method in class org.apache.flink.table.runtime.util.WindowKey
- getKey(IN) - Method in class org.apache.flink.table.runtime.operators.bundle.AbstractMapBundleOperator
-
Get the key for current processing element, which will be used as the map bundle's key.
- getKey(IN) - Method in class org.apache.flink.table.runtime.operators.bundle.KeyedMapBundleOperator
- getKey(IN) - Method in class org.apache.flink.table.runtime.operators.bundle.MapBundleOperator
- getKey(RowData) - Method in class org.apache.flink.table.runtime.keyselector.BinaryRowDataKeySelector
- getKey(RowData) - Method in class org.apache.flink.table.runtime.keyselector.EmptyRowDataKeySelector
- getKey(RowData) - Method in class org.apache.flink.table.runtime.keyselector.GenericRowDataKeySelector
- getKeyDataType() - Method in class org.apache.flink.table.runtime.dataview.MapViewSpec
- getKeyedStateBackend() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.SyncStateWindowProcessor.SyncStateContext
-
Returns the current
KeyedStateBackend
. - getKeys() - Method in class org.apache.flink.table.runtime.connector.source.LookupRuntimeProviderContext
- getKeySerializer() - Method in class org.apache.flink.table.runtime.dataview.MapViewSpec
- getKeySerializer() - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- getKind() - Method in class org.apache.flink.table.runtime.functions.BuiltInSpecializedFunction
- getKVIterator() - Method in class org.apache.flink.table.runtime.operators.sort.BufferedKVExternalSorter
- getLastWindow(TimeWindow) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- getLastWindow(TimeWindow) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- getLastWindow(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.PanedWindowAssigner
-
Gets the last window which the pane belongs to.
- getLastWindowEnd(long) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigner
-
Returns the last window which the slice belongs to.
- getLastWindowEnd(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- getLastWindowEnd(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- getLastWindowEnd(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.SlicedSharedSliceAssigner
- getLastWindowEnd(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.SlicedUnsharedSliceAssigner
- getLastWindowEnd(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.TumblingSliceAssigner
- getLastWindowEnd(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.WindowedSliceAssigner
- getLeftLateRecordsDroppedRate() - Method in class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
- getLength() - Method in class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- getLength() - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- getLength() - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashPartition
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.table.runtime.hashtable.LongHashPartition
- getLimitForSegment(MemorySegment) - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelReaderInputView
- getLineageVertex() - Method in class org.apache.flink.table.runtime.operators.values.ValuesInputFormat
- getList() - Method in class org.apache.flink.table.runtime.dataview.StateListView
- getListState() - Method in class org.apache.flink.table.runtime.dataview.StateListView
- getListState() - Method in class org.apache.flink.table.runtime.dataview.StateListView.KeyedStateListView
- getListState() - Method in class org.apache.flink.table.runtime.dataview.StateListView.NamespacedStateListView
- getLong(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getLong(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getLong(MemorySegment[], int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
get long from segments.
- getManagedCaches() - Method in class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager
- getManagedMemoryFraction() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- getManagedMemoryWeight() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- getMap() - Method in class org.apache.flink.table.runtime.dataview.StateMapView
- getMap(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getMap(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getMapState() - Method in class org.apache.flink.table.runtime.dataview.StateMapView.KeyedStateMapViewWithKeysNotNull
- getMapState() - Method in class org.apache.flink.table.runtime.dataview.StateMapView.KeyedStateMapViewWithKeysNullable
- getMapState() - Method in class org.apache.flink.table.runtime.dataview.StateMapView.NamespacedStateMapViewWithKeysNotNull
- getMapState() - Method in class org.apache.flink.table.runtime.dataview.StateMapView.NamespacedStateMapViewWithKeysNullable
- getMatchBuffer() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- getMatchKey() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeFullOuterJoinIterator
- getMatchKey() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- getMaxOutputDelay() - Method in class org.apache.flink.table.runtime.operators.join.interval.RowTimeIntervalJoin
-
Get the maximum interval between receiving a row and emitting it (as part of a joined result).
- getMaxParallelism() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- getMemoryManager() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowProcessor.Context
-
Returns the current
MemoryManager
. - getMemorySize() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowProcessor.Context
-
Returns the managed memory size can be used by this operator.
- getMergingIterator(List<ChannelWithMeta>, List<FileIOChannel>) - Method in class org.apache.flink.table.runtime.operators.sort.AbstractBinaryExternalMerger
-
Returns an iterator that iterates over the merged result from all given channels.
- getMergingWindowAssigner() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigner
-
Currently, unslice assigner has an inner
MergingWindowAssigner
to reuse the logic inGroupWindowAssigner
to merge windows. - getMergingWindowAssigner() - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.SessionUnsliceAssigner
- getMergingWindowAssigner() - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- getMetricGroup() - Method in class org.apache.flink.table.runtime.generated.WatermarkGeneratorCodeGeneratorFunctionContextWrapper
- getMetricGroup() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger.TriggerContext
-
Returns the metric group for this
Trigger
. - getMinResources() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- getMultipleInputId() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSelectionSpec
- getMultipleInputId() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSpec
- getName() - Method in class org.apache.flink.table.runtime.groupwindow.NamedWindowProperty
-
Deprecated.
- getName() - Method in class org.apache.flink.table.runtime.groupwindow.WindowReference
-
Deprecated.
- getNestedSerializers(ExternalSerializer<I, E>) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer.ExternalSerializerSnapshot
- getNestedSerializers(LinkedListSerializer<T>) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer.LinkedListSerializerSnapshot
- getNestedSerializers(RawValueDataSerializer<T>) - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer.RawValueDataSerializerSnapshot
- getNestedSerializers(WindowKeySerializer) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer.WindowKeySerializerSnapshot
- getNextBuffer() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
Gets the next buffer to be used with the hash-table, either for an in-memory partition, or for the table buckets.
- getNextBuffers(int) - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
Bulk memory acquisition.
- getNextOrNull(ResettableExternalBuffer.BufferIterator) - Static method in interface org.apache.flink.table.runtime.operators.over.frame.OverWindowFrame
-
Get next row from iterator.
- getNextReturnedBlock() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- getNextReturnedBlock() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- getNextTriggerWatermark(long, long, ZoneId, boolean) - Static method in class org.apache.flink.table.runtime.util.TimeWindowUtil
-
Method to get the next watermark to trigger window.
- getNioFileChannel() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- getNioFileChannel() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- getNodeFactory() - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
-
Returns the
JsonNodeFactory
for creating nodes. - getNotNullNextBuffer() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- getNullFilterKeys(boolean[]) - Static method in class org.apache.flink.table.runtime.operators.join.NullAwareJoinHelper
- getNullState() - Method in class org.apache.flink.table.runtime.dataview.StateMapView.KeyedStateMapViewWithKeysNullable
- getNullState() - Method in class org.apache.flink.table.runtime.dataview.StateMapView.NamespacedStateMapViewWithKeysNullable
- getNumBytes() - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelWriterOutputView
- getNumBytes() - Method in class org.apache.flink.table.runtime.io.HeaderlessChannelWriterOutputView
- getNumBytesInLastBlock() - Method in class org.apache.flink.table.runtime.io.ChannelWithMeta
- getNumCompressedBytes() - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelWriterOutputView
- getNumCompressedBytes() - Method in class org.apache.flink.table.runtime.io.HeaderlessChannelWriterOutputView
- getNumElements() - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- getNumElements() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
- getNumElements() - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- getNumKeyBytes() - Method in interface org.apache.flink.table.runtime.generated.NormalizedKeyComputer
-
Get normalized keys bytes length.
- getNumKeys() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
- getNumKeys() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
- getNumKeys() - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
-
Returns the number of keys in this map.
- getNumLateRecordsDropped() - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- getNumLateRecordsDropped() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- getNumLateRecordsDropped() - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- getNumLateRecordsDropped() - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.UnalignedWindowTableFunctionOperator
- getNumNullRowTimeRecordsDropped() - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.WindowTableFunctionOperatorBase
- getNumOfAssociations() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.OuterRecord
- getNumSpillFiles() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- getNumSpillFiles() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalSorter
- getNumSpillFiles() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
- getNumSpillFiles() - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- getNumSpillFiles() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
- getNumWords() - Method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HyperLogLogPlusPlus
- getObject() - Method in class org.apache.flink.table.runtime.util.ObjectContainer
- getOccupancy() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryInMemorySortBuffer
- getOperatorAttributes() - Method in class org.apache.flink.table.runtime.operators.sort.StreamSortOperator
- getOperatorName() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- getOperatorName() - Method in class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer
- getOperatorOwner() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowProcessor.Context
-
Returns the object instance of this operator which is used for tracking managed memories used by this operator.
- getOuterRecords() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.AssociatedRecords
-
Gets the iterable of
OuterRecord
which composites record and numOfAssociations. - getOutput() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSpec
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.MultiPercentileAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.SinglePercentileAggFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.scalar.BuiltInScalarFunction
- getOutputDataType() - Method in class org.apache.flink.table.runtime.functions.table.BuiltInTableFunction
- getOutputEdges() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- getOutputOpInputId() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSpec
- getOutputSerdeClass() - Method in class org.apache.flink.table.runtime.script.ScriptTransformIOInfo
- getOutputSerdeProps() - Method in class org.apache.flink.table.runtime.script.ScriptTransformIOInfo
- getOutputType() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- getOutputWrappers() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- getParallelism() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- getPartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Creates a partitioned state handle, using the state backend configured for this task.
- getPartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger.TriggerContext
-
Retrieves a
State
object that can be used to interact with fault-tolerant state that is scoped to the window and key of the current trigger invocation. - getPartitionsPendingForSMJ() - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
- getPartitionsPendingForSMJ() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- getPrecision() - Method in class org.apache.flink.table.runtime.typeutils.LegacyInstantTypeInfo
- getPrecision() - Method in class org.apache.flink.table.runtime.typeutils.LegacyLocalDateTimeTypeInfo
- getPrecision() - Method in class org.apache.flink.table.runtime.typeutils.LegacyTimestampTypeInfo
- getPrecision() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- getPreferredResources() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- getPrevRowFromCache(RowData) - Method in class org.apache.flink.table.runtime.operators.rank.utils.FastTop1Helper
- getProbeLongKey(RowData) - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
-
For code gen get probe side long key.
- getProbeRow() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- getProducedType() - Method in class org.apache.flink.formats.raw.RawFormatDeserializationSchema
- getProducedType() - Method in class org.apache.flink.table.runtime.keyselector.BinaryRowDataKeySelector
- getProducedType() - Method in class org.apache.flink.table.runtime.keyselector.EmptyRowDataKeySelector
- getProducedType() - Method in class org.apache.flink.table.runtime.keyselector.GenericRowDataKeySelector
- getProducedType() - Method in interface org.apache.flink.table.runtime.keyselector.RowDataKeySelector
- getProducedType() - Method in class org.apache.flink.table.runtime.operators.join.interval.FilterAllFlatMapFunction
- getProducedType() - Method in class org.apache.flink.table.runtime.operators.join.interval.IntervalJoinFunction
- getProducedType() - Method in class org.apache.flink.table.runtime.operators.join.interval.PaddingLeftMapFunction
- getProducedType() - Method in class org.apache.flink.table.runtime.operators.join.interval.PaddingRightMapFunction
- getProducedType() - Method in class org.apache.flink.table.runtime.operators.values.ValuesInputFormat
- getProperty() - Method in class org.apache.flink.table.runtime.groupwindow.NamedWindowProperty
-
Deprecated.
- getRankEnd() - Method in class org.apache.flink.table.runtime.operators.rank.ConstantRankRange
- getRankEndIndex() - Method in class org.apache.flink.table.runtime.operators.rank.VariableRankRange
- getRankStart() - Method in class org.apache.flink.table.runtime.operators.rank.ConstantRankRange
- getRawValue(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getRawValue(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getReader() - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelReaderInputView
- getReadOrder() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSelectionSpec
- getReadOrder() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSpec
- getRecord() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.OuterRecord
- getRecordAreaMemorySegments() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
- getRecordProcessor(int) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.FirstInputOfTwoInput
- getRecordProcessor(int) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.OneInput
- getRecordProcessor(int) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.SecondInputOfTwoInput
- getRecordReaderClass() - Method in class org.apache.flink.table.runtime.script.ScriptTransformIOInfo
- getRecords() - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
-
Get records associated with joinKeys from bufferBundle.
- getRecords() - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.InputSideHasNoUniqueKeyBundle
- getRecords() - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.InputSideHasUniqueKeyBundle
- getRecords() - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.JoinKeyContainsUniqueKeyBundle
- getRecords() - Method in interface org.apache.flink.table.runtime.operators.join.stream.state.JoinRecordStateView
-
Gets all the records under the current context (i.e. join key).
- getRecords() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.AssociatedRecords
-
Gets the iterable of records.
- getRecordsAndNumOfAssociations() - Method in interface org.apache.flink.table.runtime.operators.join.stream.state.OuterJoinRecordStateView
-
Gets all the records and number of associations under the current context (i.e. join key).
- getRecordsWithJoinKey(RowData) - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
-
Get records associated with joinKeys from bufferBundle.
- getRecordsWithJoinKey(RowData) - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.InputSideHasNoUniqueKeyBundle
- getRecordsWithJoinKey(RowData) - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.InputSideHasUniqueKeyBundle
- getRecordsWithJoinKey(RowData) - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.JoinKeyContainsUniqueKeyBundle
- getRecordWriterClass() - Method in class org.apache.flink.table.runtime.script.ScriptTransformIOInfo
- getReferences() - Method in class org.apache.flink.table.runtime.generated.GeneratedClass
- getRegexpMatcher(StringData, StringData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns a Matcher object that represents the result of matching given StringData against a specified regular expression pattern.
- getRequirements() - Method in class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
- getRequirements() - Method in class org.apache.flink.table.runtime.functions.BuiltInSpecializedFunction
- getRequirements() - Method in class org.apache.flink.table.runtime.functions.scalar.BuiltInScalarFunction
- getRequirements() - Method in class org.apache.flink.table.runtime.functions.table.BuiltInTableFunction
- getResultFuture() - Method in class org.apache.flink.table.runtime.collector.TableFunctionResultFuture
-
Gets the internal collector which used to emit the final row.
- getResultType() - Method in class org.apache.flink.table.runtime.groupwindow.ProctimeAttribute
-
Deprecated.
- getResultType() - Method in class org.apache.flink.table.runtime.groupwindow.RowtimeAttribute
-
Deprecated.
- getResultType() - Method in class org.apache.flink.table.runtime.groupwindow.SliceEnd
-
Deprecated.
- getResultType() - Method in class org.apache.flink.table.runtime.groupwindow.WindowEnd
-
Deprecated.
- getResultType() - Method in interface org.apache.flink.table.runtime.groupwindow.WindowProperty
-
Deprecated.
- getResultType() - Method in class org.apache.flink.table.runtime.groupwindow.WindowStart
-
Deprecated.
- getRetryPredicate() - Method in class org.apache.flink.table.runtime.operators.join.lookup.ResultRetryStrategy
- getReturnQueue() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- getReturnQueue() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- getRightLateRecordsDroppedRate() - Method in class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
- getRow() - Method in class org.apache.flink.table.data.UpdatableRowData
- getRow() - Method in class org.apache.flink.table.runtime.hashtable.BuildSideIterator.BucketIterator
- getRow() - Method in class org.apache.flink.table.runtime.hashtable.BuildSideIterator
- getRow() - Method in class org.apache.flink.table.runtime.hashtable.LongHashPartition.MatchIterator
- getRow() - Method in class org.apache.flink.table.runtime.hashtable.LookupBucketIterator
- getRow() - Method in class org.apache.flink.table.runtime.hashtable.WrappedRowIterator
- getRow() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer.BufferIterator
- getRow() - Method in interface org.apache.flink.table.runtime.util.RowIterator
-
Retrieve the row from this iterator.
- getRow(int, int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getRow(int, int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getRowKind() - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getRowKind() - Method in class org.apache.flink.table.data.UpdatableRowData
- getRuntimeContext() - Method in interface org.apache.flink.table.runtime.context.ExecutionContext
- getRuntimeContext() - Method in class org.apache.flink.table.runtime.context.ExecutionContextImpl
- getRuntimeContext() - Method in class org.apache.flink.table.runtime.dataview.PerKeyStateDataViewStore
- getRuntimeContext() - Method in class org.apache.flink.table.runtime.dataview.PerWindowStateDataViewStore
- getRuntimeContext() - Method in interface org.apache.flink.table.runtime.dataview.StateDataViewStore
- getRuntimeContext() - Method in class org.apache.flink.table.runtime.dataview.UnsupportedStateDataViewStore
- getRuntimeContext() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowProcessor.Context
-
Returns the current
RuntimeContext
. - getSerializableConf() - Method in class org.apache.flink.table.runtime.script.ScriptTransformIOInfo
- getSerializedRowFixedPartLength() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
-
Return fixed part length to serialize one row.
- getShiftTimeZone() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Returns the shifted timezone of the window.
- getShiftTimeZone() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger.TriggerContext
-
Returns the shifted timezone.
- getShiftTimeZone() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerService
-
The shift timezone of the window, if the proctime or rowtime type is TIMESTAMP_LTZ, the shift timezone is the timezone user configured in TableConfig, other cases the timezone is UTC which means never shift when assigning windows.
- getShiftTimeZone() - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerServiceBase
- getShiftTimeZone(LogicalType, ZoneId) - Static method in class org.apache.flink.table.runtime.util.TimeWindowUtil
-
Get the shifted timezone of window if the time attribute type is TIMESTAMP_LTZ, always returns UTC timezone if the time attribute type is TIMESTAMP which means do not shift.
- getShort(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getShort(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getShort(MemorySegment[], int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
get short from segments.
- getSize() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- getSize() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- getSliceEndInterval() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigner
-
Returns the interval of slice ends, i.e. the step size to advance of the slice end when a new slice assigned.
- getSliceEndInterval() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- getSliceEndInterval() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- getSliceEndInterval() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.TumblingSliceAssigner
- getSliceEndInterval() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.WindowedSliceAssigner
- getSortKeyComparator() - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Gets sort key comparator used by buffer.
- getSource() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper.Edge
- getSpilledPartitionBuildSideIter(BinaryHashPartition) - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
- getSpilledPartitionBuildSideIter(LongHashPartition) - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- getSpilledPartitionProbeSideIter(BinaryHashPartition) - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
- getSpilledPartitionProbeSideIter(LongHashPartition) - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- getSpillInBytes() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- getSpillInBytes() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalSorter
- getSpillInBytes() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
- getSpillInBytes() - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- getSpillInBytes() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
- getStart() - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow
-
Gets the starting timestamp of the window.
- getStateId() - Method in class org.apache.flink.table.runtime.dataview.DataViewSpec
- getStateListView(String, TypeSerializer<EE>) - Method in class org.apache.flink.table.runtime.dataview.PerKeyStateDataViewStore
- getStateListView(String, TypeSerializer<EE>) - Method in class org.apache.flink.table.runtime.dataview.PerWindowStateDataViewStore
- getStateListView(String, TypeSerializer<EE>) - Method in interface org.apache.flink.table.runtime.dataview.StateDataViewStore
-
Creates a state list view.
- getStateListView(String, TypeSerializer<EE>) - Method in class org.apache.flink.table.runtime.dataview.UnsupportedStateDataViewStore
- getStateMapView(String, boolean, TypeSerializer<EK>, TypeSerializer<EV>) - Method in class org.apache.flink.table.runtime.dataview.PerKeyStateDataViewStore
- getStateMapView(String, boolean, TypeSerializer<EK>, TypeSerializer<EV>) - Method in class org.apache.flink.table.runtime.dataview.PerWindowStateDataViewStore
- getStateMapView(String, boolean, TypeSerializer<EK>, TypeSerializer<EV>) - Method in interface org.apache.flink.table.runtime.dataview.StateDataViewStore
-
Creates a state map view.
- getStateMapView(String, boolean, TypeSerializer<EK>, TypeSerializer<EV>) - Method in class org.apache.flink.table.runtime.dataview.UnsupportedStateDataViewStore
- getStateWindow(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowProcessFunction
-
Get the state window as the namespace stored acc in the data about this actual window.
- getStateWindow(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowSet
-
Returns the state window for the given in-flight
Window
. - getStreamOperator() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.table.runtime.operators.CodeGenOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.table.runtime.operators.fusion.OperatorFusionCodegenFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoinOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.table.runtime.operators.multipleinput.BatchMultipleInputStreamOperatorFactory
- getStreamOperatorClass(ClassLoader) - Method in class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperatorFactory
- getString(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getString(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getSynchronousResult(int) - Method in class org.apache.flink.table.runtime.operators.calc.async.DelegatingAsyncResultFuture
- getTailWrapper() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- getTarget() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper.Edge
- getTargetColumns() - Method in class org.apache.flink.table.runtime.connector.sink.SinkRuntimeProviderContext
- getTimerService() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowProcessor.Context
-
Returns the current
InternalTimerService
. - getTimestamp(int, int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.UpdatableRowData
- getTopNBufferFromCache(RowData) - Method in class org.apache.flink.table.runtime.operators.rank.utils.AppendOnlyTopNHelper
- getTotalFields() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- getTotalFields() - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- getTotalFields() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- getTotalFields() - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- getTotalFields() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- getTriggerWindow() - Method in class org.apache.flink.table.runtime.operators.window.grouping.WindowsGrouping
- getType() - Method in class org.apache.flink.table.runtime.groupwindow.WindowReference
-
Deprecated.
- getTypeClass() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- getTypeClass() - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- getTypeClass() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- getTypeClass() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapTypeInfo
- getTypeClass() - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- getTypeClass() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.runtime.functions.BuiltInSpecializedFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.runtime.functions.scalar.BuiltInScalarFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.runtime.functions.table.BuiltInTableFunction
- getUniqueKeySelector() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinInputSideSpec
-
Returns the
KeySelector
to extract unique key from the input row. - getUniqueKeyType() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinInputSideSpec
-
Returns the
TypeInformation
of the unique key. - getUnnestedType(LogicalType) - Static method in class org.apache.flink.table.runtime.functions.table.UnnestRowsFunction
- getUsedMemoryInBytes() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- getUsedMemoryInBytes() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalSorter
- getUsedMemoryInBytes() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
- getUsedMemoryInBytes() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
- getUtcTimestamp(RowData, ClockService) - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.SessionUnsliceAssigner
- getValue() - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.PercentileAccumulator
- getValue() - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunction
-
Gets the result of the aggregation from the current accumulators.
- getValue() - Method in class org.apache.flink.table.runtime.operators.metrics.SimpleGauge
- getValue() - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap.LookupInfo
- getValue() - Method in interface org.apache.flink.table.runtime.util.KeyValueIterator
-
Retrieve the value from this iterator.
- getValue(N) - Method in interface org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunction
-
Gets the result of the aggregation from the current accumulators and namespace properties (like window start).
- getValue(RowData) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- getValue(RowData) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- getValue(ArrayAggFunction.ArrayAggAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction
- getValue(CollectAggFunction.CollectAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction
- getValue(FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- getValue(HllBuffer) - Method in class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction
- getValue(JsonArrayAggFunction.Accumulator) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction
- getValue(JsonObjectAggFunction.Accumulator) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction
- getValue(LagAggFunction.LagAcc<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction
- getValue(LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- getValue(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction
- getValue(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
- getValue(MaxWithRetractAggFunction.MaxWithRetractAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction
- getValue(MinWithRetractAggFunction.MinWithRetractAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction
- getValue(PercentileAggFunction.PercentileAccumulator) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.MultiPercentileAggFunction
- getValue(PercentileAggFunction.PercentileAccumulator) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.SinglePercentileAggFunction
- getValueDataType() - Method in class org.apache.flink.table.runtime.dataview.MapViewSpec
- getValueSerializer() - Method in class org.apache.flink.table.runtime.dataview.MapViewSpec
- getValueSerializer() - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- getWatermarkLatency() - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- getWatermarkLatency() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- getWatermarkLatency() - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- getWatermarkLatency() - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.UnalignedWindowTableFunctionOperator
- getWindow() - Method in class org.apache.flink.table.runtime.util.WindowKey
- getWindowAccumulators(W) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Gets the accumulators of the given window.
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountSlidingWindowAssigner
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountTumblingWindowAssigner
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.GroupWindowAssigner
-
Returns a
TypeSerializer
for serializing windows that are assigned by thisWindowAssigner
. - getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SessionWindowAssigner
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.TumblingWindowAssigner
- getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- getWindowStart(long) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigner
-
Returns the corresponding window start timestamp of the given window end timestamp.
- getWindowStart(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- getWindowStart(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- getWindowStart(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.TumblingSliceAssigner
- getWindowStart(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.WindowedSliceAssigner
- getWindowStartWithOffset(long, long, long) - Static method in class org.apache.flink.table.runtime.operators.window.TimeWindow
-
Method to get the window start for a timestamp.
- getWindowStateMergingConsumer() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowProcessFunction.MergingContext
-
Returns the consumer used to merge window state.
- getWindowTimerService() - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- getWindowTimerService() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- getWindowTimerService() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.UnsliceSyncStateWindowAggProcessor
- getWindowTimerService() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- GlobalAggCombiner - Class in org.apache.flink.table.runtime.operators.aggregate.window.combines
-
An implementation of
RecordsCombiner
that accumulates local accumulators records into the window accumulator state. - GlobalAggCombiner(WindowTimerService<Long>, StateKeyContext, WindowValueState<Long>, NamespaceAggsHandleFunction<Long>, NamespaceAggsHandleFunction<Long>) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.combines.GlobalAggCombiner
- GlobalAggCombiner.Factory - Class in org.apache.flink.table.runtime.operators.aggregate.window.combines
-
Factory to create
GlobalAggCombiner
. - globalAggregate(GeneratedNamespaceAggsHandleFunction<?>, GeneratedNamespaceAggsHandleFunction<?>, GeneratedNamespaceAggsHandleFunction<?>, AbstractRowDataSerializer<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- GlobalRuntimeFilterBuilderOperator - Class in org.apache.flink.table.runtime.operators.runtimefilter
-
Global runtime filter builder operator.
- GlobalRuntimeFilterBuilderOperator(int) - Constructor for class org.apache.flink.table.runtime.operators.runtimefilter.GlobalRuntimeFilterBuilderOperator
- GroupAggFunction - Class in org.apache.flink.table.runtime.operators.aggregate
-
Aggregate Function used for the groupby (without window) aggregate.
- GroupAggFunction(GeneratedAggsHandleFunction, GeneratedRecordEqualiser, LogicalType[], int, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunction
-
Creates a
GroupAggFunction
. - GroupAggFunctionBase - Class in org.apache.flink.table.runtime.operators.aggregate
-
Base class for
GroupAggFunction
andAsyncStateGroupAggFunction
. - GroupAggFunctionBase(GeneratedAggsHandleFunction, GeneratedRecordEqualiser, LogicalType[], int, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
- GroupAggHelper - Class in org.apache.flink.table.runtime.operators.aggregate.utils
-
A helper to do the logic of group agg.
- GroupAggHelper(RecordCounter, boolean, StateTtlConfig, AggsHandleFunction, RecordEqualiser) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.utils.GroupAggHelper
- GroupTableAggFunction - Class in org.apache.flink.table.runtime.operators.aggregate
-
Aggregate Function used for the groupby (without window) table aggregate.
- GroupTableAggFunction(GeneratedTableAggsHandleFunction, LogicalType[], int, boolean, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.GroupTableAggFunction
-
Creates a
GroupTableAggFunction
. - GroupWindowAssigner<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.assigners
-
A
GroupWindowAssigner
assigns zero or moreWindows
to an element. - GroupWindowAssigner() - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.GroupWindowAssigner
- growAndRehash() - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- growthThreshold - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
-
The map will be expanded once the number of elements exceeds this threshold.
H
- handleCoordinationRequest(CoordinationRequest) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- handleEventFromOperator(int, int, OperatorEvent) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- hash(byte[], MessageDigest) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Calculate the hash value of the given bytes use
MessageDigest
. - hash(int, int) - Static method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The level parameter is needed so that we can have different hash functions when we recursively apply the partitioning, so that the working set eventually fits into memory.
- hash(String, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Calculate the hash value of a given string.
- hash(String, String, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Calculate the hash value of a given string.
- hash(MemorySegment[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
hash segments to int.
- hash(BinaryStringData, String) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- hash(BinaryStringData, MessageDigest) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Calculate the hash value of a given string use
MessageDigest
. - hashBytes(MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.util.MurmurHashUtil
-
Hash bytes in MemorySegment.
- hashBytesByWords(MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.util.MurmurHashUtil
-
Hash bytes in MemorySegment, length must be aligned to 4 bytes.
- hashByWords(MemorySegment[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
hash segments to int, numBytes must be aligned to 4 bytes.
- hashCode() - Method in class org.apache.flink.formats.raw.RawFormatDeserializationSchema
- hashCode() - Method in class org.apache.flink.formats.raw.RawFormatSerializationSchema
- hashCode() - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction.ArrayAggAccumulator
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HllBuffer
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction.Accumulator
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction.Accumulator
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction.LagAcc
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction.LastValueWithRetractAccumulator
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction.ListAggWithRetractAccumulator
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction.MaxWithRetractAccumulator
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction.MinWithRetractAccumulator
- hashCode() - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.PercentileAccumulator
- hashCode() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSelectionSpec
- hashCode() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSpec
- hashCode() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper.Edge
- hashCode() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- hashCode() - Method in class org.apache.flink.table.runtime.operators.rank.ComparableRecordComparator
- hashCode() - Method in class org.apache.flink.table.runtime.operators.window.CountWindow
- hashCode() - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow
- hashCode() - Method in class org.apache.flink.table.runtime.operators.window.Window
- hashCode() - Method in class org.apache.flink.table.runtime.partitioner.BinaryHashPartitioner
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.BigDecimalTypeInfo
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.LegacyInstantTypeInfo
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.LegacyLocalDateTimeTypeInfo
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.LegacyTimestampTypeInfo
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializer
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapTypeInfo
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- hashCode() - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- hashCode() - Method in class org.apache.flink.table.runtime.util.ObjectContainer
- hashCode() - Method in class org.apache.flink.table.runtime.util.WindowKey
- hashCode(Object) - Method in interface org.apache.flink.table.runtime.generated.HashFunction
- hashCode(Object) - Method in class org.apache.flink.table.runtime.util.EqualityAndHashcodeProvider
- hashCode(String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- HashFunction - Interface in org.apache.flink.table.runtime.generated
-
Interface for code generated hash code of
RowData
which will select some fields to hash orArrayData
orMapData
. - hashInt(int, long) - Static method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.XXH64
- HashJoinOperator - Class in org.apache.flink.table.runtime.operators.join
-
Hash join base operator.
- HashJoinType - Enum in org.apache.flink.table.runtime.operators.join
-
Join type for hash table.
- hashLong(long, long) - Static method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.XXH64
- hashUnsafeBytes(Object, long, int) - Static method in class org.apache.flink.table.runtime.util.MurmurHashUtil
-
Hash unsafe bytes.
- hashUnsafeBytes(MemorySegment, int, int, long) - Static method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.XXH64
- hashUnsafeBytesByWords(Object, long, int) - Static method in class org.apache.flink.table.runtime.util.MurmurHashUtil
-
Hash unsafe bytes, length must be aligned to 4 bytes.
- hasKeyContext() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputBase
- hasNext() - Method in class org.apache.flink.table.runtime.dataview.NullAwareMapIterator
- hasNext() - Method in class org.apache.flink.table.runtime.util.SingleElementIterator
- hasOffset() - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- hasSource() - Method in class org.apache.flink.table.runtime.hashtable.ProbeIterator
- hasTriggerWindow() - Method in class org.apache.flink.table.runtime.operators.window.grouping.WindowsGrouping
-
Check if there are windows could be triggered according to the current watermark.
- hasUniqueKey() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinInputSideSpec
-
Returns true if the input has unique key, otherwise false.
- HeaderlessChannelWriterOutputView - Class in org.apache.flink.table.runtime.io
-
A
DataOutputView
that is backed by aBlockChannelWriter
, making it effectively a data output stream. - HeaderlessChannelWriterOutputView(BlockChannelWriter<MemorySegment>, List<MemorySegment>, int) - Constructor for class org.apache.flink.table.runtime.io.HeaderlessChannelWriterOutputView
- HeapWindowsGrouping - Class in org.apache.flink.table.runtime.operators.window.grouping
-
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. - HeapWindowsGrouping(int, long, long, int, boolean) - Constructor for class org.apache.flink.table.runtime.operators.window.grouping.HeapWindowsGrouping
- HeapWindowsGrouping(int, long, long, long, int, boolean) - Constructor for class org.apache.flink.table.runtime.operators.window.grouping.HeapWindowsGrouping
- hex(long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns the hex string of a long argument.
- hex(String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns the hex string of a string argument.
- hitCount - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- HllBuffer - Class in org.apache.flink.table.runtime.functions.aggregate.hyperloglog
-
Buffer used by HyperLogLogPlusPlus and ApproximateCountDistinct.
- HllBuffer() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HllBuffer
- hopping(int, ZoneId, Duration, Duration) - Static method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners
-
Creates a hopping window
SliceAssigner
that assigns elements to slices of hopping windows. - HoppingSliceAssigner(int, ZoneId, long, long, long) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- HyperLogLogPlusPlus - Class in org.apache.flink.table.runtime.functions.aggregate.hyperloglog
-
The implement of HyperLogLogPlusPlus is inspired from Apache Spark.
- HyperLogLogPlusPlus(double) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HyperLogLogPlusPlus
I
- IDENTIFIER - Static variable in class org.apache.flink.formats.raw.RawFormatFactory
- IdentityConverter<I> - Class in org.apache.flink.table.data.conversion
-
No-op converter that just forwards its input.
- IdentityConverter() - Constructor for class org.apache.flink.table.data.conversion.IdentityConverter
- IdentityConverter() - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.IdentityConverter
- IfNullFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.IF_NULL
. - IfNullFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.IfNullFunction
- indexEntrySize - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- INIT_BUCKET_MEMORY_IN_BYTES - Static variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- initBucketSegments(int) - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- initcap(String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL INITCAP(string) function.
- initCleanupTimeState(String) - Method in class org.apache.flink.table.runtime.functions.KeyedProcessFunctionWithCleanupState
- initialize(StreamGraphContext) - Method in class org.apache.flink.table.runtime.strategy.AdaptiveBroadcastJoinOptimizationStrategy
- initialize(StreamGraphContext) - Method in class org.apache.flink.table.runtime.strategy.AdaptiveSkewedJoinOptimizationStrategy
- initializeCache(Object) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowSet
-
Set current key context of this window set.
- initializeMetrics(CacheMetricGroup) - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.table.runtime.operators.rank.async.AsyncStateFastTop1Function
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.table.runtime.operators.rank.FastTop1Function
- initializeState(FunctionInitializationContext) - Method in class org.apache.flink.table.runtime.operators.rank.UpdatableTopNFunction
- initializeState(StateInitializationContext) - Method in class org.apache.flink.table.runtime.operators.sort.StreamSortOperator
- initializeState(StateInitializationContext) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- initializeState(StateInitializationContext) - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- initializeWatermark(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- initializeWatermark(long) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.processors.RowTimeSyncStateWindowDeduplicateProcessor
- initializeWatermark(long) - Method in class org.apache.flink.table.runtime.operators.rank.window.processors.SyncStateWindowRankProcessor
- initializeWatermark(long) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowProcessor
-
Initializes the watermark which restores from state.
- initPartitionFanOut - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- initRankEnd(RowData) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractSyncStateTopNFunction
-
Initialize rank end.
- initRankEnd(RowData) - Method in class org.apache.flink.table.runtime.operators.rank.async.AbstractAsyncStateTopNFunction
-
Initialize rank end.
- INNER - org.apache.flink.table.runtime.operators.join.FlinkJoinType
- INNER - org.apache.flink.table.runtime.operators.join.HashJoinType
- InputBase - Class in org.apache.flink.table.runtime.operators.multipleinput.input
-
Base
Input
used inMultipleInputStreamOperatorBase
. - InputBase() - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.input.InputBase
- InputConversionOperator<E> - Class in org.apache.flink.table.runtime.operators.source
-
Operator that converts to internal data structures and wraps atomic records if necessary.
- InputConversionOperator(DynamicTableSource.DataStructureConverter, boolean, boolean, boolean, boolean) - Constructor for class org.apache.flink.table.runtime.operators.source.InputConversionOperator
- inputCountIndex - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- inputFieldTypes - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- InputFormatCacheLoader - Class in org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat
-
CacheLoader
that usedInputFormat
for loading data into the cache. - InputFormatCacheLoader(InputFormat<RowData, ?>, GenericRowDataKeySelector, RowDataSerializer) - Constructor for class org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat.InputFormatCacheLoader
- inputRowType - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- InputSelectionHandler - Class in org.apache.flink.table.runtime.operators.multipleinput.input
-
This handler is mainly used for selecting the next available input index according to read priority in
MultipleInputStreamOperatorBase
. - InputSelectionHandler(List<InputSelectionSpec>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.input.InputSelectionHandler
- InputSelectionSpec - Class in org.apache.flink.table.runtime.operators.multipleinput.input
-
Describe the inputId and read order of MultipleInput operator.
- InputSelectionSpec(int, int) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.input.InputSelectionSpec
- inputSerializer(AbstractRowDataSerializer<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- inputSerializer(AbstractRowDataSerializer<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.RowTimeWindowDeduplicateOperatorBuilder
- inputSerializer(AbstractRowDataSerializer<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- InputSideHasNoUniqueKeyBundle - Class in org.apache.flink.table.runtime.operators.join.stream.bundle
-
For the case that input has no uniqueKey.
- InputSideHasNoUniqueKeyBundle() - Constructor for class org.apache.flink.table.runtime.operators.join.stream.bundle.InputSideHasNoUniqueKeyBundle
- InputSideHasUniqueKeyBundle - Class in org.apache.flink.table.runtime.operators.join.stream.bundle
-
For the case that input has uniqueKey which is not contained by joinKey.
- InputSideHasUniqueKeyBundle() - Constructor for class org.apache.flink.table.runtime.operators.join.stream.bundle.InputSideHasUniqueKeyBundle
- InputSpec - Class in org.apache.flink.table.runtime.operators.multipleinput.input
-
Describe the info of
Input
. - InputSpec(int, int, TableOperatorWrapper<?>, int) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.input.InputSpec
- inputSpecMap - Variable in class org.apache.flink.table.runtime.operators.multipleinput.MultipleInputStreamOperatorBase
- InputSplitCacheLoadTask - Class in org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat
-
Parallel task that loads data into the cache from
InputFormat
with specifiedInputSplit
. - InputSplitCacheLoadTask(ConcurrentHashMap<RowData, Collection<RowData>>, GenericRowDataKeySelector, RowDataSerializer, InputFormat<RowData, InputSplit>, InputSplit) - Constructor for class org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat.InputSplitCacheLoadTask
- InsensitiveOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The insensitive window frame calculates the statements which shouldn't care the window frame, for example RANK/DENSE_RANK/PERCENT_RANK/NTILE/ROW_NUMBER.
- InsensitiveOverFrame(GeneratedAggsHandleFunction) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.InsensitiveOverFrame
- insertIntoProbeBuffer(RowData) - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
-
If the probe row corresponding partition has been spilled to disk, just call this method spill probe row to disk.
- INSTANCE - Static variable in class org.apache.flink.table.data.conversion.DayTimeIntervalDurationConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.ArrayDataConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.BooleanConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.ByteConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.DateConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.DoubleConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.FloatConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.IntConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.LocalDateConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.LocalTimeConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.LongConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.MapDataConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.PrimitiveBooleanArrayConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.PrimitiveByteArrayConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.PrimitiveDoubleArrayConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.PrimitiveFloatArrayConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.PrimitiveIntArrayConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.PrimitiveLongArrayConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.PrimitiveShortArrayConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.RawValueDataConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.ShortConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.StringConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.StringDataConverter
- INSTANCE - Static variable in class org.apache.flink.table.data.util.DataFormatConverters.TimeConverter
- INSTANCE - Static variable in class org.apache.flink.table.runtime.connector.source.ScanRuntimeProviderContext
- INSTANCE - Static variable in class org.apache.flink.table.runtime.keyselector.EmptyRowDataKeySelector
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- INSTANCE - Static variable in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- InstantConverter(int) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.InstantConverter
- instr(BinaryStringData, BinaryStringData, int, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- IntApproxCountDistinctAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.IntApproxCountDistinctAggFunction
- internalPool - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- InternalSerializers - Class in org.apache.flink.table.runtime.typeutils
-
TypeSerializer
ofLogicalType
for internal data structures. - internalTimerService - Variable in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerServiceBase
- InternalTimeWindowAssigner - Interface in org.apache.flink.table.runtime.operators.window.groupwindow.assigners
-
The internal time window assigner which has some useful methods.
- InternalTypeInfo<T> - Class in org.apache.flink.table.runtime.typeutils
-
Type information that wraps a serializer that originated from a
LogicalType
. - InternalWindowProcessFunction<K,W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.internal
-
The internal interface for functions that process over grouped windows.
- InternalWindowProcessFunction(GroupWindowAssigner<W>, NamespaceAggsHandleFunctionBase<W>, long) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
- InternalWindowProcessFunction.Context<K,W extends Window> - Interface in org.apache.flink.table.runtime.operators.window.groupwindow.internal
-
Information available in an invocation of methods of
InternalWindowProcessFunction
. - intersects(TimeWindow) - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow
-
Returns
true
if this window intersects the given window. - IntervalJoinFunction - Class in org.apache.flink.table.runtime.operators.join.interval
- IntervalJoinFunction(GeneratedJoinCondition, InternalTypeInfo<RowData>, boolean[]) - Constructor for class org.apache.flink.table.runtime.operators.join.interval.IntervalJoinFunction
- IntHashSet - Class in org.apache.flink.table.runtime.util.collections
-
Int hash set.
- IntHashSet() - Constructor for class org.apache.flink.table.runtime.util.collections.IntHashSet
- IntHashSet(int) - Constructor for class org.apache.flink.table.runtime.util.collections.IntHashSet
- IntHashSet(int, float) - Constructor for class org.apache.flink.table.runtime.util.collections.IntHashSet
- invalidate(RowData) - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.LookupFullCache
- invalidCounter - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- invertKey() - Method in interface org.apache.flink.table.runtime.generated.NormalizedKeyComputer
-
Flag whether normalized key comparisons should be inverted key.
- inView - Variable in class org.apache.flink.table.runtime.io.BinaryRowChannelInputViewIterator
- ioManager - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The I/O manager used to instantiate writers for the spilled partitions.
- ioManager - Variable in class org.apache.flink.table.runtime.operators.sort.AbstractBinaryExternalMerger
- is32BitDecimal(int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- is64BitDecimal(int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- isAccumulateMsg(RowData) - Static method in class org.apache.flink.table.data.util.RowDataUtil
-
Returns true if the message is either
RowKind.INSERT
orRowKind.UPDATE_AFTER
, which refers to an accumulate operation of aggregation. - isAlpha(Object) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- isArray(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isAssignable(LogicalType, LogicalType) - Static method in class org.apache.flink.table.runtime.types.PlannerTypeUtils
-
Now in the conversion to the TypeInformation from DataType, type may lose some information about nullable and precision.
- isAsyncStateProcessingEnabled() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.FirstInputOfTwoInput
- isAsyncStateProcessingEnabled() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.OneInput
- isAsyncStateProcessingEnabled() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.SecondInputOfTwoInput
- isBasicType() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- isBasicType() - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- isBasicType() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- isBasicType() - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- isBasicType() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- isBinaryString(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isBoolean(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isBounded() - Method in class org.apache.flink.table.runtime.connector.sink.SinkRuntimeProviderContext
- isBroadcastJoin(ImmutableStreamNode) - Static method in class org.apache.flink.table.runtime.strategy.AdaptiveJoinOptimizationUtils
- isBroadcastJoinDisabled(ReadableConfig) - Static method in class org.apache.flink.table.runtime.strategy.AdaptiveJoinOptimizationUtils
- isBuildOuter() - Method in enum org.apache.flink.table.runtime.operators.join.HashJoinType
- isByteArrayDecimal(int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- isCharacterString(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isCleanupTime(W, long) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
-
Returns
true
if the given time is the cleanup time for the given window. - isClosed() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- isClosed() - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- isClosed() - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelReaderInputView
- isClosed() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
-
Checks if the wrapped operator has been closed.
- isCollected() - Method in class org.apache.flink.table.runtime.collector.TableFunctionCollector
-
Whether
Collector.collect(Object)
has been called. - isComparable(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isConstantRankEnd - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- isDecimal(Object) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- isDecimal(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isDense - Variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Is now dense mode.
- isDeterministic() - Method in class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
- isDeterministic() - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- isDeterministic() - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- isDeterministic() - Method in class org.apache.flink.table.runtime.functions.BuiltInSpecializedFunction
- isDeterministic() - Method in class org.apache.flink.table.runtime.functions.scalar.BuiltInScalarFunction
- isDeterministic() - Method in class org.apache.flink.table.runtime.functions.table.BuiltInTableFunction
- isDigit(Object) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- isDuplicate(RowData, RowData, int, boolean) - Static method in class org.apache.flink.table.runtime.operators.deduplicate.utils.DeduplicateFunctionHelper
-
Returns current row is duplicate row or not compared to previous row.
- isEmpty() - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
-
Check if this bufferBundle is empty.
- isEmpty() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.AssociatedRecords
- isEmpty() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryInMemorySortBuffer
-
Checks whether the buffer is empty.
- isEmpty(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- isEmpty(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
-
Returns true if this state contains no key-value mappings, otherwise false.
- isEndOfStream(RowData) - Method in class org.apache.flink.formats.raw.RawFormatDeserializationSchema
- isEventTime - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- isEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountSlidingWindowAssigner
- isEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountTumblingWindowAssigner
- isEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- isEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.GroupWindowAssigner
-
Returns
true
if elements are assigned to windows based on event time,false
otherwise. - isEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SessionWindowAssigner
- isEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- isEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.TumblingWindowAssigner
- isEventTime() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowAssigner
-
Returns
true
if elements are assigned to windows based on event time,false
based on processing time. - isEventTime() - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.WindowedSliceAssigner
- isEventTime() - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.SessionUnsliceAssigner
- isEventTime() - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- isFound() - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap.LookupInfo
- isIdentityConversion() - Method in interface org.apache.flink.table.data.conversion.DataStructureConverter
-
Returns whether this conversion is a no-op.
- isIdentityConversion() - Method in class org.apache.flink.table.data.conversion.IdentityConverter
- isImmutableType() - Method in class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- isImmutableType() - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- isInRankEnd(long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractSyncStateTopNFunction
- isInRankEnd(long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- isInRankRange(long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractSyncStateTopNFunction
- isInRankRange(long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- isInteger(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isInternalInput() - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- isInteroperable(LogicalType, LogicalType) - Static method in class org.apache.flink.table.runtime.types.PlannerTypeUtils
-
Can the two types operate with each other.
- isJsonArray(String) - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
- isJsonObject(String) - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
- isJsonScalar(String) - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
- isJsonValue(String) - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
- isKeyFullyDetermines() - Method in interface org.apache.flink.table.runtime.generated.NormalizedKeyComputer
-
whether the normalized key can fully determines the comparison.
- isKeyType() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- isKeyType() - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- isKeyType() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- isKeyType() - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- isKeyType() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- isLeftOuter() - Method in enum org.apache.flink.table.runtime.operators.join.FlinkJoinType
- isLeftOuterJoin - Variable in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- isLong(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isMap(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isMultiset(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isMutable(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isNullAt(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- isNullAt(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- isNumeric(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isOuter() - Method in enum org.apache.flink.table.runtime.operators.join.FlinkJoinType
- isPointwise() - Method in class org.apache.flink.table.runtime.partitioner.BinaryHashPartitioner
- isPointwise() - Method in class org.apache.flink.table.runtime.partitioner.RowDataCustomStreamPartitioner
- isPrimitive(LogicalType) - Static method in class org.apache.flink.table.runtime.types.PlannerTypeUtils
- isPrimitive(LogicalTypeRoot) - Static method in class org.apache.flink.table.runtime.types.PlannerTypeUtils
- isProbeOuter() - Method in enum org.apache.flink.table.runtime.operators.join.HashJoinType
- isProcessingTimeTimer(KeyedProcessFunction.OnTimerContext) - Method in class org.apache.flink.table.runtime.functions.KeyedProcessFunctionWithCleanupState
- isProcTime(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isRaw(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isReference(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isRetractMsg(RowData) - Static method in class org.apache.flink.table.data.util.RowDataUtil
-
Returns true if the message is either
RowKind.DELETE
orRowKind.UPDATE_BEFORE
, which refers to a retract operation of aggregation. - isRightOuter() - Method in enum org.apache.flink.table.runtime.operators.join.FlinkJoinType
- isRow(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isRowTime(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isSpaceString(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- isStopped - Variable in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
- isStructuredType(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isTemporal(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isTimeInterval(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isTimePoint(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isTimestamp(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isTimestampWithLocalZone(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- isTupleType() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- isTupleType() - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- isTupleType() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- isTupleType() - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- isTupleType() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- isWindowFired(long, long, ZoneId) - Static method in class org.apache.flink.table.runtime.util.TimeWindowUtil
-
Returns the window should fired or not on current progress.
- isWindowLate(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
-
Returns
true
if the watermark is after the end timestamp plus the allowed lateness of the given window. - IterativeConditionRunner - Class in org.apache.flink.table.runtime.operators.match
-
A
RichIterativeCondition
wrapper to delegate invocation to the code generatedRichIterativeCondition
. - IterativeConditionRunner(GeneratedFunction<RichIterativeCondition<RowData>>) - Constructor for class org.apache.flink.table.runtime.operators.match.IterativeConditionRunner
- iterator() - Method in class org.apache.flink.table.runtime.util.SingleElementIterator
- iterator(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
-
Iterates over all the mappings in the state.
J
- join(RowData, RowData, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.interval.IntervalJoinFunction
- join(RowIterator<BinaryRowData>, RowData) - Method in class org.apache.flink.table.runtime.operators.join.HashJoinOperator
- joinAndClear(long, Iterable<RowData>, Iterable<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
- joinCondition - Variable in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- joinCondition - Variable in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- joinCondition - Variable in class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
- JoinCondition - Interface in org.apache.flink.table.runtime.generated
-
Interface for code generated condition function for [[org.apache.calcite.rel.core.Join]].
- JoinConditionWithNullFilters - Class in org.apache.flink.table.runtime.operators.join
-
Utility to take null filters into consideration when apply join condition.
- JoinConditionWithNullFilters(JoinCondition, boolean[], KeyContext) - Constructor for class org.apache.flink.table.runtime.operators.join.JoinConditionWithNullFilters
- JoinHelper<STATE_VIEW,OUTER_STATE_VIEW extends STATE_VIEW> - Class in org.apache.flink.table.runtime.operators.join.stream.utils
-
A helper to do the logic of streaming join.
- JoinHelper(boolean, boolean, JoinedRowData, RowData, RowData, TimestampedCollector<RowData>) - Constructor for class org.apache.flink.table.runtime.operators.join.stream.utils.JoinHelper
- JoinInputSideSpec - Class in org.apache.flink.table.runtime.operators.join.stream.utils
-
The
JoinInputSideSpec
is ap specification which describes input side information of a Join. - joinKeyContainsUniqueKey() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinInputSideSpec
-
Returns true if the join key contains the unique key of the input.
- JoinKeyContainsUniqueKeyBundle - Class in org.apache.flink.table.runtime.operators.join.stream.bundle
-
For the case that input has joinKey contains uniqueKey.
- JoinKeyContainsUniqueKeyBundle() - Constructor for class org.apache.flink.table.runtime.operators.join.stream.bundle.JoinKeyContainsUniqueKeyBundle
- JoinRecordAsyncStateView - Interface in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state
-
A
JoinRecordAsyncStateView
is a view to the join state. - JoinRecordAsyncStateViews - Class in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state
-
Utility to create a
JoinRecordAsyncStateView
depends onJoinInputSideSpec
. - JoinRecordAsyncStateViews() - Constructor for class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.JoinRecordAsyncStateViews
- JoinRecordStateView - Interface in org.apache.flink.table.runtime.operators.join.stream.state
-
A
JoinRecordStateView
is a view to the join state. - JoinRecordStateViews - Class in org.apache.flink.table.runtime.operators.join.stream.state
-
Utility to create a
JoinRecordStateView
depends onJoinInputSideSpec
. - JoinRecordStateViews() - Constructor for class org.apache.flink.table.runtime.operators.join.stream.state.JoinRecordStateViews
- joinType(FlinkJoinType) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- JsonArrayAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Implementation for
BuiltInFunctionDefinitions.JSON_ARRAYAGG_ABSENT_ON_NULL
/BuiltInFunctionDefinitions.JSON_ARRAYAGG_NULL_ON_NULL
. - JsonArrayAggFunction(LogicalType[], boolean) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction
- JsonArrayAggFunction.Accumulator - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for
JsonArrayAggFunction
. - jsonExists(String, String) - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
- jsonExists(String, String, JsonExistsOnError) - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
- JsonObjectAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Implementation for
BuiltInFunctionDefinitions.JSON_OBJECTAGG_NULL_ON_NULL
/BuiltInFunctionDefinitions.JSON_OBJECTAGG_ABSENT_ON_NULL
. - JsonObjectAggFunction(LogicalType[], boolean) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction
- JsonObjectAggFunction.Accumulator - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for
JsonObjectAggFunction
. - JsonPathCache - Class in org.apache.flink.table.runtime.functions
-
The default cache for the jsonpath
com.jayway.jsonpath.spi.cache.CacheProvider
. - JsonPathCache() - Constructor for class org.apache.flink.table.runtime.functions.JsonPathCache
- jsonQuery(String, String, SqlJsonUtils.JsonQueryReturnType, JsonQueryWrapper, JsonQueryOnEmptyOrError, JsonQueryOnEmptyOrError) - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
- JsonQuoteFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.JSON_QUOTE
. - JsonQuoteFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.JsonQuoteFunction
- JsonUnquoteFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.JSON_UNQUOTE
. - JsonUnquoteFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.JsonUnquoteFunction
- jsonValue(String, String, JsonValueOnEmptyOrError, Object, JsonValueOnEmptyOrError, Object) - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
K
- keepCacheOnRelease(boolean) - Static method in class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager
- keepLastRow(boolean) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.RowTimeWindowDeduplicateOperatorBuilder
- keyComparator - Variable in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- keyContext - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- keyContext - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- KeyedCoProcessOperatorWithWatermarkDelay<K,IN1,IN2,OUT> - Class in org.apache.flink.table.runtime.operators.join
-
A
KeyedCoProcessOperator
that supports holding back watermarks with a static delay. - KeyedCoProcessOperatorWithWatermarkDelay(KeyedCoProcessFunction<K, IN1, IN2, OUT>, long) - Constructor for class org.apache.flink.table.runtime.operators.join.KeyedCoProcessOperatorWithWatermarkDelay
- KeyedLookupJoinWrapper - Class in org.apache.flink.table.runtime.operators.join.lookup
-
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. - KeyedLookupJoinWrapper(LookupJoinRunner, StateTtlConfig, TypeSerializer<RowData>, boolean) - Constructor for class org.apache.flink.table.runtime.operators.join.lookup.KeyedLookupJoinWrapper
- KeyedMapBundleOperator<K,V,IN,OUT> - Class in org.apache.flink.table.runtime.operators.bundle
-
The
KeyedMapBundleOperator
uses framework's key as bundle map key, thus can only be used onKeyedStream
. - KeyedMapBundleOperator(MapBundleFunction<K, V, IN, OUT>, BundleTrigger<IN>) - Constructor for class org.apache.flink.table.runtime.operators.bundle.KeyedMapBundleOperator
- KeyedProcessFunctionWithCleanupState<K,IN,OUT> - Class in org.apache.flink.table.runtime.functions
-
A function that processes elements of a stream, and could cleanup state.
- KeyedProcessFunctionWithCleanupState(long, long) - Constructor for class org.apache.flink.table.runtime.functions.KeyedProcessFunctionWithCleanupState
- KeyedStateListView(ListState<T>) - Constructor for class org.apache.flink.table.runtime.dataview.StateListView.KeyedStateListView
- KeyedStateMapViewWithKeysNotNull(MapState<EK, EV>) - Constructor for class org.apache.flink.table.runtime.dataview.StateMapView.KeyedStateMapViewWithKeysNotNull
- KeyedStateMapViewWithKeysNullable(MapState<EK, EV>, ValueState<EV>) - Constructor for class org.apache.flink.table.runtime.dataview.StateMapView.KeyedStateMapViewWithKeysNullable
- keys(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
-
Returns all the keys in the state.
- keySerializer - Variable in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
-
Used to serialize map key into RecordArea's MemorySegments.
- keySerializer - Variable in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
-
Used to serialize map key into RecordArea's MemorySegments.
- keySerializer(PagedTypeSerializer<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- keySerializer(PagedTypeSerializer<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.RowTimeWindowDeduplicateOperatorBuilder
- keySerializer(PagedTypeSerializer<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- keyValue(BinaryStringData, byte, byte, BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Parse target string as key-value string and return the value matches key name.
- keyValue(BinaryStringData, BinaryStringData, BinaryStringData, BinaryStringData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Parse string as key-value string and return the value matches key name. example: keyvalue('k1=v1;k2=v2', ';', '=', 'k2') = 'v2' keyvalue('k1:v1,k2:v2', ',', ':', 'k3') = NULL
- KeyValueIterator<K,V> - Interface in org.apache.flink.table.runtime.util
-
An internal iterator interface which presents a more restrictive API than
Iterator
.
L
- LagAcc() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction.LagAcc
- LagAggFunction<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Lag
AggregateFunction
. - LagAggFunction(LogicalType[]) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction
- LagAggFunction.LagAcc<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for LAG.
- lastBucketPosition - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- lastElement() - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Returns the last record of the last Entry in the buffer.
- lastEntry() - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Returns the last Entry in the buffer.
- lastIndexEntryOffset - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- lastOrder - Variable in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction.LastValueWithRetractAccumulator
- lastValue - Variable in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction.LastValueWithRetractAccumulator
- LastValueAggFunction<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in LAST_VALUE aggregate function.
- LastValueAggFunction(LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- LastValueWithRetractAccumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction.LastValueWithRetractAccumulator
- LastValueWithRetractAggFunction<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in LAST_VALUE with retraction aggregate function.
- LastValueWithRetractAggFunction(LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for LAST_VALUE with retraction.
- LAX - org.apache.flink.table.runtime.functions.SqlJsonUtils.PathMode
- LazyMemorySegmentPool - Class in org.apache.flink.table.runtime.util
-
MemorySegmentPool
that lazy allocate memory pages fromMemoryManager
. - LazyMemorySegmentPool(Object, MemoryManager, int) - Constructor for class org.apache.flink.table.runtime.util.LazyMemorySegmentPool
- LEFT - org.apache.flink.table.runtime.operators.join.FlinkJoinType
- LEFT_INPUT_TYPE_NUMBER - Static variable in class org.apache.flink.table.runtime.strategy.BaseAdaptiveJoinOperatorOptimizationStrategy
- LEFT_RECORDS_STATE_NAME - Static variable in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- LEFT_RECORDS_STATE_NAME - Static variable in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- leftInputSideSpec - Variable in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- leftInputSideSpec - Variable in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- leftIsOuter - Variable in class org.apache.flink.table.runtime.operators.join.stream.StreamingJoinOperator
- leftRecordStateView - Variable in class org.apache.flink.table.runtime.operators.join.stream.StreamingJoinOperator
- leftSemiOrAnti() - Method in enum org.apache.flink.table.runtime.operators.join.HashJoinType
- leftSerializer - Variable in class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
- leftSerializer(TypeSerializer<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- leftStateRetentionTime - Variable in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- leftStateRetentionTime - Variable in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- leftType - Variable in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- leftType - Variable in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- leftWindowEndIndex(int) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- LegacyInstantTypeInfo - Class in org.apache.flink.table.runtime.typeutils
-
TypeInformation
forInstant
. - LegacyInstantTypeInfo(int) - Constructor for class org.apache.flink.table.runtime.typeutils.LegacyInstantTypeInfo
- LegacyLocalDateTimeTypeInfo - Class in org.apache.flink.table.runtime.typeutils
-
TypeInformation
forLocalDateTime
. - LegacyLocalDateTimeTypeInfo(int) - Constructor for class org.apache.flink.table.runtime.typeutils.LegacyLocalDateTimeTypeInfo
- LegacyTimestampTypeInfo - Class in org.apache.flink.table.runtime.typeutils
-
TypeInformation
forTimestamp
. - LegacyTimestampTypeInfo(int) - Constructor for class org.apache.flink.table.runtime.typeutils.LegacyTimestampTypeInfo
- LENGTH_SIZE_IN_BYTES - Static variable in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- LimitOperator - Class in org.apache.flink.table.runtime.operators.sort
-
Operator for batch limit.
- LimitOperator(boolean, long, long) - Constructor for class org.apache.flink.table.runtime.operators.sort.LimitOperator
- LinkedListSerializer<T> - Class in org.apache.flink.table.runtime.typeutils
-
A serializer for
LinkedList
. - LinkedListSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
-
Creates a list serializer that uses the given serializer to serialize the list's elements.
- LinkedListSerializer(TypeSerializer<T>, boolean) - Constructor for class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- LinkedListSerializer.LinkedListSerializerSnapshot<T> - Class in org.apache.flink.table.runtime.typeutils
-
Snapshot class for the
LinkedListSerializer
. - LinkedListSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.LinkedListSerializer.LinkedListSerializerSnapshot
-
Constructor for read instantiation.
- LinkedListSerializerSnapshot(LinkedListSerializer<T>) - Constructor for class org.apache.flink.table.runtime.typeutils.LinkedListSerializer.LinkedListSerializerSnapshot
-
Constructor to create the snapshot for writing.
- list - Variable in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction.ArrayAggAccumulator
- list - Variable in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction.Accumulator
- list - Variable in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction.ListAggWithRetractAccumulator
- list - Variable in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator
- ListAggWithRetractAccumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction.ListAggWithRetractAccumulator
- ListAggWithRetractAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in LISTAGG with retraction aggregate function.
- ListAggWithRetractAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction
- ListAggWithRetractAggFunction.ListAggWithRetractAccumulator - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for LISTAGG with retraction.
- ListAggWsWithRetractAccumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator
- ListAggWsWithRetractAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in LISTAGGWS with retraction aggregate function.
- ListAggWsWithRetractAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
- ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for LISTAGGWS with retraction.
- ListenableCollector<T> - Class in org.apache.flink.table.runtime.collector
-
A listenable collector for lookup join that can be called when an original record was collected.
- ListenableCollector() - Constructor for class org.apache.flink.table.runtime.collector.ListenableCollector
- ListenableCollector.CollectListener<T> - Interface in org.apache.flink.table.runtime.collector
-
An interface can listen on collecting original record.
- ListMemorySegmentPool - Class in org.apache.flink.table.runtime.operators.sort
-
MemorySegment pool of a MemorySegment list.
- ListMemorySegmentPool(List<MemorySegment>) - Constructor for class org.apache.flink.table.runtime.operators.sort.ListMemorySegmentPool
- ListViewSpec - Class in org.apache.flink.table.runtime.dataview
-
Specification for a
ListView
. - ListViewSpec(String, int, DataType) - Constructor for class org.apache.flink.table.runtime.dataview.ListViewSpec
- ListViewSpec(String, int, DataType, TypeSerializer<?>) - Constructor for class org.apache.flink.table.runtime.dataview.ListViewSpec
-
Deprecated.
- LITTLE_ENDIAN - Static variable in class org.apache.flink.formats.raw.RawFormatOptions
- LITTLE_ENDIAN - Static variable in class org.apache.flink.table.runtime.util.SegmentsUtil
-
Constant that flags the byte order.
- LOAD_FACTOR - Static variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- LocalAggCombiner - Class in org.apache.flink.table.runtime.operators.aggregate.window.combines
-
An implementation of
RecordsCombiner
that accumulates input records into local accumulators. - LocalAggCombiner(NamespaceAggsHandleFunction<Long>, Collector<RowData>) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.combines.LocalAggCombiner
- LocalAggCombiner.Factory - Class in org.apache.flink.table.runtime.operators.aggregate.window.combines
-
Factory to create
LocalAggCombiner
. - LocalDateTimeConverter(int) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.LocalDateTimeConverter
- LocalFactory(PagedTypeSerializer<RowData>, AbstractRowDataSerializer<RowData>, RecordsCombiner.LocalFactory) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.buffers.RecordsWindowBuffer.LocalFactory
- LocalRuntimeFilterBuilderOperator - Class in org.apache.flink.table.runtime.operators.runtimefilter
-
Local runtime filter builder operator.
- LocalRuntimeFilterBuilderOperator(GeneratedProjection, int, int) - Constructor for class org.apache.flink.table.runtime.operators.runtimefilter.LocalRuntimeFilterBuilderOperator
- LocalSlicingWindowAggOperator - Class in org.apache.flink.table.runtime.operators.aggregate.window
-
The operator used for local window aggregation.
- LocalSlicingWindowAggOperator(RowDataKeySelector, SliceAssigner, WindowBuffer.LocalFactory, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.LocalSlicingWindowAggOperator
- LocalZonedTimestampInstantConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
LocalZonedTimestampType
ofInstant
external type. - LocalZonedTimestampInstantConverter() - Constructor for class org.apache.flink.table.data.conversion.LocalZonedTimestampInstantConverter
- LocalZonedTimestampIntConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
LocalZonedTimestampType
ofInteger
external type. - LocalZonedTimestampIntConverter() - Constructor for class org.apache.flink.table.data.conversion.LocalZonedTimestampIntConverter
- LocalZonedTimestampLongConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
LocalZonedTimestampType
ofLong
external type. - LocalZonedTimestampLongConverter() - Constructor for class org.apache.flink.table.data.conversion.LocalZonedTimestampLongConverter
- LocalZonedTimestampTimestampConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
LocalZonedTimestampType
ofTimestamp
external type. - LocalZonedTimestampTimestampConverter() - Constructor for class org.apache.flink.table.data.conversion.LocalZonedTimestampTimestampConverter
- log(double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns the natural logarithm of "x".
- log(double, double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns the logarithm of "x" with base "base".
- log(double, DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- log(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- log(DecimalData, double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- log(DecimalData, DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- LOG - Static variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- log10(double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- log10(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- log2(double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns the logarithm of "a" with base 2.
- log2(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- log2NumBuckets - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- LogicalTypeDataTypeConverter - Class in org.apache.flink.table.runtime.types
-
Deprecated.
- LogicalTypeDataTypeConverter() - Constructor for class org.apache.flink.table.runtime.types.LogicalTypeDataTypeConverter
-
Deprecated.
- LongApproxCountDistinctAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.LongApproxCountDistinctAggFunction
- LongHashPartition - Class in org.apache.flink.table.runtime.hashtable
-
Partition for
LongHybridHashTable
. - LongHashPartition.MatchIterator - Class in org.apache.flink.table.runtime.hashtable
-
Iterator for probe match.
- LongHashPartitionChannelReaderInputViewIterator - Class in org.apache.flink.table.runtime.io
-
A simple iterator over the input read though an I/O channel.
- LongHashPartitionChannelReaderInputViewIterator(ChannelReaderInputView, BinaryRowDataSerializer) - Constructor for class org.apache.flink.table.runtime.io.LongHashPartitionChannelReaderInputViewIterator
- LongHashSet - Class in org.apache.flink.table.runtime.util.collections
-
Long hash set.
- LongHashSet() - Constructor for class org.apache.flink.table.runtime.util.collections.LongHashSet
- LongHashSet(int) - Constructor for class org.apache.flink.table.runtime.util.collections.LongHashSet
- LongHashSet(int, float) - Constructor for class org.apache.flink.table.runtime.util.collections.LongHashSet
- LongHybridHashTable - Class in org.apache.flink.table.runtime.hashtable
-
Special optimized hashTable with key long.
- LongHybridHashTable(Object, boolean, int, BinaryRowDataSerializer, BinaryRowDataSerializer, MemoryManager, long, IOManager, int, long) - Constructor for class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- LongTimestampDataConverter(int) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.LongTimestampDataConverter
- lookup(K) - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- lookup(RowData) - Method in class org.apache.flink.table.runtime.functions.table.lookup.CachingLookupFunction
- lookup(RowData) - Method in class org.apache.flink.table.runtime.operators.join.lookup.RetryableLookupFunctionDelegator
- LOOKUP_CACHE_METRIC_GROUP_NAME - Static variable in class org.apache.flink.table.runtime.functions.table.lookup.CachingAsyncLookupFunction
- LOOKUP_CACHE_METRIC_GROUP_NAME - Static variable in class org.apache.flink.table.runtime.functions.table.lookup.CachingLookupFunction
- LookupBucketIterator - Class in org.apache.flink.table.runtime.hashtable
-
Build iterator from bucket to match probe row.
- LookupCacheManager - Class in org.apache.flink.table.runtime.functions.table.lookup
-
Managing shared caches across different subtasks.
- LookupCacheManager.RefCountedCache - Class in org.apache.flink.table.runtime.functions.table.lookup
-
A wrapper class of
LookupCache
which also tracks the reference count of it. - LookupFullCache - Class in org.apache.flink.table.runtime.functions.table.lookup.fullcache
-
Internal implementation of
LookupCache
forLookupOptions.LookupCacheType.FULL
. - LookupFullCache(CacheLoader, CacheReloadTrigger) - Constructor for class org.apache.flink.table.runtime.functions.table.lookup.fullcache.LookupFullCache
- LookupJoinRunner - Class in org.apache.flink.table.runtime.operators.join.lookup
-
The join runner to lookup the dimension table.
- LookupJoinRunner(GeneratedFunction<FlatMapFunction<RowData, RowData>>, GeneratedCollector<ListenableCollector<RowData>>, GeneratedFunction<FilterCondition>, boolean, int) - Constructor for class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- LookupJoinWithCalcRunner - Class in org.apache.flink.table.runtime.operators.join.lookup
-
The join runner with an additional calculate function on the dimension table.
- LookupJoinWithCalcRunner(GeneratedFunction<FlatMapFunction<RowData, RowData>>, GeneratedFunction<FlatMapFunction<RowData, RowData>>, GeneratedCollector<ListenableCollector<RowData>>, GeneratedFunction<FilterCondition>, boolean, int) - Constructor for class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinWithCalcRunner
- LookupRuntimeProviderContext - Class in org.apache.flink.table.runtime.connector.source
-
Implementation of
DynamicTableSource.Context
. - LookupRuntimeProviderContext(int[][], boolean) - Constructor for class org.apache.flink.table.runtime.connector.source.LookupRuntimeProviderContext
- lpad(String, int, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns the string str left-padded with the string pad to a length of len characters.
- LRUMap<K,V> - Class in org.apache.flink.table.runtime.util
-
An LRU cache, based on
LinkedHashMap
. - LRUMap(int) - Constructor for class org.apache.flink.table.runtime.util.LRUMap
- LRUMap(int, LRUMap.RemovalListener<K, V>) - Constructor for class org.apache.flink.table.runtime.util.LRUMap
- LRUMap.RemovalListener<K,V> - Interface in org.apache.flink.table.runtime.util
-
An object that can receive a notification when an entry is removed from a LRUMap.
M
- main(String[]) - Static method in class org.apache.flink.table.runtime.application.SqlDriver
- map - Variable in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction.CollectAccumulator
- map - Variable in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction.Accumulator
- map - Variable in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction.MaxWithRetractAccumulator
- map - Variable in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction.MinWithRetractAccumulator
- map(RowData) - Method in class org.apache.flink.table.runtime.operators.join.interval.PaddingLeftMapFunction
- map(RowData) - Method in class org.apache.flink.table.runtime.operators.join.interval.PaddingRightMapFunction
- MapBundleFunction<K,V,IN,OUT> - Class in org.apache.flink.table.runtime.operators.bundle
-
Basic interface for map bundle processing.
- MapBundleFunction() - Constructor for class org.apache.flink.table.runtime.operators.bundle.MapBundleFunction
- MapBundleOperator<K,V,IN,OUT> - Class in org.apache.flink.table.runtime.operators.bundle
-
The
MapBundleOperator
uses aKeySelector
to extract bundle key, thus can be used with non-keyed-stream. - MapBundleOperator(MapBundleFunction<K, V, IN, OUT>, BundleTrigger<IN>, KeySelector<IN, K>) - Constructor for class org.apache.flink.table.runtime.operators.bundle.MapBundleOperator
- MapConverter(DataType, DataType) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.MapConverter
- MapDataSerializer - Class in org.apache.flink.table.runtime.typeutils
-
Serializer for
MapData
. - MapDataSerializer(LogicalType, LogicalType) - Constructor for class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- MapDataSerializer.MapDataSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils
-
TypeSerializerSnapshot
forArrayDataSerializer
. - MapDataSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.MapDataSerializer.MapDataSerializerSnapshot
- MapDataUtil - Class in org.apache.flink.table.data.util
-
Utilities for
MapData
. - MapDataUtil() - Constructor for class org.apache.flink.table.data.util.MapDataUtil
- MapEntriesFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.MAP_ENTRIES
. - MapEntriesFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.MapEntriesFunction
- MapFromArraysFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.MAP_FROM_ARRAYS
. - MapFromArraysFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.MapFromArraysFunction
- mapFromPages(BinaryRowData, AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- mapFromPages(RowData, AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- mapFromPages(WindowKey, AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- mapFromPages(T, AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.PagedTypeSerializer
-
Map a reused record from the given source paged input view.
- MapKeysFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.MAP_KEYS
. - MapKeysFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.MapKeysFunction
- MapMapConverter<K,V> - Class in org.apache.flink.table.data.conversion
- mapSize - Variable in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction.MaxWithRetractAccumulator
- mapSize - Variable in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction.MinWithRetractAccumulator
- MapUnionFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.MAP_UNION
. - MapUnionFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.MapUnionFunction
- MapUnnestTableFunction(SpecializedFunction.SpecializedContext, LogicalType, ArrayData.ElementGetter, ArrayData.ElementGetter) - Constructor for class org.apache.flink.table.runtime.functions.table.UnnestRowsFunction.MapUnnestTableFunction
- MapValuesFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.MAP_VALUES
. - MapValuesFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.MapValuesFunction
- MapViewSpec - Class in org.apache.flink.table.runtime.dataview
-
Specification for a
MapView
. - MapViewSpec(String, int, DataType, boolean) - Constructor for class org.apache.flink.table.runtime.dataview.MapViewSpec
- MapViewSpec(String, int, DataType, boolean, TypeSerializer<?>, TypeSerializer<?>) - Constructor for class org.apache.flink.table.runtime.dataview.MapViewSpec
-
Deprecated.
- markAsBroadcastJoin(boolean, boolean) - Method in interface org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoin
-
Determine whether the adaptive join operator can be optimized as broadcast hash join and decide which input side is the build side or a smaller side.
- markAsBroadcastJoin(boolean, boolean) - Method in class org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoinOperatorFactory
- mask - Variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
The mask for wrapping a position counter.
- matchBuffer - Variable in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- MatchIterator() - Constructor for class org.apache.flink.table.runtime.hashtable.LongHashPartition.MatchIterator
- matchKey - Variable in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- max - Variable in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction.MaxWithRetractAccumulator
- MAX_NUM_PARTITIONS - Static variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The maximum number of partitions, which defines the spilling granularity.
- MAX_RECURSION_DEPTH - Static variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The maximum number of recursive partitionings that the join does before giving up.
- maxFill - Variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Threshold after which we rehash.
- maxFill(int, float) - Static method in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Returns the maximum number of entries that can be filled before rehashing.
- maxInitBufferOfBucketArea(int) - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
Give up to one-sixth of the memory of the bucket area.
- maxNormalizedKey(MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
-
Max unsigned byte is -1.
- maxNumPartition() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
Bucket area need at-least one and data need at-least one.
- maxTimestamp() - Method in class org.apache.flink.table.runtime.operators.window.CountWindow
- maxTimestamp() - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow
-
Gets the largest timestamp that still belongs to this window.
- maxTimestamp() - Method in class org.apache.flink.table.runtime.operators.window.Window
-
Gets the largest timestamp that still belongs to this window.
- MaxWithRetractAccumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction.MaxWithRetractAccumulator
- MaxWithRetractAggFunction<T extends Comparable<T>> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in MAX with retraction aggregate function.
- MaxWithRetractAggFunction(LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction
- MaxWithRetractAggFunction.MaxWithRetractAccumulator<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for MAX with retraction.
- memoryPool - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- memorySegmentPool - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- MemorySegmentPool - Interface in org.apache.flink.table.runtime.util
-
MemorySegment pool to hold pages in memory.
- merge(Long, Iterable<Long>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.SliceSharedSyncStateWindowAggProcessor
- merge(N, RowData) - Method in interface org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunctionBase
-
Merges the other accumulators into current accumulators.
- merge(RowData) - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunctionBase
-
Merges the other accumulators into current accumulators.
- merge(ArrayAggFunction.ArrayAggAccumulator<T>, Iterable<ArrayAggFunction.ArrayAggAccumulator<T>>) - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction
- merge(CollectAggFunction.CollectAccumulator<T>, Iterable<CollectAggFunction.CollectAccumulator<T>>) - Method in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction
- merge(HllBuffer, Iterable<HllBuffer>) - Method in class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction
- merge(HllBuffer, HllBuffer) - Method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HyperLogLogPlusPlus
-
Merge the HLL buffers by iterating through the registers in both buffers and select the maximum number of leading zeros for each register.
- merge(JsonObjectAggFunction.Accumulator, Iterable<JsonObjectAggFunction.Accumulator>) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction
- merge(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator, Iterable<ListAggWithRetractAggFunction.ListAggWithRetractAccumulator>) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction
- merge(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator, Iterable<ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator>) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
- merge(MaxWithRetractAggFunction.MaxWithRetractAccumulator<T>, Iterable<MaxWithRetractAggFunction.MaxWithRetractAccumulator<T>>) - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction
- merge(MinWithRetractAggFunction.MinWithRetractAccumulator<T>, Iterable<MinWithRetractAggFunction.MinWithRetractAccumulator<T>>) - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction
- merge(PercentileAggFunction.PercentileAccumulator, Iterable<PercentileAggFunction.PercentileAccumulator>) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- merge(W, Collection<W>, W, Collection<W>) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowSet.MergeFunction
-
This gets called when a merge occurs.
- merge(W, R) - Method in interface org.apache.flink.table.runtime.operators.window.MergeCallback
-
Specifies that states of the given windows or slices should be merged into the result window or slice.
- MergeCallback<W,R> - Interface in org.apache.flink.table.runtime.operators.window
-
Callback to be used in when merging slices or windows for specifying which slices or windows should be merged.
- mergeChannelList(List<ChannelWithMeta>) - Method in class org.apache.flink.table.runtime.operators.sort.AbstractBinaryExternalMerger
-
Merges the given sorted runs to a smaller number of sorted runs.
- mergeComparator() - Method in class org.apache.flink.table.runtime.operators.sort.AbstractBinaryExternalMerger
- mergeComparator() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalMerger
- mergeComparator() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryKVExternalMerger
- mergePartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger.OnMergeContext
- mergeReusedEntries(int) - Method in class org.apache.flink.table.runtime.operators.sort.AbstractBinaryExternalMerger
- mergeReusedEntries(int) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalMerger
- mergeReusedEntries(int) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryKVExternalMerger
- mergeSlices(long, MergeCallback<Long, Iterable<Long>>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- mergeSlices(long, MergeCallback<Long, Iterable<Long>>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- mergeSlices(long, MergeCallback<Long, Iterable<Long>>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.SlicedSharedSliceAssigner
- mergeSlices(long, MergeCallback<Long, Iterable<Long>>) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceSharedAssigner
-
Determines which slices (if any) should be merged and then merge them.
- mergeWindows(TimeWindow, NavigableSet<TimeWindow>, MergeCallback<TimeWindow, Collection<TimeWindow>>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SessionWindowAssigner
- mergeWindows(TimeWindow, NavigableSet<TimeWindow>, MergeCallback<TimeWindow, Collection<TimeWindow>>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- mergeWindows(W, NavigableSet<W>, MergeCallback<W, Collection<W>>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.MergingWindowAssigner
-
Determines which windows (if any) should be merged.
- MergingWindowAssigner<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.assigners
-
A
WindowAssigner
that can merge windows. - MergingWindowAssigner() - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.MergingWindowAssigner
- MergingWindowProcessFunction<K,W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.internal
-
The implementation of
InternalWindowProcessFunction
forMergingWindowAssigner
. - MergingWindowProcessFunction(MergingWindowAssigner<W>, NamespaceAggsHandleFunctionBase<W>, TypeSerializer<W>, long) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowProcessFunction
- MergingWindowProcessFunction.DefaultAccMergingConsumer<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.internal
-
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> - Interface in org.apache.flink.table.runtime.operators.window.groupwindow.internal
- MergingWindowSet<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.internal
-
Utility for keeping track of merging
Windows
when using aMergingWindowAssigner
in aWindowOperator
. - MergingWindowSet(MergingWindowAssigner<W>, MapState<W, W>) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowSet
-
Restores a
MergingWindowSet
from the given state. - MergingWindowSet.MergeFunction<W> - Interface in org.apache.flink.table.runtime.operators.window.groupwindow.internal
-
Callback for
MergingWindowSet.addWindow(Window, MergeFunction)
. - min - Variable in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction.MinWithRetractAccumulator
- MIN_NUM_MEMORY - Static variable in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
-
The minimum number of segments that are required, 320 KibiBytes.
- MiniBatchGlobalGroupAggFunction - Class in org.apache.flink.table.runtime.operators.aggregate
-
Aggregate Function used for the global groupby (without window) aggregate in miniBatch mode.
- MiniBatchGlobalGroupAggFunction(GeneratedAggsHandleFunction, GeneratedAggsHandleFunction, GeneratedRecordEqualiser, LogicalType[], int, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.MiniBatchGlobalGroupAggFunction
-
Creates a
MiniBatchGlobalGroupAggFunction
. - MiniBatchGroupAggFunction - Class in org.apache.flink.table.runtime.operators.aggregate
-
Aggregate Function used for the groupby (without window) aggregate in miniBatch mode.
- MiniBatchGroupAggFunction(GeneratedAggsHandleFunction, GeneratedRecordEqualiser, LogicalType[], RowType, int, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.MiniBatchGroupAggFunction
-
Creates a
MiniBatchGroupAggFunction
. - MiniBatchIncrementalGroupAggFunction - Class in org.apache.flink.table.runtime.operators.aggregate
-
Aggregate Function used for the incremental groupby (without window) aggregate in miniBatch mode.
- MiniBatchIncrementalGroupAggFunction(GeneratedAggsHandleFunction, GeneratedAggsHandleFunction, KeySelector<RowData, RowData>, long) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.MiniBatchIncrementalGroupAggFunction
- MiniBatchLocalGroupAggFunction - Class in org.apache.flink.table.runtime.operators.aggregate
-
Aggregate Function used for the local groupby (without window) aggregate in miniBatch mode.
- MiniBatchLocalGroupAggFunction(GeneratedAggsHandleFunction) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.MiniBatchLocalGroupAggFunction
- MiniBatchStreamingJoinOperator - Class in org.apache.flink.table.runtime.operators.join.stream
-
Streaming unbounded Join base operator which support mini-batch join.
- MiniBatchStreamingJoinOperator(MiniBatchStreamingJoinOperator.MiniBatchStreamingJoinParameter) - Constructor for class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- minNormalizedKey(MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
- MinWithRetractAccumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction.MinWithRetractAccumulator
- MinWithRetractAggFunction<T extends Comparable<T>> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in MIN with retraction aggregate function.
- MinWithRetractAggFunction(LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction
- MinWithRetractAggFunction.MinWithRetractAccumulator<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for MIN with retraction.
- mod(DecimalData, DecimalData, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- MultiPercentileAggFunction(LogicalType, LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.MultiPercentileAggFunction
- MultipleInputStreamOperatorBase - Class in org.apache.flink.table.runtime.operators.multipleinput
-
Base
MultipleInputStreamOperator
to handle multiple inputs in table module. - MultipleInputStreamOperatorBase(StreamOperatorParameters<RowData>, List<InputSpec>, List<TableOperatorWrapper<?>>, TableOperatorWrapper<?>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.MultipleInputStreamOperatorBase
- multiply(DecimalData, DecimalData, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- MurmurHashUtil - Class in org.apache.flink.table.runtime.util
-
Murmur hasher.
- MurmurHashUtil() - Constructor for class org.apache.flink.table.runtime.util.MurmurHashUtil
N
- n - Variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
The current table size.
- name - Variable in class org.apache.flink.table.runtime.groupwindow.WindowReference
-
Deprecated.
- NamedWindowProperty - Class in org.apache.flink.table.runtime.groupwindow
-
Deprecated.The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.
- NamedWindowProperty(String, WindowProperty) - Constructor for class org.apache.flink.table.runtime.groupwindow.NamedWindowProperty
-
Deprecated.
- NamespaceAggsHandleFunction<N> - Interface in org.apache.flink.table.runtime.generated
-
The base class for handling aggregate functions with namespace.
- NamespaceAggsHandleFunctionBase<N> - Interface in org.apache.flink.table.runtime.generated
-
The base class for handling aggregate or table aggregate functions.
- NamespacedStateListView(InternalListState<?, N, T>) - Constructor for class org.apache.flink.table.runtime.dataview.StateListView.NamespacedStateListView
- NamespacedStateMapViewWithKeysNotNull(InternalMapState<?, N, EK, EV>) - Constructor for class org.apache.flink.table.runtime.dataview.StateMapView.NamespacedStateMapViewWithKeysNotNull
- NamespacedStateMapViewWithKeysNullable(InternalMapState<?, N, EK, EV>, InternalValueState<?, N, EV>) - Constructor for class org.apache.flink.table.runtime.dataview.StateMapView.NamespacedStateMapViewWithKeysNullable
- NamespaceTableAggsHandleFunction<N> - Interface in org.apache.flink.table.runtime.generated
-
The base class for handling table aggregate functions with namespace.
- needSetProbed() - Method in enum org.apache.flink.table.runtime.operators.join.HashJoinType
- needToCleanupState(Long) - Method in class org.apache.flink.table.runtime.functions.KeyedProcessFunctionWithCleanupState
- negate(DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- newBufferIterator(int) - Method in class org.apache.flink.table.runtime.operators.window.grouping.HeapWindowsGrouping
- newBufferIterator(int) - Method in class org.apache.flink.table.runtime.operators.window.grouping.WindowsGrouping
- newBuilder() - Static method in class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer
- newHashJoinOperator(HashJoinType, boolean, boolean, int, GeneratedJoinCondition, boolean, boolean[], GeneratedProjection, GeneratedProjection, boolean, int, long, long, RowType, SortMergeJoinFunction) - Static method in class org.apache.flink.table.runtime.operators.join.HashJoinOperator
- newInstance(ClassLoader) - Method in class org.apache.flink.table.runtime.generated.GeneratedClass
-
Create a new instance of this generated class.
- newInstance(ClassLoader, Object...) - Method in class org.apache.flink.table.runtime.generated.GeneratedClass
- newIterator() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
- newIterator() - Method in interface org.apache.flink.table.runtime.util.ResettableRowBuffer
-
Get a new iterator starting from first row.
- newIterator(int) - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
- newIterator(int) - Method in interface org.apache.flink.table.runtime.util.ResettableRowBuffer
-
Get a new iterator starting from the `beginRow`-th row.
- newMiniBatchStreamJoinOperator(FlinkJoinType, InternalTypeInfo<RowData>, InternalTypeInfo<RowData>, GeneratedJoinCondition, JoinInputSideSpec, JoinInputSideSpec, boolean, boolean, boolean[], long, long, CoBundleTrigger<RowData, RowData>) - Static method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- next() - Method in class org.apache.flink.table.runtime.dataview.NullAwareMapIterator
- next() - Method in class org.apache.flink.table.runtime.hashtable.ProbeIterator
- next() - Method in class org.apache.flink.table.runtime.io.BinaryRowChannelInputViewIterator
- next() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryMergeIterator
- next() - Method in class org.apache.flink.table.runtime.operators.sort.ChannelReaderKVInputViewIterator
- next() - Method in class org.apache.flink.table.runtime.util.SingleElementIterator
- next(Entry) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryMergeIterator
- next(Tuple2<K, V>) - Method in class org.apache.flink.table.runtime.operators.sort.ChannelReaderKVInputViewIterator
- next(BinaryRowData) - Method in class org.apache.flink.table.runtime.io.BinaryRowChannelInputViewIterator
- next(BinaryRowData) - Method in class org.apache.flink.table.runtime.io.LongHashPartitionChannelReaderInputViewIterator
- nextInnerJoin() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeInnerJoinIterator
- nextMatching() - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
-
Next record from rebuilt spilled partition or build side outer partition.
- nextMatching() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- nextMemorySegment() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- nextOuterJoin() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeFullOuterJoinIterator
- nextOuterJoin() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeOneSideOuterJoinIterator
- nextPowerOfTwo(long) - Static method in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Return the least power of two greater than or equal to the specified value.
- nextProbe() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- nextRecord(RowData) - Method in class org.apache.flink.table.runtime.operators.values.ValuesInputFormat
- nextSegment() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
This is the method called by the partitions to request memory to serialize records.
- nextSegment() - Method in class org.apache.flink.table.runtime.operators.aggregate.BytesHashMapSpillMemorySegmentPool
- nextSegment() - Method in class org.apache.flink.table.runtime.operators.sort.ListMemorySegmentPool
- nextSegment() - Method in class org.apache.flink.table.runtime.util.LazyMemorySegmentPool
- nextSegment(MemorySegment) - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashPartition
- nextSegment(MemorySegment) - Method in class org.apache.flink.table.runtime.hashtable.LongHashPartition
- nextSegment(MemorySegment) - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelReaderInputView
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashPartition.BuildSideBuffer
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelWriterOutputView
- nextSegment(MemorySegment, int) - Method in class org.apache.flink.table.runtime.io.HeaderlessChannelWriterOutputView
- nextSelection() - Method in class org.apache.flink.table.runtime.operators.join.HashJoinOperator
- nextSelection() - Method in class org.apache.flink.table.runtime.operators.multipleinput.BatchMultipleInputStreamOperator
- nextTriggerWindow(long, Supplier<Boolean>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- nextTriggerWindow(long, Supplier<Boolean>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- nextTriggerWindow(long, Supplier<Boolean>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.SlicedSharedSliceAssigner
- nextTriggerWindow(long, Supplier<Boolean>) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceSharedAssigner
-
Returns the optional end timestamp of next window which should be triggered.
- nextTriggerWindow(long, RowData, Function<RowData, Boolean>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
- nextTriggerWindow(long, RowData, Function<RowData, Boolean>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
- nextTriggerWindow(long, RowData, Function<RowData, Boolean>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.SlicedSharedSliceAssigner
- nextTriggerWindow(long, RowData, Function<RowData, Boolean>) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceSharedAssigner
- NO_RETRY_STRATEGY - Static variable in class org.apache.flink.table.runtime.operators.join.lookup.ResultRetryStrategy
- NonBufferOverWindowOperator - Class in org.apache.flink.table.runtime.operators.over
-
The operator for OVER window don't need cache data.
- NonBufferOverWindowOperator(StreamOperatorParameters<RowData>, GeneratedAggsHandleFunction[], GeneratedRecordComparator, boolean[]) - Constructor for class org.apache.flink.table.runtime.operators.over.NonBufferOverWindowOperator
- NonBufferOverWindowOperator(GeneratedAggsHandleFunction[], GeneratedRecordComparator, boolean[]) - Constructor for class org.apache.flink.table.runtime.operators.over.NonBufferOverWindowOperator
- NONE - org.apache.flink.table.runtime.functions.SqlJsonUtils.PathMode
- NormalizedKeyComputer - Interface in org.apache.flink.table.runtime.generated
-
Normalized key computer for
BinaryInMemorySortBuffer
. - notifyCheckpointComplete(long) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- NULL_STRING - Static variable in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- NullAwareJoinHelper - Class in org.apache.flink.table.runtime.operators.join
-
Helper for null aware join.
- NullAwareJoinHelper() - Constructor for class org.apache.flink.table.runtime.operators.join.NullAwareJoinHelper
- NullAwareMapIterator<K,V> - Class in org.apache.flink.table.runtime.dataview
-
An
Iterator
implementation that iterate on a map iterator and a null entry. - NullAwareMapIterator(Iterator<Map.Entry<K, V>>, NullAwareMapIterator.NullMapEntry<K, V>) - Constructor for class org.apache.flink.table.runtime.dataview.NullAwareMapIterator
- NullAwareMapIterator.NullMapEntry<K,V> - Interface in org.apache.flink.table.runtime.dataview
-
A Map Entry that the entry key is always null.
- nullRow - Variable in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- numBucketsMask - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- numBucketsMask2 - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- numBucketsPerSegment - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- numBucketsPerSegmentBits - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- numBucketsPerSegmentMask - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- numElements - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- numNullRowTimeRecordsDropped - Variable in class org.apache.flink.table.runtime.operators.window.tvf.operator.WindowTableFunctionOperatorBase
- numOfAssociations - Variable in class org.apache.flink.table.runtime.operators.join.stream.utils.OuterRecord
- numRecords - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- numSpillFiles - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- numSpillFiles - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
O
- ObjectArrayConverter(DataType) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.ObjectArrayConverter
- ObjectContainer - Class in org.apache.flink.table.runtime.util
-
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.
- ObjectContainer(Object, BiFunction<Object, Object, Boolean>, Function<Object, Integer>) - Constructor for class org.apache.flink.table.runtime.util.ObjectContainer
- ObjectHashSet<T> - Class in org.apache.flink.table.runtime.util.collections
-
Wrap
HashSet
with hashSet interface. - ObjectHashSet() - Constructor for class org.apache.flink.table.runtime.util.collections.ObjectHashSet
- ObjectHashSet(int) - Constructor for class org.apache.flink.table.runtime.util.collections.ObjectHashSet
- ObjectHashSet(int, float) - Constructor for class org.apache.flink.table.runtime.util.collections.ObjectHashSet
- of(boolean, boolean, boolean) - Static method in enum org.apache.flink.table.runtime.operators.join.HashJoinType
- of(boolean, boolean, boolean, boolean, boolean) - Static method in enum org.apache.flink.table.runtime.operators.join.HashJoinType
- of(int) - Static method in class org.apache.flink.table.runtime.operators.aggregate.RecordCounter
-
Creates a
RecordCounter
depends on the index of count(*). - of(int, int) - Static method in class org.apache.flink.table.runtime.typeutils.BigDecimalTypeInfo
- of(int, int) - Static method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- of(long) - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountTumblingWindowAssigner
- of(long, long) - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountSlidingWindowAssigner
- of(long, long) - Static method in class org.apache.flink.table.runtime.operators.window.TimeWindow
- of(BigDecimal) - Static method in class org.apache.flink.table.runtime.typeutils.BigDecimalTypeInfo
- of(Duration) - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.TumblingWindowAssigner
-
Creates a new
TumblingWindowAssigner
GroupWindowAssigner
that assigns elements to time windows based on the element timestamp. - of(Duration, Duration) - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
-
Creates a new
CumulativeWindowAssigner
that assigns elements to cumulative time windows based on the element timestamp. - of(Duration, Duration) - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
-
Creates a new
SlidingEventTimeWindows
WindowAssigner
that assigns elements to sliding time windows based on the element timestamp. - of(InternalTimerService<?>) - Static method in interface org.apache.flink.table.runtime.operators.window.tvf.common.ClockService
-
Creates a
ClockService
from the givenInternalTimerService
. - of(DataType) - Static method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
-
Creates an instance of a
ExternalSerializer
defined by the givenDataType
. - of(DataType) - Static method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
-
Creates type information for a
DataType
that is possibly represented by internal data structures but serialized and deserialized into external data structures. - of(DataType, boolean) - Static method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
-
Creates an instance of a
ExternalSerializer
defined by the givenDataType
. - of(DataType, boolean) - Static method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
-
Creates type information for a
DataType
that is possibly represented by internal data structures but serialized and deserialized into external data structures. - of(LogicalType) - Static method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
-
Creates type information for a
LogicalType
that is represented by internal data structures. - of(RowType) - Static method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
-
Creates type information for a
RowType
represented by internal data structures. - ofFields(LogicalType...) - Static method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
-
Creates type information for
RowType
represented by internal data structures. - ofFields(LogicalType[], String[]) - Static method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
-
Creates type information for
RowType
represented by internal data structures. - offset - Variable in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction.LagAcc
- OFFSET_LEN - Static variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- OffsetOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The offset window frame calculates frames containing LEAD/LAG statements.
- OffsetOverFrame(GeneratedAggsHandleFunction, Long, OffsetOverFrame.CalcOffsetFunc) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.OffsetOverFrame
- OffsetOverFrame.CalcOffsetFunc - Interface in org.apache.flink.table.runtime.operators.over.frame
-
Calc offset from base row.
- ofSystem() - Static method in interface org.apache.flink.table.runtime.operators.window.tvf.common.ClockService
-
Creates a
ClockService
which assigns as current processing time the result of callingSystem.currentTimeMillis()
. - onBufferEvict(int) - Method in class org.apache.flink.table.runtime.operators.window.grouping.HeapWindowsGrouping
- onBufferEvict(int) - Method in class org.apache.flink.table.runtime.operators.window.grouping.WindowsGrouping
- onCollect(T) - Method in interface org.apache.flink.table.runtime.collector.ListenableCollector.CollectListener
-
A callback method when an original record was collected, do nothing by default.
- OneInput - Class in org.apache.flink.table.runtime.operators.multipleinput.input
-
Input
forOneInputStreamOperator
. - OneInput(OneInputStreamOperator<RowData, RowData>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.input.OneInput
- OneInputStreamOperatorOutput - Class in org.apache.flink.table.runtime.operators.multipleinput.output
-
An
Output
that can be used to emit elements and other messages forOneInputStreamOperator
. - OneInputStreamOperatorOutput(OneInputStreamOperator<RowData, RowData>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.output.OneInputStreamOperatorOutput
- onElement(Object, long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.CountElement
- onElement(Object, long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.EveryElement
- onElement(Object, long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
- onElement(Object, long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowEarlyAndLate
- onElement(Object, long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowNoLate
- onElement(Object, long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindow
- onElement(Object, long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindowNoLate
- onElement(Object, long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterFirstElementPeriodic
- onElement(Object, long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger
-
Called for every element that gets added to a pane.
- onElement(T) - Method in interface org.apache.flink.table.runtime.operators.bundle.trigger.BundleTrigger
-
Called for every element that gets added to the bundle.
- onElement(T) - Method in class org.apache.flink.table.runtime.operators.bundle.trigger.CountBundleTrigger
- onElement1(IN1) - Method in interface org.apache.flink.table.runtime.operators.bundle.trigger.CoBundleTrigger
-
Called for every element that gets added to the bundle from the first input.
- onElement1(IN1) - Method in class org.apache.flink.table.runtime.operators.bundle.trigger.CountCoBundleTrigger
- onElement2(IN2) - Method in interface org.apache.flink.table.runtime.operators.bundle.trigger.CoBundleTrigger
-
Called for every element that gets added to the bundle from the second input.
- onElement2(IN2) - Method in class org.apache.flink.table.runtime.operators.bundle.trigger.CountCoBundleTrigger
- onEvent(RowData, long, WatermarkOutput) - Method in class org.apache.flink.table.runtime.generated.GeneratedWatermarkGeneratorSupplier.DefaultWatermarkGenerator
- onEventTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.CountElement
- onEventTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.EveryElement
- onEventTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
- onEventTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowEarlyAndLate
- onEventTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowNoLate
- onEventTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindow
- onEventTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindowNoLate
- onEventTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterFirstElementPeriodic
- onEventTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger
-
Called when an event-time timer that was set using the trigger context fires.
- onEventTime(InternalTimer<Object, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalProcessTimeJoinOperator
-
Invoked when an event-time timer fires.
- onEventTime(InternalTimer<Object, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalRowTimeJoinOperator
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- onEventTime(InternalTimer<RowData, Long>) - Method in class org.apache.flink.table.runtime.operators.join.window.asyncprocessing.AsyncStateWindowJoinOperator
- onEventTime(InternalTimer<RowData, Long>) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperator
- onEventTime(InternalTimer<RowData, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.sort.ProcTimeSortOperator
- onEventTime(InternalTimer<RowData, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.sort.RowTimeSortOperator
- onEventTime(InternalTimer<RowData, TimeWindow>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.UnalignedWindowTableFunctionOperator
- onMerge(W, Collection<W>) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Call
Trigger.onMerge(Window, Trigger.OnMergeContext)
on trigger. - onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.CountElement
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.EveryElement
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowEarlyAndLate
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowNoLate
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindow
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindowNoLate
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterFirstElementPeriodic
- onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger
-
Called when several windows have been merged into one window by the
WindowAssigner
. - onOperatorsFinished(OperatorsFinished, StreamGraphContext) - Method in class org.apache.flink.table.runtime.strategy.AdaptiveBroadcastJoinOptimizationStrategy
- onOperatorsFinished(OperatorsFinished, StreamGraphContext) - Method in class org.apache.flink.table.runtime.strategy.AdaptiveSkewedJoinOptimizationStrategy
- onOperatorsFinished(OperatorsFinished, StreamGraphContext) - Method in class org.apache.flink.table.runtime.strategy.PostProcessAdaptiveJoinStrategy
- onPeriodicEmit(WatermarkOutput) - Method in class org.apache.flink.table.runtime.generated.GeneratedWatermarkGeneratorSupplier.DefaultWatermarkGenerator
- onProcessingTime(long) - Method in class org.apache.flink.table.runtime.operators.wmassigners.ProcTimeMiniBatchAssignerOperator
- onProcessingTime(long) - Method in class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperator
- onProcessingTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.CountElement
- onProcessingTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.EveryElement
- onProcessingTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
- onProcessingTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowEarlyAndLate
- onProcessingTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowNoLate
- onProcessingTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindow
- onProcessingTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindowNoLate
- onProcessingTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterFirstElementPeriodic
- onProcessingTime(long, W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger
-
Called when a processing-time timer that was set using the trigger context fires.
- onProcessingTime(InternalTimer<Object, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.join.temporal.BaseTwoInputStreamOperatorWithStateRetention
-
The users of this class are not allowed to use processing time timers.
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- onProcessingTime(InternalTimer<RowData, Long>) - Method in class org.apache.flink.table.runtime.operators.join.window.asyncprocessing.AsyncStateWindowJoinOperator
- onProcessingTime(InternalTimer<RowData, Long>) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperator
- onProcessingTime(InternalTimer<RowData, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.sort.ProcTimeSortOperator
- onProcessingTime(InternalTimer<RowData, VoidNamespace>) - Method in class org.apache.flink.table.runtime.operators.sort.RowTimeSortOperator
- onProcessingTime(InternalTimer<RowData, TimeWindow>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.UnalignedWindowTableFunctionOperator
- onRemoval(Map.Entry<K, V>) - Method in interface org.apache.flink.table.runtime.util.LRUMap.RemovalListener
- onRemoval(RemovalNotification<RowData, V>) - Method in class org.apache.flink.table.runtime.operators.rank.TopNBufferCacheRemovalListener
- onTimer(long, KeyedProcessFunction.OnTimerContext, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.AbstractRowTimeUnboundedPrecedingOver
- onTimer(long, KeyedProcessFunction.OnTimerContext, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeRangeBoundedPrecedingFunction
- onTimer(long, KeyedProcessFunction.OnTimerContext, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeRowsBoundedPrecedingFunction
- onTimer(long, KeyedProcessFunction.OnTimerContext, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRangeBoundedPrecedingFunction
- onTimer(long, KeyedProcessFunction.OnTimerContext, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRowsBoundedPrecedingFunction
- open() - Method in class org.apache.flink.table.runtime.keyselector.GenericRowDataKeySelector
- open() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.LocalSlicingWindowAggOperator
- open() - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator
- open() - Method in class org.apache.flink.table.runtime.operators.bundle.AbstractMapBundleOperator
- open() - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.HashJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AsyncStateStreamingJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.stream.StreamingJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.stream.StreamingSemiAntiJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.temporal.BaseTwoInputStreamOperatorWithStateRetention
- open() - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalProcessTimeJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalRowTimeJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.window.asyncprocessing.AsyncStateWindowJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperator
- open() - Method in class org.apache.flink.table.runtime.operators.multipleinput.MultipleInputStreamOperatorBase
-
Open all sub-operators in a multiple input operator from tail to head, contrary to
StreamOperator.close()
which happens head to tail (seeMultipleInputStreamOperatorBase.close()
). - open() - Method in class org.apache.flink.table.runtime.operators.over.BufferDataOverWindowOperator
- open() - Method in class org.apache.flink.table.runtime.operators.over.NonBufferOverWindowOperator
- open() - Method in class org.apache.flink.table.runtime.operators.runtimefilter.GlobalRuntimeFilterBuilderOperator
- open() - Method in class org.apache.flink.table.runtime.operators.runtimefilter.LocalRuntimeFilterBuilderOperator
- open() - Method in class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer
- open() - Method in class org.apache.flink.table.runtime.operators.sink.OutputConversionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.sink.SinkOperator
- open() - Method in class org.apache.flink.table.runtime.operators.sink.SinkUpsertMaterializer
- open() - Method in class org.apache.flink.table.runtime.operators.sort.ProcTimeSortOperator
- open() - Method in class org.apache.flink.table.runtime.operators.sort.RankOperator
- open() - Method in class org.apache.flink.table.runtime.operators.sort.RowTimeSortOperator
- open() - Method in class org.apache.flink.table.runtime.operators.sort.SortLimitOperator
- open() - Method in class org.apache.flink.table.runtime.operators.sort.SortOperator
- open() - Method in class org.apache.flink.table.runtime.operators.sort.StreamSortOperator
- open() - Method in class org.apache.flink.table.runtime.operators.source.InputConversionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator
- open() - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- open() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.AggregateWindowOperator
- open() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- open() - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- open() - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.UnalignedWindowTableFunctionOperator
- open() - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.WindowTableFunctionOperatorBase
- open() - Method in class org.apache.flink.table.runtime.operators.wmassigners.ProcTimeMiniBatchAssignerOperator
- open() - Method in class org.apache.flink.table.runtime.operators.wmassigners.RowTimeMiniBatchAssginerOperator
- open() - Method in class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperator
- open(boolean, StreamTask<?, ?>, StreamConfig, StreamRecordCollector, long, RuntimeContext, OperatorMetricGroup) - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinFunction
- open(C) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- open(C) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowProcessor
-
Initialization method for the function.
- open(ClassLoader) - Method in class org.apache.flink.table.data.conversion.ArrayListConverter
- open(ClassLoader) - Method in class org.apache.flink.table.data.conversion.ArrayObjectArrayConverter
- open(ClassLoader) - Method in interface org.apache.flink.table.data.conversion.DataStructureConverter
- open(ClassLoader) - Method in class org.apache.flink.table.data.conversion.MapMapConverter
- open(ClassLoader) - Method in class org.apache.flink.table.data.conversion.RowRowConverter
- open(ClassLoader) - Method in class org.apache.flink.table.data.conversion.StructuredObjectConverter
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.aggregate.async.AsyncStateGroupAggFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.aggregate.GroupTableAggFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.calc.async.AsyncFunctionRunner
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.deduplicate.asyncprocessing.AsyncStateRowTimeDeduplicateFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeDeduplicateKeepLastRowFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.deduplicate.RowTimeDeduplicateFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.join.interval.IntervalJoinFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinRunner
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinWithCalcRunner
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.join.lookup.KeyedLookupJoinWrapper
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinWithCalcRunner
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.match.IterativeConditionRunner
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.match.PatternProcessFunctionRunner
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.over.AbstractRowTimeUnboundedPrecedingOver
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeRangeBoundedPrecedingFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeRowsBoundedPrecedingFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeUnboundedPrecedingFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRangeBoundedPrecedingFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRowsBoundedPrecedingFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractSyncStateTopNFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.rank.AppendOnlyFirstNFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.rank.AppendOnlyTopNFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.rank.async.AbstractAsyncStateTopNFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.rank.async.AsyncStateAppendOnlyTopNFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.rank.async.AsyncStateFastTop1Function
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.rank.FastTop1Function
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.rank.RetractableTopNFunction
- open(OpenContext) - Method in class org.apache.flink.table.runtime.operators.rank.UpdatableTopNFunction
- open(DeserializationSchema.InitializationContext) - Method in class org.apache.flink.formats.raw.RawFormatDeserializationSchema
- open(SerializationSchema.InitializationContext) - Method in class org.apache.flink.formats.raw.RawFormatSerializationSchema
- open(Configuration, ClassLoader) - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
- open(Configuration, ClassLoader) - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat.InputFormatCacheLoader
- open(GenericInputSplit) - Method in class org.apache.flink.table.runtime.operators.values.ValuesInputFormat
- open(CacheMetricGroup) - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.LookupFullCache
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.DefaultExpressionEvaluator
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayContainsFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayDistinctFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayExceptFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayIntersectFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayMaxFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayMinFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayPositionFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayRemoveFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.ArraySortFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.ArrayUnionFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.MapUnionFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.scalar.TypeOfFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.table.lookup.CachingAsyncLookupFunction
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.functions.table.lookup.CachingLookupFunction
-
Open the
CachingLookupFunction
. - open(FunctionContext) - Method in class org.apache.flink.table.runtime.operators.join.lookup.RetryableAsyncLookupFunctionDelegator
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.operators.join.lookup.RetryableLookupFunctionDelegator
- open(FunctionContext) - Method in class org.apache.flink.table.runtime.util.EqualityAndHashcodeProvider
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchGlobalGroupAggFunction
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchGroupAggFunction
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchIncrementalGroupAggFunction
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.aggregate.MiniBatchLocalGroupAggFunction
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.bundle.MapBundleFunction
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeMiniBatchDeduplicateKeepLastRowFunction
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.over.frame.InsensitiveOverFrame
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.over.frame.OffsetOverFrame
- open(ExecutionContext) - Method in interface org.apache.flink.table.runtime.operators.over.frame.OverWindowFrame
-
Open to init with
ExecutionContext
. - open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.over.frame.RangeSlidingOverFrame
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.over.frame.RangeUnboundedFollowingOverFrame
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.over.frame.RangeUnboundedPrecedingOverFrame
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.over.frame.SlidingOverFrame
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.over.frame.UnboundedFollowingOverFrame
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.over.frame.UnboundedOverWindowFrame
- open(ExecutionContext) - Method in class org.apache.flink.table.runtime.operators.over.frame.UnboundedPrecedingOverFrame
- open(StateDataViewStore) - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunctionBase
-
Initialization method for the function.
- open(StateDataViewStore) - Method in interface org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunctionBase
-
Initialization method for the function.
- open(AsyncStateWindowProcessor.AsyncStateContext<Long>) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- open(AsyncStateWindowProcessor.AsyncStateContext<W>) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateWindowAggProcessor
- open(InternalWindowProcessFunction.Context<?, CountWindow>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountSlidingWindowAssigner
- open(InternalWindowProcessFunction.Context<?, CountWindow>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountTumblingWindowAssigner
- open(InternalWindowProcessFunction.Context<?, W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.GroupWindowAssigner
-
Initialization method for the function.
- open(InternalWindowProcessFunction.Context<K, W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
-
Initialization method for the function.
- open(InternalWindowProcessFunction.Context<K, W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowProcessFunction
- open(Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.CountElement
- open(Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.EveryElement
- open(Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
- open(Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowEarlyAndLate
- open(Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowNoLate
- open(Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindow
- open(Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindowNoLate
- open(Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterFirstElementPeriodic
- open(Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger
-
Initialization method for the trigger.
- open(SyncStateWindowProcessor.SyncStateContext<Long>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- open(SyncStateWindowProcessor.SyncStateContext<Long>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.processors.RowTimeSyncStateWindowDeduplicateProcessor
- open(SyncStateWindowProcessor.SyncStateContext<Long>) - Method in class org.apache.flink.table.runtime.operators.rank.window.processors.SyncStateWindowRankProcessor
- open(SyncStateWindowProcessor.SyncStateContext<TimeWindow>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.UnsliceSyncStateWindowAggProcessor
- open(SyncStateWindowProcessor.SyncStateContext<W>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSyncStateWindowAggProcessor
- OperatorFusionCodegenFactory<OUT> - Class in org.apache.flink.table.runtime.operators.fusion
-
Stream operator factory for multiple operator fusion codegen.
- OperatorFusionCodegenFactory(GeneratedClass<? extends StreamOperator<OUT>>) - Constructor for class org.apache.flink.table.runtime.operators.fusion.OperatorFusionCodegenFactory
- OptimizableHashSet - Class in org.apache.flink.table.runtime.util.collections
-
A type-specific hash set with with a fast, small-footprint implementation.
- OptimizableHashSet(int, float) - Constructor for class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
- optimize() - Method in class org.apache.flink.table.runtime.util.collections.ByteHashSet
- optimize() - Method in class org.apache.flink.table.runtime.util.collections.DoubleHashSet
- optimize() - Method in class org.apache.flink.table.runtime.util.collections.FloatHashSet
- optimize() - Method in class org.apache.flink.table.runtime.util.collections.IntHashSet
- optimize() - Method in class org.apache.flink.table.runtime.util.collections.LongHashSet
- optimize() - Method in class org.apache.flink.table.runtime.util.collections.ObjectHashSet
- optimize() - Method in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Decide whether to convert to dense mode.
- optimize() - Method in class org.apache.flink.table.runtime.util.collections.ShortHashSet
- OPTION_SQL_FILE - Static variable in class org.apache.flink.table.runtime.application.SqlDriver
- OPTION_SQL_SCRIPT - Static variable in class org.apache.flink.table.runtime.application.SqlDriver
- optionalOptions() - Method in class org.apache.flink.formats.raw.RawFormatFactory
- orderToValueMap - Variable in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator
- orderToValueMap - Variable in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction.LastValueWithRetractAccumulator
- org.apache.flink.formats.raw - package org.apache.flink.formats.raw
- org.apache.flink.table.data - package org.apache.flink.table.data
- org.apache.flink.table.data.binary - package org.apache.flink.table.data.binary
- org.apache.flink.table.data.conversion - package org.apache.flink.table.data.conversion
- org.apache.flink.table.data.util - package org.apache.flink.table.data.util
- org.apache.flink.table.data.writer - package org.apache.flink.table.data.writer
- org.apache.flink.table.runtime.application - package org.apache.flink.table.runtime.application
- org.apache.flink.table.runtime.collector - package org.apache.flink.table.runtime.collector
- org.apache.flink.table.runtime.connector.sink - package org.apache.flink.table.runtime.connector.sink
- org.apache.flink.table.runtime.connector.source - package org.apache.flink.table.runtime.connector.source
- org.apache.flink.table.runtime.context - package org.apache.flink.table.runtime.context
- org.apache.flink.table.runtime.dataview - package org.apache.flink.table.runtime.dataview
- org.apache.flink.table.runtime.functions - package org.apache.flink.table.runtime.functions
- org.apache.flink.table.runtime.functions.aggregate - package org.apache.flink.table.runtime.functions.aggregate
- org.apache.flink.table.runtime.functions.aggregate.hyperloglog - package org.apache.flink.table.runtime.functions.aggregate.hyperloglog
- org.apache.flink.table.runtime.functions.scalar - package org.apache.flink.table.runtime.functions.scalar
- org.apache.flink.table.runtime.functions.table - package org.apache.flink.table.runtime.functions.table
- org.apache.flink.table.runtime.functions.table.lookup - package org.apache.flink.table.runtime.functions.table.lookup
- org.apache.flink.table.runtime.functions.table.lookup.fullcache - package org.apache.flink.table.runtime.functions.table.lookup.fullcache
- org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat - package org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat
- org.apache.flink.table.runtime.generated - package org.apache.flink.table.runtime.generated
- org.apache.flink.table.runtime.groupwindow - package org.apache.flink.table.runtime.groupwindow
- org.apache.flink.table.runtime.hashtable - package org.apache.flink.table.runtime.hashtable
- org.apache.flink.table.runtime.io - package org.apache.flink.table.runtime.io
- org.apache.flink.table.runtime.keyselector - package org.apache.flink.table.runtime.keyselector
- org.apache.flink.table.runtime.operators - package org.apache.flink.table.runtime.operators
- org.apache.flink.table.runtime.operators.aggregate - package org.apache.flink.table.runtime.operators.aggregate
- org.apache.flink.table.runtime.operators.aggregate.async - package org.apache.flink.table.runtime.operators.aggregate.async
- org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers - package org.apache.flink.table.runtime.operators.aggregate.asyncwindow.buffers
- org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines - package org.apache.flink.table.runtime.operators.aggregate.asyncwindow.combines
- org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors - package org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors
- org.apache.flink.table.runtime.operators.aggregate.utils - package org.apache.flink.table.runtime.operators.aggregate.utils
- org.apache.flink.table.runtime.operators.aggregate.window - package org.apache.flink.table.runtime.operators.aggregate.window
- org.apache.flink.table.runtime.operators.aggregate.window.buffers - package org.apache.flink.table.runtime.operators.aggregate.window.buffers
- org.apache.flink.table.runtime.operators.aggregate.window.combines - package org.apache.flink.table.runtime.operators.aggregate.window.combines
- org.apache.flink.table.runtime.operators.aggregate.window.processors - package org.apache.flink.table.runtime.operators.aggregate.window.processors
- org.apache.flink.table.runtime.operators.bundle - package org.apache.flink.table.runtime.operators.bundle
- org.apache.flink.table.runtime.operators.bundle.trigger - package org.apache.flink.table.runtime.operators.bundle.trigger
- org.apache.flink.table.runtime.operators.calc.async - package org.apache.flink.table.runtime.operators.calc.async
- org.apache.flink.table.runtime.operators.deduplicate - package org.apache.flink.table.runtime.operators.deduplicate
- org.apache.flink.table.runtime.operators.deduplicate.asyncprocessing - package org.apache.flink.table.runtime.operators.deduplicate.asyncprocessing
- org.apache.flink.table.runtime.operators.deduplicate.utils - package org.apache.flink.table.runtime.operators.deduplicate.utils
- org.apache.flink.table.runtime.operators.deduplicate.window - package org.apache.flink.table.runtime.operators.deduplicate.window
- org.apache.flink.table.runtime.operators.deduplicate.window.combines - package org.apache.flink.table.runtime.operators.deduplicate.window.combines
- org.apache.flink.table.runtime.operators.deduplicate.window.processors - package org.apache.flink.table.runtime.operators.deduplicate.window.processors
- org.apache.flink.table.runtime.operators.dynamicfiltering - package org.apache.flink.table.runtime.operators.dynamicfiltering
- org.apache.flink.table.runtime.operators.fusion - package org.apache.flink.table.runtime.operators.fusion
- org.apache.flink.table.runtime.operators.join - package org.apache.flink.table.runtime.operators.join
- org.apache.flink.table.runtime.operators.join.adaptive - package org.apache.flink.table.runtime.operators.join.adaptive
- org.apache.flink.table.runtime.operators.join.interval - package org.apache.flink.table.runtime.operators.join.interval
- org.apache.flink.table.runtime.operators.join.lookup - package org.apache.flink.table.runtime.operators.join.lookup
- org.apache.flink.table.runtime.operators.join.stream - package org.apache.flink.table.runtime.operators.join.stream
- org.apache.flink.table.runtime.operators.join.stream.asyncprocessing - package org.apache.flink.table.runtime.operators.join.stream.asyncprocessing
- org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state - package org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state
- org.apache.flink.table.runtime.operators.join.stream.bundle - package org.apache.flink.table.runtime.operators.join.stream.bundle
- org.apache.flink.table.runtime.operators.join.stream.state - package org.apache.flink.table.runtime.operators.join.stream.state
- org.apache.flink.table.runtime.operators.join.stream.utils - package org.apache.flink.table.runtime.operators.join.stream.utils
- org.apache.flink.table.runtime.operators.join.temporal - package org.apache.flink.table.runtime.operators.join.temporal
- org.apache.flink.table.runtime.operators.join.window - package org.apache.flink.table.runtime.operators.join.window
- org.apache.flink.table.runtime.operators.join.window.asyncprocessing - package org.apache.flink.table.runtime.operators.join.window.asyncprocessing
- org.apache.flink.table.runtime.operators.join.window.utils - package org.apache.flink.table.runtime.operators.join.window.utils
- org.apache.flink.table.runtime.operators.match - package org.apache.flink.table.runtime.operators.match
- org.apache.flink.table.runtime.operators.metrics - package org.apache.flink.table.runtime.operators.metrics
- org.apache.flink.table.runtime.operators.misc - package org.apache.flink.table.runtime.operators.misc
- org.apache.flink.table.runtime.operators.multipleinput - package org.apache.flink.table.runtime.operators.multipleinput
- org.apache.flink.table.runtime.operators.multipleinput.input - package org.apache.flink.table.runtime.operators.multipleinput.input
- org.apache.flink.table.runtime.operators.multipleinput.output - package org.apache.flink.table.runtime.operators.multipleinput.output
- org.apache.flink.table.runtime.operators.over - package org.apache.flink.table.runtime.operators.over
- org.apache.flink.table.runtime.operators.over.frame - package org.apache.flink.table.runtime.operators.over.frame
- org.apache.flink.table.runtime.operators.rank - package org.apache.flink.table.runtime.operators.rank
- org.apache.flink.table.runtime.operators.rank.async - package org.apache.flink.table.runtime.operators.rank.async
- org.apache.flink.table.runtime.operators.rank.utils - package org.apache.flink.table.runtime.operators.rank.utils
- org.apache.flink.table.runtime.operators.rank.window - package org.apache.flink.table.runtime.operators.rank.window
- org.apache.flink.table.runtime.operators.rank.window.combines - package org.apache.flink.table.runtime.operators.rank.window.combines
- org.apache.flink.table.runtime.operators.rank.window.processors - package org.apache.flink.table.runtime.operators.rank.window.processors
- org.apache.flink.table.runtime.operators.runtimefilter - package org.apache.flink.table.runtime.operators.runtimefilter
- org.apache.flink.table.runtime.operators.runtimefilter.util - package org.apache.flink.table.runtime.operators.runtimefilter.util
- org.apache.flink.table.runtime.operators.sink - package org.apache.flink.table.runtime.operators.sink
- org.apache.flink.table.runtime.operators.sort - package org.apache.flink.table.runtime.operators.sort
- org.apache.flink.table.runtime.operators.source - package org.apache.flink.table.runtime.operators.source
- org.apache.flink.table.runtime.operators.values - package org.apache.flink.table.runtime.operators.values
- org.apache.flink.table.runtime.operators.window - package org.apache.flink.table.runtime.operators.window
- org.apache.flink.table.runtime.operators.window.async - package org.apache.flink.table.runtime.operators.window.async
- org.apache.flink.table.runtime.operators.window.async.tvf.combines - package org.apache.flink.table.runtime.operators.window.async.tvf.combines
- org.apache.flink.table.runtime.operators.window.async.tvf.common - package org.apache.flink.table.runtime.operators.window.async.tvf.common
- org.apache.flink.table.runtime.operators.window.async.tvf.slicing - package org.apache.flink.table.runtime.operators.window.async.tvf.slicing
- org.apache.flink.table.runtime.operators.window.async.tvf.state - package org.apache.flink.table.runtime.operators.window.async.tvf.state
- org.apache.flink.table.runtime.operators.window.grouping - package org.apache.flink.table.runtime.operators.window.grouping
- org.apache.flink.table.runtime.operators.window.groupwindow.assigners - package org.apache.flink.table.runtime.operators.window.groupwindow.assigners
- org.apache.flink.table.runtime.operators.window.groupwindow.internal - package org.apache.flink.table.runtime.operators.window.groupwindow.internal
- org.apache.flink.table.runtime.operators.window.groupwindow.operator - package org.apache.flink.table.runtime.operators.window.groupwindow.operator
- org.apache.flink.table.runtime.operators.window.groupwindow.triggers - package org.apache.flink.table.runtime.operators.window.groupwindow.triggers
- org.apache.flink.table.runtime.operators.window.tvf.asyncprocessing.state - package org.apache.flink.table.runtime.operators.window.tvf.asyncprocessing.state
- org.apache.flink.table.runtime.operators.window.tvf.combines - package org.apache.flink.table.runtime.operators.window.tvf.combines
- org.apache.flink.table.runtime.operators.window.tvf.common - package org.apache.flink.table.runtime.operators.window.tvf.common
- org.apache.flink.table.runtime.operators.window.tvf.operator - package org.apache.flink.table.runtime.operators.window.tvf.operator
- org.apache.flink.table.runtime.operators.window.tvf.slicing - package org.apache.flink.table.runtime.operators.window.tvf.slicing
- org.apache.flink.table.runtime.operators.window.tvf.state - package org.apache.flink.table.runtime.operators.window.tvf.state
- org.apache.flink.table.runtime.operators.window.tvf.unslicing - package org.apache.flink.table.runtime.operators.window.tvf.unslicing
- org.apache.flink.table.runtime.operators.wmassigners - package org.apache.flink.table.runtime.operators.wmassigners
- org.apache.flink.table.runtime.partitioner - package org.apache.flink.table.runtime.partitioner
- org.apache.flink.table.runtime.script - package org.apache.flink.table.runtime.script
- org.apache.flink.table.runtime.strategy - package org.apache.flink.table.runtime.strategy
- org.apache.flink.table.runtime.types - package org.apache.flink.table.runtime.types
- org.apache.flink.table.runtime.typeutils - package org.apache.flink.table.runtime.typeutils
- org.apache.flink.table.runtime.util - package org.apache.flink.table.runtime.util
- org.apache.flink.table.runtime.util.collections - package org.apache.flink.table.runtime.util.collections
- org.apache.flink.table.runtime.util.collections.binary - package org.apache.flink.table.runtime.util.collections.binary
- OuterJoinPaddingUtil - Class in org.apache.flink.table.runtime.operators.join
-
An utility to generate reusable padding results for outer joins.
- OuterJoinPaddingUtil(int, int) - Constructor for class org.apache.flink.table.runtime.operators.join.OuterJoinPaddingUtil
- OuterJoinRecordAsyncStateView - Interface in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state
-
A
OuterJoinRecordAsyncStateView
is an extension toJoinRecordAsyncStateView
. - OuterJoinRecordAsyncStateViews - Class in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state
-
Utility to create a
OuterJoinRecordAsyncStateViews
depends onJoinInputSideSpec
. - OuterJoinRecordAsyncStateViews() - Constructor for class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.OuterJoinRecordAsyncStateViews
- OuterJoinRecordStateView - Interface in org.apache.flink.table.runtime.operators.join.stream.state
-
A
OuterJoinRecordStateView
is an extension toJoinRecordStateView
. - OuterJoinRecordStateViews - Class in org.apache.flink.table.runtime.operators.join.stream.state
-
Utility to create a
OuterJoinRecordStateViews
depends onJoinInputSideSpec
. - OuterJoinRecordStateViews() - Constructor for class org.apache.flink.table.runtime.operators.join.stream.state.OuterJoinRecordStateViews
- OuterRecord - Class in org.apache.flink.table.runtime.operators.join.stream.utils
-
An
OuterRecord
is a composite of record andnumOfAssociations
. - OuterRecord(RowData) - Constructor for class org.apache.flink.table.runtime.operators.join.stream.utils.OuterRecord
- OuterRecord(RowData, int) - Constructor for class org.apache.flink.table.runtime.operators.join.stream.utils.OuterRecord
- output - Variable in class org.apache.flink.table.runtime.operators.over.AbstractRowTimeUnboundedPrecedingOver
- output(RowData) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowProcessor.Context
-
Outputs results to downstream operators.
- OutputBase - Class in org.apache.flink.table.runtime.operators.multipleinput.output
-
Base
Output
that can be used to emit elements and other messages inMultipleInputStreamOperatorBase
. - OutputBase(StreamOperator<?>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.output.OutputBase
- OutputConversionOperator - Class in org.apache.flink.table.runtime.operators.sink
-
Operator that converts to external data structures and unwraps atomic records if necessary.
- OutputConversionOperator(RowData.FieldGetter, DynamicTableSink.DataStructureConverter, int, boolean) - Constructor for class org.apache.flink.table.runtime.operators.sink.OutputConversionOperator
- outputRankNumber - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- outputRankNumber - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- outputRankNumber(boolean) - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- outputResult(Object) - Method in class org.apache.flink.table.runtime.collector.TableFunctionCollector
-
Output final result of this UDTF to downstreams.
- outputResult(T) - Method in class org.apache.flink.table.runtime.collector.WrappingCollector
-
Outputs the final result to the wrapped collector.
- outputs - Variable in class org.apache.flink.table.runtime.operators.multipleinput.output.BroadcastingOutput
- outRow - Variable in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- OVER_MAX_ROW_COUNT - Static variable in class org.apache.flink.table.runtime.operators.runtimefilter.util.RuntimeFilterUtils
- overlay(String, String, long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- overlay(String, String, long, long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- OverWindowFrame - Interface in org.apache.flink.table.runtime.operators.over.frame
-
A window frame calculates the results for those records belong to a window frame.
P
- PaddingLeftMapFunction - Class in org.apache.flink.table.runtime.operators.join.interval
-
Function performing left padding.
- PaddingLeftMapFunction(OuterJoinPaddingUtil, InternalTypeInfo<RowData>) - Constructor for class org.apache.flink.table.runtime.operators.join.interval.PaddingLeftMapFunction
- PaddingRightMapFunction - Class in org.apache.flink.table.runtime.operators.join.interval
-
Function performing right padding.
- PaddingRightMapFunction(OuterJoinPaddingUtil, InternalTypeInfo<RowData>) - Constructor for class org.apache.flink.table.runtime.operators.join.interval.PaddingRightMapFunction
- padLeft(RowData) - Method in class org.apache.flink.table.runtime.operators.join.OuterJoinPaddingUtil
-
Returns a padding result with the given left row.
- padNullForLeftJoin(RowData, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- padRight(RowData) - Method in class org.apache.flink.table.runtime.operators.join.OuterJoinPaddingUtil
-
Returns a padding result with the given right row.
- PagedTypeSerializer<T> - Class in org.apache.flink.table.runtime.typeutils
-
A type serializer which provides paged serialize and deserialize methods.
- PagedTypeSerializer() - Constructor for class org.apache.flink.table.runtime.typeutils.PagedTypeSerializer
- pageSize - Variable in class org.apache.flink.table.runtime.operators.sort.AbstractBinaryExternalMerger
- pageSize() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- pageSize() - Method in class org.apache.flink.table.runtime.operators.aggregate.BytesHashMapSpillMemorySegmentPool
- pageSize() - Method in class org.apache.flink.table.runtime.operators.sort.ListMemorySegmentPool
- pageSize() - Method in class org.apache.flink.table.runtime.util.LazyMemorySegmentPool
- pageSize() - Method in interface org.apache.flink.table.runtime.util.MemorySegmentPool
-
Get the page size of each page this pool holds.
- PanedWindowAssigner<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.assigners
-
A
WindowAssigner
that window can be split into panes. - PanedWindowAssigner() - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.PanedWindowAssigner
- PanedWindowProcessFunction<K,W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.internal
-
The implementation of
InternalWindowProcessFunction
forPanedWindowAssigner
. - PanedWindowProcessFunction(PanedWindowAssigner<W>, NamespaceAggsHandleFunctionBase<W>, long) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.internal.PanedWindowProcessFunction
- parameters - Variable in class org.apache.flink.table.runtime.operators.fusion.FusionStreamOperatorBase
- parseOptions(String[]) - Static method in class org.apache.flink.table.runtime.application.SqlDriver
- parseUrl(String, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Parse url and return various components of the URL.
- parseUrl(String, String, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Parse url and return various parameter of the URL.
- PatternProcessFunctionRunner - Class in org.apache.flink.table.runtime.operators.match
-
A
PatternProcessFunction
wrapper to delegate invocation to the code generatedPatternProcessFunction
. - PatternProcessFunctionRunner(GeneratedFunction<PatternProcessFunction<RowData, RowData>>) - Constructor for class org.apache.flink.table.runtime.operators.match.PatternProcessFunctionRunner
- percentages - Variable in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.PercentileAccumulator
- PercentileAccumulator() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.PercentileAccumulator
- PercentileAggFunction<T> - Class in org.apache.flink.table.runtime.functions.aggregate
-
Built-in PERCENTILE aggregate function.
- PercentileAggFunction(LogicalType, LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- PercentileAggFunction.MultiPercentileAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Percentile agg function with multiple percentage parameters.
- PercentileAggFunction.PercentileAccumulator - Class in org.apache.flink.table.runtime.functions.aggregate
-
Accumulator for PERCENTILE.
- PercentileAggFunction.SinglePercentileAggFunction - Class in org.apache.flink.table.runtime.functions.aggregate
-
Percentile agg function with only one percentage parameter.
- PeriodicWatermarkAssignerWrapper - Class in org.apache.flink.table.runtime.operators.wmassigners
-
Generates periodic watermarks based on a
PeriodicWatermarkAssigner
. - PeriodicWatermarkAssignerWrapper(PeriodicWatermarkAssigner, int) - Constructor for class org.apache.flink.table.runtime.operators.wmassigners.PeriodicWatermarkAssignerWrapper
- PerKeyStateDataViewStore - Class in org.apache.flink.table.runtime.dataview
-
Default implementation of
StateDataViewStore
that currently forwards state registration to aRuntimeContext
. - PerKeyStateDataViewStore(RuntimeContext) - Constructor for class org.apache.flink.table.runtime.dataview.PerKeyStateDataViewStore
- PerKeyStateDataViewStore(RuntimeContext, StateTtlConfig) - Constructor for class org.apache.flink.table.runtime.dataview.PerKeyStateDataViewStore
- PerWindowStateDataViewStore - Class in org.apache.flink.table.runtime.dataview
-
An implementation of
StateDataViewStore
for window aggregates which forwards the state registration to an underlyingKeyedStateBackend
. - PerWindowStateDataViewStore(KeyedStateBackend<?>, TypeSerializer<?>, RuntimeContext) - Constructor for class org.apache.flink.table.runtime.dataview.PerWindowStateDataViewStore
- PlannerTypeUtils - Class in org.apache.flink.table.runtime.types
-
Utilities for
LogicalType
andDataType
.. - PlannerTypeUtils() - Constructor for class org.apache.flink.table.runtime.types.PlannerTypeUtils
- pointTo(int, BinaryRowData, AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
-
Point row to memory segments with offset(in the AbstractPagedInputView) and length.
- PojoConverter(PojoTypeInfo<T>, DataType[]) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.PojoConverter
- position(BinaryStringData, BinaryStringData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- position(BinaryStringData, BinaryStringData, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- PostProcessAdaptiveJoinStrategy - Class in org.apache.flink.table.runtime.strategy
-
The post-processing phase of adaptive join optimization, which must be placed at the end of all adaptive join optimization strategies.
- PostProcessAdaptiveJoinStrategy() - Constructor for class org.apache.flink.table.runtime.strategy.PostProcessAdaptiveJoinStrategy
- power(double, DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- power(DecimalData, double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- power(DecimalData, DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- power10(int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- precision() - Method in class org.apache.flink.table.runtime.typeutils.BigDecimalTypeInfo
- precision() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- preferCustomShuffle() - Method in class org.apache.flink.table.runtime.connector.source.LookupRuntimeProviderContext
- preFilter(RowData) - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- preFilterCondition - Variable in class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinRunner
- preFilterCondition - Variable in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- prepare(ResettableExternalBuffer) - Method in class org.apache.flink.table.runtime.operators.over.frame.InsensitiveOverFrame
- prepare(ResettableExternalBuffer) - Method in class org.apache.flink.table.runtime.operators.over.frame.OffsetOverFrame
- prepare(ResettableExternalBuffer) - Method in interface org.apache.flink.table.runtime.operators.over.frame.OverWindowFrame
-
Prepare for next partition.
- prepare(ResettableExternalBuffer) - Method in class org.apache.flink.table.runtime.operators.over.frame.RowSlidingOverFrame
- prepare(ResettableExternalBuffer) - Method in class org.apache.flink.table.runtime.operators.over.frame.RowUnboundedPrecedingOverFrame
- prepare(ResettableExternalBuffer) - Method in class org.apache.flink.table.runtime.operators.over.frame.SlidingOverFrame
- prepare(ResettableExternalBuffer) - Method in class org.apache.flink.table.runtime.operators.over.frame.UnboundedFollowingOverFrame
- prepare(ResettableExternalBuffer) - Method in class org.apache.flink.table.runtime.operators.over.frame.UnboundedOverWindowFrame
- prepare(ResettableExternalBuffer) - Method in class org.apache.flink.table.runtime.operators.over.frame.UnboundedPrecedingOverFrame
- prepareAggregateAccumulatorForEmit(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.GeneralWindowProcessFunction
- prepareAggregateAccumulatorForEmit(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
-
Prepares the accumulator of the given window before emit the final result.
- prepareAggregateAccumulatorForEmit(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowProcessFunction
- prepareAggregateAccumulatorForEmit(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.PanedWindowProcessFunction
- prepareAggregator() - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateWindowAggProcessor
- prepareAggregator() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSyncStateWindowAggProcessor
- prepareAggregator() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- prepareCheckpoint() - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- prepareCheckpoint() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- prepareCheckpoint() - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.UnsliceSyncStateWindowAggProcessor
- prepareCheckpoint() - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.processors.RowTimeSyncStateWindowDeduplicateProcessor
- prepareCheckpoint() - Method in class org.apache.flink.table.runtime.operators.rank.window.processors.SyncStateWindowRankProcessor
- prepareCheckpoint() - Method in interface org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowProcessor
-
Performs a preparation before checkpoint.
- prepareCheckpoint() - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.SyncStateWindowProcessor
-
Performs a preparation before checkpoint.
- prepareCollector(RowData, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.LocalSlicingWindowAggOperator
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.table.runtime.operators.bundle.AbstractMapBundleOperator
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- prepareSnapshotPreBarrier(long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- preProcessWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator
- preProcessWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- previousState - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- PrintfFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.PRINTF
. - PrintfFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.PrintfFunction
- PROBE_OUTER - org.apache.flink.table.runtime.operators.join.HashJoinType
- ProbeIterator - Class in org.apache.flink.table.runtime.hashtable
-
Probe iterator from probe or spilled partition.
- ProbeIterator(BinaryRowData) - Constructor for class org.apache.flink.table.runtime.hashtable.ProbeIterator
- probeKey - Variable in class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- probeToBinary(RowData) - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
-
For code gen probe side to BinaryRowData.
- process(int, RowData) - Method in class org.apache.flink.table.runtime.operators.over.frame.InsensitiveOverFrame
- process(int, RowData) - Method in class org.apache.flink.table.runtime.operators.over.frame.OffsetOverFrame
- process(int, RowData) - Method in interface org.apache.flink.table.runtime.operators.over.frame.OverWindowFrame
-
return the ACC of the window frame.
- process(int, RowData) - Method in class org.apache.flink.table.runtime.operators.over.frame.RangeSlidingOverFrame
- process(int, RowData) - Method in class org.apache.flink.table.runtime.operators.over.frame.RangeUnboundedFollowingOverFrame
- process(int, RowData) - Method in class org.apache.flink.table.runtime.operators.over.frame.RangeUnboundedPrecedingOverFrame
- process(int, RowData) - Method in class org.apache.flink.table.runtime.operators.over.frame.RowSlidingOverFrame
- process(int, RowData) - Method in class org.apache.flink.table.runtime.operators.over.frame.RowUnboundedFollowingOverFrame
- process(int, RowData) - Method in class org.apache.flink.table.runtime.operators.over.frame.RowUnboundedPrecedingOverFrame
- process(int, RowData) - Method in class org.apache.flink.table.runtime.operators.over.frame.UnboundedOverWindowFrame
- processAsFirstRow(RowData, RowData, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.utils.FastTop1Helper
- processBundles(BufferBundle<?>, BufferBundle<?>) - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- processElement(StreamRecord<E>) - Method in class org.apache.flink.table.runtime.operators.source.InputConversionOperator
- processElement(StreamRecord<IN>) - Method in class org.apache.flink.table.runtime.operators.bundle.AbstractMapBundleOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.LocalSlicingWindowAggOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.FirstInputOfTwoInput
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.OneInput
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.SecondInputOfTwoInput
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.BufferDataOverWindowOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.NonBufferOverWindowOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.runtimefilter.GlobalRuntimeFilterBuilderOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.runtimefilter.LocalRuntimeFilterBuilderOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sink.ConstraintEnforcer
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sink.OutputConversionOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sink.RowKindSetter
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sink.SinkOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sink.SinkUpsertMaterializer
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sink.StreamRecordTimestampInserter
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sort.LimitOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sort.ProcTimeSortOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sort.RankOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sort.RowTimeSortOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sort.SortLimitOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sort.SortOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.sort.StreamSortOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.AlignedWindowTableFunctionOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.operator.UnalignedWindowTableFunctionOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.wmassigners.ProcTimeMiniBatchAssignerOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.wmassigners.RowTimeMiniBatchAssginerOperator
- processElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperator
- processElement(StreamRecord<RowData>, int, Meter, BiConsumerWithException<Long, RowData, Exception>) - Method in class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.AbstractRowTimeUnboundedPrecedingOver
-
Puts an element from the input stream into state if it is not late.
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeRangeBoundedPrecedingFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeRowsBoundedPrecedingFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.ProcTimeUnboundedPrecedingFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRangeBoundedPrecedingFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRowsBoundedPrecedingFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.async.AsyncStateGroupAggFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.GroupTableAggFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.asyncprocessing.AsyncStateRowTimeDeduplicateFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeDeduplicateKeepFirstRowFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeDeduplicateKeepLastRowFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.deduplicate.RowTimeDeduplicateFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.lookup.KeyedLookupJoinWrapper
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.AppendOnlyFirstNFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.AppendOnlyTopNFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.async.AsyncStateAppendOnlyTopNFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.async.AsyncStateFastTop1Function
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.FastTop1Function
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.RetractableTopNFunction
- processElement(RowData, KeyedProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.UpdatableTopNFunction
- processElement(RowData, ProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- processElement(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- processElement(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- processElement(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.UnsliceSyncStateWindowAggProcessor
- processElement(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.processors.RowTimeSyncStateWindowDeduplicateProcessor
- processElement(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.window.processors.SyncStateWindowRankProcessor
- processElement(RowData, RowData) - Method in interface org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowProcessor
-
Process an element with associated key from the input stream.
- processElement(RowData, RowData) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.SyncStateWindowProcessor
-
Process an element with associated key from the input stream.
- processElement(RowData, RowData, RowData, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.aggregate.utils.GroupAggHelper
- processElement(RowData, JoinRecordStateView, JoinRecordStateView, boolean, boolean) - Method in class org.apache.flink.table.runtime.operators.join.stream.StreamingJoinOperator
- processElement1(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.HashJoinOperator
- processElement1(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinOperator
- processElement1(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AsyncStateStreamingJoinOperator
- processElement1(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- processElement1(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.stream.StreamingJoinOperator
- processElement1(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.stream.StreamingSemiAntiJoinOperator
-
Process an input element and output incremental joined records, retraction messages will be sent in some scenarios.
- processElement1(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalProcessTimeJoinOperator
- processElement1(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalRowTimeJoinOperator
- processElement1(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.window.asyncprocessing.AsyncStateWindowJoinOperator
- processElement1(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperator
- processElement1(RowData) - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinFunction
- processElement2(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.HashJoinOperator
- processElement2(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinOperator
- processElement2(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AsyncStateStreamingJoinOperator
- processElement2(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- processElement2(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.stream.StreamingJoinOperator
- processElement2(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.stream.StreamingSemiAntiJoinOperator
-
Process an input element and output incremental joined records, retraction messages will be sent in some scenarios.
- processElement2(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalProcessTimeJoinOperator
- processElement2(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.temporal.TemporalRowTimeJoinOperator
- processElement2(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.window.asyncprocessing.AsyncStateWindowJoinOperator
- processElement2(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperator
- processElement2(RowData) - Method in class org.apache.flink.table.runtime.operators.join.SortMergeJoinFunction
- processElementsWithSameTimestamp(List<RowData>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.AbstractRowTimeUnboundedPrecedingOver
-
Process the same timestamp datas, the mechanism is different between rows and range window.
- processElementsWithSameTimestamp(List<RowData>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRangeUnboundedPrecedingFunction
- processElementsWithSameTimestamp(List<RowData>, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.over.RowTimeRowsUnboundedPrecedingFunction
- processElementWithoutRowNumber(TopNBuffer, RowData, long, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.utils.AppendOnlyTopNHelper
- processElementWithRowNumber(TopNBuffer, RowData, RowData, long, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.utils.AppendOnlyTopNHelper
-
The without-number-algorithm can't handle topN with offset, so use the with-number-algorithm to handle offset.
- processFirstRowOnProcTime(RowData, ValueState<Boolean>, Collector<RowData>) - Static method in class org.apache.flink.table.runtime.operators.deduplicate.utils.DeduplicateFunctionHelper
-
Processes element to deduplicate on keys with process time semantic, sends current element if it is first row.
- ProcessingTimeTriggers - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A
Trigger
that reacts to processing-time timers. - ProcessingTimeTriggers.AfterEndOfWindow<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
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> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A composite
Trigger
that consist of AfterEndOfWindow and a early trigger. - ProcessingTimeTriggers.AfterFirstElementPeriodic<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
Trigger every a given interval, the first trigger time is interval after the first element in the pane.
- processJoin(RowData, STATE_VIEW, STATE_VIEW, boolean, AssociatedRecords, boolean) - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinHelper
-
Process an input element and output incremental joined records, retraction messages will be sent in some scenarios.
- processLastRowOnChangelog(RowData, boolean, ValueState<RowData>, Collector<RowData>, boolean, RecordEqualiser) - Static method in class org.apache.flink.table.runtime.operators.deduplicate.utils.DeduplicateFunctionHelper
-
Processes element to deduplicate on keys, sends current element as last row, retracts previous element if needed.
- processLastRowOnProcTime(RowData, boolean, boolean, ValueState<RowData>, Collector<RowData>, boolean, RecordEqualiser) - Static method in class org.apache.flink.table.runtime.operators.deduplicate.utils.DeduplicateFunctionHelper
-
Processes element to deduplicate on keys with process time semantic, sends current element as last row, retracts previous element if needed.
- processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.FirstInputOfTwoInput
- processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.OneInput
- processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.SecondInputOfTwoInput
- processMatch(Map<String, List<RowData>>, PatternProcessFunction.Context, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.match.PatternProcessFunctionRunner
- processSingleSideBundles(BufferBundle<?>, JoinRecordStateView, JoinRecordStateView, boolean) - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
-
RetractMsg+accumulatingMsg would be optimized which would keep sending retractMsg but do not deal with state.
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.LocalSlicingWindowAggOperator
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.bundle.AbstractMapBundleOperator
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.join.KeyedCoProcessOperatorWithWatermarkDelay
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.FirstInputOfTwoInput
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.OneInput
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.SecondInputOfTwoInput
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.sink.SinkOperator
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.source.InputConversionOperator
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.wmassigners.ProcTimeMiniBatchAssignerOperator
-
Override the base implementation to completely ignore watermarks propagated from upstream (we rely only on the
WatermarkStrategyWithPeriodicWatermarks
to emit watermarks from here). - processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.wmassigners.RowTimeMiniBatchAssginerOperator
- processWatermark(Watermark) - Method in class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperator
-
Override the base implementation to completely ignore watermarks propagated from upstream (we rely only on the
WatermarkGenerator
to emit watermarks from here). - processWatermark1(Watermark) - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- processWatermark2(Watermark) - Method in class org.apache.flink.table.runtime.operators.join.stream.MiniBatchStreamingJoinOperator
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.FirstInputOfTwoInput
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.OneInput
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.SecondInputOfTwoInput
- processWatermarkStatus(WatermarkStatus) - Method in class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperator
- processWithPrevRow(RowData, RowData, RowData, Collector<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.utils.FastTop1Helper
- ProctimeAttribute - Class in org.apache.flink.table.runtime.groupwindow
-
Deprecated.The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.
- ProctimeAttribute(WindowReference) - Constructor for class org.apache.flink.table.runtime.groupwindow.ProctimeAttribute
-
Deprecated.
- ProcTimeDeduplicateKeepFirstRowFunction - Class in org.apache.flink.table.runtime.operators.deduplicate
-
This function is used to deduplicate on keys and keeps only first row.
- ProcTimeDeduplicateKeepFirstRowFunction(long) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeDeduplicateKeepFirstRowFunction
- ProcTimeDeduplicateKeepLastRowFunction - Class in org.apache.flink.table.runtime.operators.deduplicate
-
This function is used to deduplicate on keys and keeps only last row.
- ProcTimeDeduplicateKeepLastRowFunction(InternalTypeInfo<RowData>, long, boolean, boolean, boolean, GeneratedRecordEqualiser) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeDeduplicateKeepLastRowFunction
- ProcTimeIntervalJoin - Class in org.apache.flink.table.runtime.operators.join.interval
-
The function to execute processing time interval stream inner-join.
- ProcTimeIntervalJoin(FlinkJoinType, long, long, long, InternalTypeInfo<RowData>, InternalTypeInfo<RowData>, IntervalJoinFunction) - Constructor for class org.apache.flink.table.runtime.operators.join.interval.ProcTimeIntervalJoin
- ProcTimeMiniBatchAssignerOperator - Class in org.apache.flink.table.runtime.operators.wmassigners
-
A stream operator that emits mini-batch marker in a given period.
- ProcTimeMiniBatchAssignerOperator(long) - Constructor for class org.apache.flink.table.runtime.operators.wmassigners.ProcTimeMiniBatchAssignerOperator
- ProcTimeMiniBatchDeduplicateKeepFirstRowFunction - Class in org.apache.flink.table.runtime.operators.deduplicate
-
This function is used to get the first row for every key partition in miniBatch mode.
- ProcTimeMiniBatchDeduplicateKeepFirstRowFunction(TypeSerializer<RowData>, long) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeMiniBatchDeduplicateKeepFirstRowFunction
- ProcTimeMiniBatchDeduplicateKeepLastRowFunction - Class in org.apache.flink.table.runtime.operators.deduplicate
-
This function is used to get the last row for every key partition in miniBatch mode.
- ProcTimeMiniBatchDeduplicateKeepLastRowFunction(InternalTypeInfo<RowData>, TypeSerializer<RowData>, long, boolean, boolean, boolean, GeneratedRecordEqualiser) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.ProcTimeMiniBatchDeduplicateKeepLastRowFunction
- ProcTimeRangeBoundedPrecedingFunction<K> - Class in org.apache.flink.table.runtime.operators.over
-
Process Function used for the aggregate in bounded proc-time OVER window.
- ProcTimeRangeBoundedPrecedingFunction(GeneratedAggsHandleFunction, LogicalType[], LogicalType[], long) - Constructor for class org.apache.flink.table.runtime.operators.over.ProcTimeRangeBoundedPrecedingFunction
- ProcTimeRowsBoundedPrecedingFunction<K> - Class in org.apache.flink.table.runtime.operators.over
-
Process Function for ROW clause processing-time bounded OVER window.
- ProcTimeRowsBoundedPrecedingFunction(long, long, GeneratedAggsHandleFunction, LogicalType[], LogicalType[], long) - Constructor for class org.apache.flink.table.runtime.operators.over.ProcTimeRowsBoundedPrecedingFunction
- ProcTimeSortOperator - Class in org.apache.flink.table.runtime.operators.sort
-
Sort on proc-time and additional secondary sort attributes.
- ProcTimeSortOperator(InternalTypeInfo<RowData>, GeneratedRecordComparator) - Constructor for class org.apache.flink.table.runtime.operators.sort.ProcTimeSortOperator
- ProcTimeUnboundedPrecedingFunction<K> - Class in org.apache.flink.table.runtime.operators.over
-
Process Function for processing-time unbounded OVER window.
- ProcTimeUnboundedPrecedingFunction(StateTtlConfig, GeneratedAggsHandleFunction, LogicalType[]) - Constructor for class org.apache.flink.table.runtime.operators.over.ProcTimeUnboundedPrecedingFunction
- produceUpdates - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- produceUpdates - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- produceUpdates() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- Projection<IN extends org.apache.flink.table.data.RowData,OUT extends org.apache.flink.table.data.RowData> - Interface in org.apache.flink.table.runtime.generated
-
Interface for code generated projection, which will map a RowData to another one.
- Provider(OperatorID, List<String>) - Constructor for class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator.Provider
- PunctuatedWatermarkStrategyWrapper - Class in org.apache.flink.table.runtime.operators.wmassigners
-
Generates periodic watermarks based on a
PunctuatedWatermarkAssigner
. - PunctuatedWatermarkStrategyWrapper(PunctuatedWatermarkAssigner, int, DataType) - Constructor for class org.apache.flink.table.runtime.operators.wmassigners.PunctuatedWatermarkStrategyWrapper
- pushToOperator(StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingFirstInputOfTwoInputStreamOperatorOutput
- pushToOperator(StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingOneInputStreamOperatorOutput
- pushToOperator(StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.CopyingSecondInputOfTwoInputStreamOperatorOutput
- pushToOperator(StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.FirstInputOfTwoInputStreamOperatorOutput
- pushToOperator(StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.OneInputStreamOperatorOutput
- pushToOperator(StreamRecord<X>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.output.SecondInputOfTwoInputStreamOperatorOutput
- put(String, JsonPath) - Method in class org.apache.flink.table.runtime.functions.JsonPathCache
- put(RowData, Collection<RowData>) - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.LookupFullCache
- put(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Appends a record into the buffer.
- put(W, RowData, UV) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
-
Associates a new value with the given key.
- putAll(RowData, Collection<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Puts a record list into the buffer under the sortKey.
- putAll(W, Map<RowData, UV>) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
-
Copies all of the mappings from the given map into the state.
- putBinaryNormalizedKey(byte[], MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
- putBooleanNormalizedKey(boolean, MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
- putBuildRow(BinaryRowData) - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- putBuildRow(RowData) - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
-
Put a build side row to hash table.
- putByteNormalizedKey(byte, MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
- putDecimalNormalizedKey(DecimalData, MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
-
Just support the compact precision decimal.
- putDoubleNormalizedKey(double, MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
-
See http://stereopsis.com/radix.html for more details.
- putFloatNormalizedKey(float, MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
-
See http://stereopsis.com/radix.html for more details.
- putIntNormalizedKey(int, MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
- putKey(RowData, MemorySegment, int) - Method in interface org.apache.flink.table.runtime.generated.NormalizedKeyComputer
-
Writes a normalized key for the given record into the target
MemorySegment
. - putLongNormalizedKey(long, MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
- putShortNormalizedKey(short, MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
- putStringNormalizedKey(StringData, MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
-
UTF-8 supports bytes comparison.
- putTimestampNormalizedKey(TimestampData, MemorySegment, int, int) - Static method in class org.apache.flink.table.runtime.operators.sort.SortUtil
-
Support the compact precision TimestampData.
Q
- query(HllBuffer) - Method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HyperLogLogPlusPlus
-
Compute the HyperLogLog estimate.
R
- radians(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- RangeSlidingOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The range sliding window frame calculates frames with the following SQL form: ...
- RangeSlidingOverFrame(RowType, RowType, GeneratedAggsHandleFunction, GeneratedRecordComparator, GeneratedRecordComparator) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.RangeSlidingOverFrame
- RangeUnboundedFollowingOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The range unboundedFollowing window frame calculates frames with the following SQL form: ...
- RangeUnboundedFollowingOverFrame(RowType, GeneratedAggsHandleFunction, GeneratedRecordComparator) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.RangeUnboundedFollowingOverFrame
- RangeUnboundedPrecedingOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The range UnboundPreceding window frame calculates frames with the following SQL form: ...
- RangeUnboundedPrecedingOverFrame(GeneratedAggsHandleFunction, GeneratedRecordComparator) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.RangeUnboundedPrecedingOverFrame
- RANK - org.apache.flink.table.runtime.operators.rank.RankType
-
Returns a unique rank number for each distinct row within the partition based on the order, starting at 1 for the first row in each partition, with the same rank for duplicate values and leaving gaps between the ranks; this gap appears in the sequence after the duplicate values.
- rankEnd - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractSyncStateTopNFunction
- rankEnd(long) - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- rankEndFetcher - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- RankOperator - Class in org.apache.flink.table.runtime.operators.sort
-
Rank operator to compute top N.
- RankOperator(GeneratedRecordComparator, GeneratedRecordComparator, long, long, boolean) - Constructor for class org.apache.flink.table.runtime.operators.sort.RankOperator
- RankRange - Interface in org.apache.flink.table.runtime.operators.rank
-
RankRange for Rank, including following 3 types : ConstantRankRange, ConstantRankRangeWithoutEnd, VariableRankRange.
- rankStart - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- rankStart(long) - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- RankType - Enum in org.apache.flink.table.runtime.operators.rank
-
An enumeration of rank type, usable to show how exactly generate rank number.
- RawByteArrayConverter<T> - Class in org.apache.flink.table.data.conversion
-
Converter for
RawType
ofbyte[]
external type. - RawFormatDeserializationSchema - Class in org.apache.flink.formats.raw
-
Deserialization schema from raw (byte based) value to Flink Table/SQL internal data structure
RowData
. - RawFormatDeserializationSchema(LogicalType, TypeInformation<RowData>, String, boolean) - Constructor for class org.apache.flink.formats.raw.RawFormatDeserializationSchema
- RawFormatFactory - Class in org.apache.flink.formats.raw
-
Format factory for raw format which allows to read and write raw (byte based) values as a single column.
- RawFormatFactory() - Constructor for class org.apache.flink.formats.raw.RawFormatFactory
- RawFormatOptions - Class in org.apache.flink.formats.raw
-
Options for the "raw" format.
- RawFormatSerializationSchema - Class in org.apache.flink.formats.raw
-
Serialization schema that serializes an
RowData
object into raw (byte based) value. - RawFormatSerializationSchema(LogicalType, String, boolean) - Constructor for class org.apache.flink.formats.raw.RawFormatSerializationSchema
- RawObjectConverter<T> - Class in org.apache.flink.table.data.conversion
-
Converter for
RawType
of object external type. - RawValueDataSerializer<T> - Class in org.apache.flink.table.runtime.typeutils
-
Serializer for
RawValueData
. - RawValueDataSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- RawValueDataSerializer.RawValueDataSerializerSnapshot<T> - Class in org.apache.flink.table.runtime.typeutils
-
TypeSerializerSnapshot
forRawValueDataSerializer
. - RawValueDataSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer.RawValueDataSerializerSnapshot
- RawValueDataSerializerSnapshot(RawValueDataSerializer<T>) - Constructor for class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer.RawValueDataSerializerSnapshot
- reachedEnd() - Method in class org.apache.flink.table.runtime.operators.values.ValuesInputFormat
- readAllBuffers(FileIOChannel.ID, int) - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- readBlock(MemorySegment) - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- readOuterSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer.ExternalSerializerSnapshot
- readOuterSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer.LinkedListSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer.ArrayDataSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer.DecimalSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer.MapDataSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer.RowDataSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializerSnapshot
- readSnapshot(int, DataInputView, ClassLoader) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer.TimestampDataSerializerSnapshot
- realSize() - Method in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
- record - Variable in class org.apache.flink.table.runtime.operators.join.stream.utils.OuterRecord
- RECORD_BYTES - Static variable in class org.apache.flink.table.runtime.hashtable.BinaryHashBucketArea
-
The number of bytes that the entry in the hash structure occupies, in bytes.
- RECORD_EXTRA_LENGTH - Static variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- recordArea - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
-
The segments where the actual data is stored.
- recordBuffer - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- RecordComparator - Interface in org.apache.flink.table.runtime.generated
-
Record comparator for
BinaryInMemorySortBuffer
. - recordCounter - Variable in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
-
Used to count the number of added and retracted input records.
- recordCounter - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
-
Used to count the number of added and retracted input records.
- RecordCounter - Class in org.apache.flink.table.runtime.operators.aggregate
-
The
RecordCounter
is used to count the number of input records under the current key. - RecordCounter() - Constructor for class org.apache.flink.table.runtime.operators.aggregate.RecordCounter
- recordCountIsZero(RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.RecordCounter
-
We store the counter in the accumulator.
- RecordEqualiser - Interface in org.apache.flink.table.runtime.generated
-
Record equaliser for RowData which can compare two RowData and returns whether they are equal.
- RecordsCombiner - Interface in org.apache.flink.table.runtime.operators.window.tvf.combines
-
The
RecordsCombiner
is used to combine buffered records into state. - RecordsCombiner.Factory - Interface in org.apache.flink.table.runtime.operators.window.tvf.combines
-
A factory that creates a
RecordsCombiner
. - RecordsCombiner.LocalFactory - Interface in org.apache.flink.table.runtime.operators.window.tvf.combines
-
A factory that creates a
RecordsCombiner
used for combining at local stage. - recordSize() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- recordsPerSegment() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- RecordsWindowBuffer - Class in org.apache.flink.table.runtime.operators.aggregate.window.buffers
-
An implementation of
WindowBuffer
that buffers input elements in aWindowBytesMultiMap
and combines buffered elements into state when flushing. - RecordsWindowBuffer(Object, MemoryManager, long, RecordsCombiner, PagedTypeSerializer<RowData>, AbstractRowDataSerializer<RowData>, boolean, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.buffers.RecordsWindowBuffer
- RecordsWindowBuffer.Factory - Class in org.apache.flink.table.runtime.operators.aggregate.window.buffers
-
Factory to create
RecordsWindowBuffer
withRecordsCombiner.Factory
. - RecordsWindowBuffer.LocalFactory - Class in org.apache.flink.table.runtime.operators.aggregate.window.buffers
-
Factory to create
RecordsWindowBuffer
withRecordsCombiner.LocalFactory
. - recycle(MemorySegment) - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- recycle(MemorySegment) - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- recycle(MemorySegment) - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelReaderInputView
- recycle(MemorySegment) - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelWriterOutputView
- reducedSize() - Method in class org.apache.flink.table.runtime.operators.join.stream.bundle.BufferBundle
-
Return the number of reduced records.
- RefCountedCache(LookupCache) - Constructor for class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager.RefCountedCache
- reference - Variable in class org.apache.flink.table.runtime.groupwindow.AbstractWindowProperty
-
Deprecated.
- regExp(String, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- RegexpCountFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.REGEXP_COUNT
. - RegexpCountFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.RegexpCountFunction
- regexpExtract(String, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns the first string extracted with a specified regular expression.
- regexpExtract(String, String, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns a string extracted with a specified regular expression and a regex match group index.
- regexpExtract(String, String, long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- RegexpExtractAllFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.REGEXP_EXTRACT_ALL
. - RegexpExtractAllFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.RegexpExtractAllFunction
- RegexpInstrFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.REGEXP_INSTR
. - RegexpInstrFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.RegexpInstrFunction
- regexpReplace(String, String, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns a string resulting from replacing all substrings that match the regular expression with replacement.
- RegexpSubstrFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.REGEXP_SUBSTR
. - RegexpSubstrFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.RegexpSubstrFunction
- registerCacheIfAbsent(String, LookupCache) - Method in class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager
-
Register a cache instance with identifier to the manager.
- registerCallback(BundleTriggerCallback) - Method in interface org.apache.flink.table.runtime.operators.bundle.trigger.BundleTrigger
-
Register a callback which will be called once this trigger decides to finish this bundle.
- registerCallback(BundleTriggerCallback) - Method in interface org.apache.flink.table.runtime.operators.bundle.trigger.CoBundleTrigger
-
Register a callback which will be called once this trigger decides to finish this bundle.
- registerCallback(BundleTriggerCallback) - Method in class org.apache.flink.table.runtime.operators.bundle.trigger.CountBundleTrigger
- registerCallback(BundleTriggerCallback) - Method in class org.apache.flink.table.runtime.operators.bundle.trigger.CountCoBundleTrigger
- registerDynamicFilteringDataListenerID(String) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorFactory
- registerEventTimeTimer(long) - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator.ContextImpl
- registerEventTimeTimer(long) - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator.ContextImpl
- registerEventTimeTimer(long) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger.TriggerContext
-
Register an event-time callback.
- registerEventTimeWindowTimer(Long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SlicingWindowTimerServiceImpl
- registerEventTimeWindowTimer(TimeWindow) - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnslicingWindowTimerServiceImpl
- registerEventTimeWindowTimer(W) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerService
-
Registers a window timer to be fired when event time watermark passes the window.
- registerMetric() - Method in class org.apache.flink.table.runtime.operators.rank.utils.AppendOnlyTopNHelper
- registerMetric() - Method in class org.apache.flink.table.runtime.operators.rank.utils.FastTop1Helper
- registerMetric(long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- registerMetric(long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- registerMetric(long, long, long) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- registerMetric(OperatorMetricGroup) - Method in class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
- registerProcessingCleanupTimer() - Method in class org.apache.flink.table.runtime.operators.join.temporal.BaseTwoInputStreamOperatorWithStateRetention
-
If the user has specified a
minRetentionTime
andmaxRetentionTime
, this method registers a cleanup timer forcurrentProcessingTime + minRetentionTime
. - registerProcessingCleanupTimer(ValueState<Long>, long, long, long, TimerService) - Method in interface org.apache.flink.table.runtime.functions.CleanupState
- registerProcessingCleanupTimer(KeyedProcessFunction.Context, long) - Method in class org.apache.flink.table.runtime.functions.KeyedProcessFunctionWithCleanupState
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator.ContextImpl
- registerProcessingTimeTimer(long) - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator.ContextImpl
- registerProcessingTimeTimer(long) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger.TriggerContext
-
Register a system time callback.
- registerProcessingTimeWindowTimer(Long) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SlicingWindowTimerServiceImpl
- registerProcessingTimeWindowTimer(TimeWindow) - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnslicingWindowTimerServiceImpl
- registerProcessingTimeWindowTimer(W) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerService
-
Registers a window timer to be fired when processing time passes the window.
- release() - Method in class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager.RefCountedCache
- releaseMemoryCacheForSMJ() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
Due to adaptive hash join is introduced, the cached memory segments should be released to
MemoryManager
before switch to sort merge join. - reloadAsync() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
- ReloadTriggerContext - Class in org.apache.flink.table.runtime.functions.table.lookup.fullcache
-
Runtime implementation of
CacheReloadTrigger.Context
. - ReloadTriggerContext(Supplier<CompletableFuture<Void>>, Consumer<Throwable>) - Constructor for class org.apache.flink.table.runtime.functions.table.lookup.fullcache.ReloadTriggerContext
- remainBuffers() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- remove() - Method in interface org.apache.flink.table.runtime.dataview.NullAwareMapIterator.NullMapEntry
- remove() - Method in class org.apache.flink.table.runtime.dataview.NullAwareMapIterator
- remove() - Method in class org.apache.flink.table.runtime.util.SingleElementIterator
- remove(EE) - Method in class org.apache.flink.table.runtime.dataview.StateListView
- remove(RowData, RowData) - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
- remove(W, RowData) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
-
Deletes the mapping of the given key.
- removeAll(RowData) - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Removes all record list from the buffer under the sortKey.
- removeChannel(FileIOChannel.ID) - Method in class org.apache.flink.table.runtime.operators.sort.SpillChannelManager
- removeEldestEntry(Map.Entry<K, V>) - Method in class org.apache.flink.table.runtime.util.LRUMap
- removeFromState(RowData) - Method in class org.apache.flink.table.runtime.operators.rank.utils.AppendOnlyTopNHelper
- removeLast() - Method in class org.apache.flink.table.runtime.operators.rank.TopNBuffer
-
Removes the last record of the last Entry in the buffer.
- removeLegacyTypes(LogicalType) - Static method in class org.apache.flink.table.runtime.types.PlannerTypeUtils
-
A conversion that removes all
LegacyTypeInformationType
s by mapping to corresponding new types. - repeat(String, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns a string that repeats the base string n times.
- replace(long, RowData) - Method in class org.apache.flink.table.runtime.util.WindowKey
-
Replace the currently stored key and window by the given new key and new window.
- replace(String, String, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Replaces all the old strings with the replacement string.
- ReplicateRowsFunction - Class in org.apache.flink.table.runtime.functions.table
-
Replicate the row N times.
- ReplicateRowsFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.table.ReplicateRowsFunction
- reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.table.runtime.operators.sink.SinkOperator
- requestCount - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- requestFailed(Buffer, IOException) - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- requestFailed(Buffer, IOException) - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelReaderInputView
- requestSuccessful(Buffer) - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- requestSuccessful(Buffer) - Method in class org.apache.flink.table.runtime.io.CompressedHeaderlessChannelReaderInputView
- requiredOptions() - Method in class org.apache.flink.formats.raw.RawFormatFactory
- reservedNumBuffers - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- reset() - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
-
First, reset.
- reset() - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
-
First, reset.
- reset() - Method in interface org.apache.flink.table.data.writer.BinaryWriter
-
Reset writer to prepare next write.
- reset() - Method in class org.apache.flink.table.runtime.collector.TableFunctionCollector
-
Resets the flag to indicate whether [[collect(T)]] has been called.
- reset() - Method in interface org.apache.flink.table.runtime.operators.bundle.trigger.BundleTrigger
-
Reset the trigger to its initiate status.
- reset() - Method in interface org.apache.flink.table.runtime.operators.bundle.trigger.CoBundleTrigger
-
Reset the trigger to its initiate status.
- reset() - Method in class org.apache.flink.table.runtime.operators.bundle.trigger.CountBundleTrigger
- reset() - Method in class org.apache.flink.table.runtime.operators.bundle.trigger.CountCoBundleTrigger
- reset() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryInMemorySortBuffer
-
Resets the sort buffer back to the state where it is empty.
- reset() - Method in class org.apache.flink.table.runtime.operators.window.grouping.WindowsGrouping
-
Reset for next group.
- reset() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesHashMap
-
reset the map's record and bucket area's memory segments for reusing.
- reset() - Method in class org.apache.flink.table.runtime.util.collections.binary.AbstractBytesMultiMap
-
reset the map's record and bucket area's memory segments for reusing.
- reset() - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
-
reset the map's record and bucket area's memory segments for reusing.
- reset() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer.BufferIterator
- reset() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
- reset() - Method in interface org.apache.flink.table.runtime.util.ResettableRowBuffer
-
Re-initialize the buffer state.
- reset() - Method in interface org.apache.flink.table.runtime.util.ResettableRowBuffer.ResettableIterator
-
Re-initialize the iterator, start from begin row.
- resetAccumulator(RowData) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction
- resetAccumulator(RowData) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueAggFunction
- resetAccumulator(ArrayAggFunction.ArrayAggAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction
- resetAccumulator(CollectAggFunction.CollectAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction
- resetAccumulator(FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- resetAccumulator(HllBuffer) - Method in class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ApproxCountDistinctAggFunction
- resetAccumulator(JsonArrayAggFunction.Accumulator) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction
- resetAccumulator(JsonObjectAggFunction.Accumulator) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction
- resetAccumulator(LagAggFunction.LagAcc<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.LagAggFunction
- resetAccumulator(LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- resetAccumulator(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction
- resetAccumulator(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
- resetAccumulator(MaxWithRetractAggFunction.MaxWithRetractAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction
- resetAccumulator(MinWithRetractAggFunction.MinWithRetractAccumulator<T>) - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction
- resetAccumulators() - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunctionBase
-
Resets all the accumulators.
- resetBucketSegments(List<MemorySegment>) - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- resetBuffer() - Method in class org.apache.flink.table.runtime.operators.window.grouping.HeapWindowsGrouping
- resetBuffer() - Method in class org.apache.flink.table.runtime.operators.window.grouping.WindowsGrouping
- ResettableExternalBuffer - Class in org.apache.flink.table.runtime.util
-
A resettable external buffer for binary row.
- ResettableExternalBuffer(IOManager, LazyMemorySegmentPool, AbstractRowDataSerializer, boolean) - Constructor for class org.apache.flink.table.runtime.util.ResettableExternalBuffer
- ResettableExternalBuffer.BufferIterator - Class in org.apache.flink.table.runtime.util
-
Iterator of external buffer.
- ResettableRowBuffer - Interface in org.apache.flink.table.runtime.util
-
Resettable buffer that add
RowData
and returnBinaryRowData
iterator. - ResettableRowBuffer.ResettableIterator - Interface in org.apache.flink.table.runtime.util
-
Row iterator that can be reset.
- resetToCheckpoint(long, byte[]) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- resolveOuterSchemaCompatibility(TypeSerializerSnapshot<LinkedList<T>>) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer.LinkedListSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<SortedMap<K, V>>) - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<ArrayData>) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer.ArrayDataSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<BinaryRowData>) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<DecimalData>) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer.DecimalSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<MapData>) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer.MapDataSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<RowData>) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer.RowDataSerializerSnapshot
- resolveSchemaCompatibility(TypeSerializerSnapshot<TimestampData>) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer.TimestampDataSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer.ArrayDataSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer.DecimalSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer.MapDataSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer.RowDataSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializerSnapshot
- restoreSerializer() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer.TimestampDataSerializerSnapshot
- ResultRetryStrategy - Class in org.apache.flink.table.runtime.operators.join.lookup
-
A utility class to wrap the data stream api
AsyncRetryStrategy
to support both sync and async retry in table module. - ResultRetryStrategy(AsyncRetryStrategy) - Constructor for class org.apache.flink.table.runtime.operators.join.lookup.ResultRetryStrategy
- retain() - Method in class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager.RefCountedCache
- retireWindow(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowSet
-
Removes the given window from the set of in-flight windows.
- retract(RowData) - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunctionBase
-
Retracts the input values from the accumulators.
- retract(RowData) - Method in interface org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunctionBase
-
Retracts the input values from the accumulators.
- retract(ArrayAggFunction.ArrayAggAccumulator<T>, T) - Method in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction
- retract(CollectAggFunction.CollectAccumulator<T>, T) - Method in class org.apache.flink.table.runtime.functions.aggregate.CollectAggFunction
- retract(FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T>, Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- retract(FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator<T>, Object, Long) - Method in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction
- retract(JsonArrayAggFunction.Accumulator, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonArrayAggFunction
- retract(JsonObjectAggFunction.Accumulator, StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.JsonObjectAggFunction
- retract(LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T>, Object) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- retract(LastValueWithRetractAggFunction.LastValueWithRetractAccumulator<T>, Object, Long) - Method in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction
- retract(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction
- retract(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator, StringData, StringData) - Method in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction
- retract(MaxWithRetractAggFunction.MaxWithRetractAccumulator<T>, T) - Method in class org.apache.flink.table.runtime.functions.aggregate.MaxWithRetractAggFunction
- retract(MinWithRetractAggFunction.MinWithRetractAccumulator<T>, T) - Method in class org.apache.flink.table.runtime.functions.aggregate.MinWithRetractAggFunction
- retract(PercentileAggFunction.PercentileAccumulator, Object, Double) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- retract(PercentileAggFunction.PercentileAccumulator, Object, Double[]) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- retract(PercentileAggFunction.PercentileAccumulator, Object, Double[], Number) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- retract(PercentileAggFunction.PercentileAccumulator, Object, Double, Number) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- RetractableTopNFunction - Class in org.apache.flink.table.runtime.operators.rank
-
A TopN function could handle updating stream.
- RetractableTopNFunction(StateTtlConfig, InternalTypeInfo<RowData>, ComparableRecordComparator, RowDataKeySelector, RankType, RankRange, GeneratedRecordEqualiser, boolean, boolean) - Constructor for class org.apache.flink.table.runtime.operators.rank.RetractableTopNFunction
- retractList - Variable in class org.apache.flink.table.runtime.functions.aggregate.ArrayAggFunction.ArrayAggAccumulator
- retractList - Variable in class org.apache.flink.table.runtime.functions.aggregate.ListAggWithRetractAggFunction.ListAggWithRetractAccumulator
- retractList - Variable in class org.apache.flink.table.runtime.functions.aggregate.ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator
- retractRecord(RowData) - Method in interface org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.JoinRecordAsyncStateView
-
Retract the record from the state view.
- retractRecord(RowData) - Method in interface org.apache.flink.table.runtime.operators.join.stream.state.JoinRecordStateView
-
Retract the record from the state view.
- retractRecord(STATE_VIEW, RowData) - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinHelper
- RetryableAsyncLookupFunctionDelegator - Class in org.apache.flink.table.runtime.operators.join.lookup
-
A delegator holds user's
AsyncLookupFunction
to handle retries. - RetryableAsyncLookupFunctionDelegator(AsyncLookupFunction, ResultRetryStrategy) - Constructor for class org.apache.flink.table.runtime.operators.join.lookup.RetryableAsyncLookupFunctionDelegator
- RetryableLookupFunctionDelegator - Class in org.apache.flink.table.runtime.operators.join.lookup
-
A delegator holds user's
LookupFunction
to handle retries. - RetryableLookupFunctionDelegator(LookupFunction, ResultRetryStrategy) - Constructor for class org.apache.flink.table.runtime.operators.join.lookup.RetryableLookupFunctionDelegator
- RetryPredicates - Class in org.apache.flink.table.runtime.operators.calc.async
-
Contains retry predicates used to determine if a result or error should result in a retry.
- RetryPredicates() - Constructor for class org.apache.flink.table.runtime.operators.calc.async.RetryPredicates
- RetryPredicates.AnyExceptionStrategy - Class in org.apache.flink.table.runtime.operators.calc.async
-
Returns true for any exception.
- RetryPredicates.EmptyResponseResultStrategy - Class in org.apache.flink.table.runtime.operators.calc.async
-
Returns true if the response is null or empty.
- returnAll(List<MemorySegment>) - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- returnAll(List<MemorySegment>) - Method in class org.apache.flink.table.runtime.operators.aggregate.BytesHashMapSpillMemorySegmentPool
- returnAll(List<MemorySegment>) - Method in class org.apache.flink.table.runtime.operators.sort.ListMemorySegmentPool
- returnAll(List<MemorySegment>) - Method in class org.apache.flink.table.runtime.util.LazyMemorySegmentPool
- returnAll(List<MemorySegment>) - Method in interface org.apache.flink.table.runtime.util.MemorySegmentPool
-
Return all pages back into this pool.
- returnPage(MemorySegment) - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- returnPage(MemorySegment) - Method in class org.apache.flink.table.runtime.util.LazyMemorySegmentPool
- returnSegments(List<MemorySegment>) - Method in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- returnToSegmentPool() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryInMemorySortBuffer
- REUSABLE_TRUE_STATE_FUTURE - Static variable in class org.apache.flink.table.runtime.util.AsyncStateUtils
- REUSABLE_VOID_STATE_FUTURE - Static variable in class org.apache.flink.table.runtime.util.AsyncStateUtils
- reusedKey - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
-
Used as a reused object when lookup and iteration.
- reusedValue - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
-
Used as a reused object when retrieve the map's value by key and iteration.
- reuseOutput - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- reverse(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Reverse each character in current string.
- RIGHT - org.apache.flink.table.runtime.operators.join.FlinkJoinType
- RIGHT_INPUT_TYPE_NUMBER - Static variable in class org.apache.flink.table.runtime.strategy.BaseAdaptiveJoinOperatorOptimizationStrategy
- RIGHT_RECORDS_STATE_NAME - Static variable in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- RIGHT_RECORDS_STATE_NAME - Static variable in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- rightInputSideSpec - Variable in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- rightInputSideSpec - Variable in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- rightIsOuter - Variable in class org.apache.flink.table.runtime.operators.join.stream.StreamingJoinOperator
- rightRecordStateView - Variable in class org.apache.flink.table.runtime.operators.join.stream.StreamingJoinOperator
- rightRowSerializer - Variable in class org.apache.flink.table.runtime.operators.join.lookup.AsyncLookupJoinRunner
- rightSerializer - Variable in class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
- rightSerializer(TypeSerializer<RowData>) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- rightStateRetentionTime - Variable in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- rightStateRetentionTime - Variable in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- rightType - Variable in class org.apache.flink.table.runtime.operators.join.stream.AbstractStreamingJoinOperator
- rightType - Variable in class org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.AbstractAsyncStateStreamingJoinOperator
- rightWindowEndIndex(int) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- ROW_NUMBER - org.apache.flink.table.runtime.operators.rank.RankType
-
Returns a unique sequential number for each row within the partition based on the order, starting at 1 for the first row in each partition and without repeating or skipping numbers in the ranking result of each partition.
- row1 - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- RowConverter(DataType[]) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.RowConverter
- RowDataCustomStreamPartitioner - Class in org.apache.flink.table.runtime.partitioner
-
The partitioner used to partition row data by the connector's custom logic.
- RowDataCustomStreamPartitioner(SupportsLookupCustomShuffle.InputDataPartitioner, RowDataKeySelector) - Constructor for class org.apache.flink.table.runtime.partitioner.RowDataCustomStreamPartitioner
- RowDataEventComparator - Class in org.apache.flink.table.runtime.operators.match
-
An implementation of
EventComparator
based on a generatedRecordComparator
. - RowDataEventComparator(GeneratedRecordComparator) - Constructor for class org.apache.flink.table.runtime.operators.match.RowDataEventComparator
- RowDataKeySelector - Interface in org.apache.flink.table.runtime.keyselector
-
RowDataKeySelector takes an RowData and extracts the deterministic key for the RowData.
- RowDataSerializer - Class in org.apache.flink.table.runtime.typeutils
-
Serializer for
RowData
. - RowDataSerializer(LogicalType...) - Constructor for class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- RowDataSerializer(LogicalType[], TypeSerializer<?>[]) - Constructor for class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- RowDataSerializer(RowType) - Constructor for class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- RowDataSerializer.RowDataSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils
-
TypeSerializerSnapshot
forBinaryRowDataSerializer
. - RowDataSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.RowDataSerializer.RowDataSerializerSnapshot
- RowDataUtil - Class in org.apache.flink.table.data.util
-
Utilities for
RowData
. - RowDataUtil() - Constructor for class org.apache.flink.table.data.util.RowDataUtil
- RowIterator<T extends org.apache.flink.table.data.RowData> - Interface in org.apache.flink.table.runtime.util
-
An internal iterator interface which presents a more restrictive API than
Iterator
. - RowKindSetter - Class in org.apache.flink.table.runtime.operators.sink
-
An operator that sets the row kind of the incoming records to a specific row kind.
- RowKindSetter(RowKind) - Constructor for class org.apache.flink.table.runtime.operators.sink.RowKindSetter
- RowRowConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
RowType
ofRow
external type. - RowSlidingOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The row sliding window frame calculates frames with the following SQL form: ...
- RowSlidingOverFrame(RowType, RowType, GeneratedAggsHandleFunction, long, long) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.RowSlidingOverFrame
- RowtimeAttribute - Class in org.apache.flink.table.runtime.groupwindow
-
Deprecated.The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.
- RowtimeAttribute(WindowReference) - Constructor for class org.apache.flink.table.runtime.groupwindow.RowtimeAttribute
-
Deprecated.
- RowTimeDeduplicateFunction - Class in org.apache.flink.table.runtime.operators.deduplicate
-
This function is used to deduplicate on keys and keeps only first or last row on row time.
- RowTimeDeduplicateFunction(InternalTypeInfo<RowData>, long, int, boolean, boolean, boolean) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.RowTimeDeduplicateFunction
- RowTimeDeduplicateFunctionHelper - Class in org.apache.flink.table.runtime.operators.deduplicate.utils
-
A helper to deduplicate data with row time in
RowTimeDeduplicateFunction
andAsyncStateRowTimeDeduplicateFunction
. - RowTimeDeduplicateFunctionHelper(boolean, boolean, int, boolean) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.utils.RowTimeDeduplicateFunctionHelper
- RowTimeDeduplicateRecordsCombiner - Class in org.apache.flink.table.runtime.operators.deduplicate.window.combines
-
An implementation of
RecordsCombiner
that stores the first/last records of incremental input records into the window state. - RowTimeDeduplicateRecordsCombiner(WindowTimerService<Long>, StateKeyContext, WindowValueState<Long>, int, boolean, TypeSerializer<RowData>) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.window.combines.RowTimeDeduplicateRecordsCombiner
- RowTimeDeduplicateRecordsCombiner.Factory - Class in org.apache.flink.table.runtime.operators.deduplicate.window.combines
-
Factory to create
RowTimeDeduplicateRecordsCombiner
. - rowtimeIndex - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- rowtimeIndex - Variable in class org.apache.flink.table.runtime.operators.window.tvf.operator.WindowTableFunctionOperatorBase
- rowtimeIndex(int) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.RowTimeWindowDeduplicateOperatorBuilder
- RowTimeIntervalJoin - Class in org.apache.flink.table.runtime.operators.join.interval
-
The function to execute row(event) time interval stream inner-join.
- RowTimeIntervalJoin(FlinkJoinType, long, long, long, long, InternalTypeInfo<RowData>, InternalTypeInfo<RowData>, IntervalJoinFunction, int, int) - Constructor for class org.apache.flink.table.runtime.operators.join.interval.RowTimeIntervalJoin
- RowTimeMiniBatchAssginerOperator - Class in org.apache.flink.table.runtime.operators.wmassigners
-
A stream operator that emits watermark in a given event-time interval.
- RowTimeMiniBatchAssginerOperator(long) - Constructor for class org.apache.flink.table.runtime.operators.wmassigners.RowTimeMiniBatchAssginerOperator
- RowTimeMiniBatchDeduplicateFunction - Class in org.apache.flink.table.runtime.operators.deduplicate
-
This function is used to get the first or last row for every key partition in miniBatch mode.
- RowTimeMiniBatchDeduplicateFunction(InternalTypeInfo<RowData>, TypeSerializer<RowData>, long, int, boolean, boolean, boolean) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.RowTimeMiniBatchDeduplicateFunction
- RowTimeMiniBatchLatestChangeDeduplicateFunction - Class in org.apache.flink.table.runtime.operators.deduplicate
-
This function is used to get the first or last row for every key partition in miniBatch mode.
- RowTimeMiniBatchLatestChangeDeduplicateFunction(InternalTypeInfo<RowData>, TypeSerializer<RowData>, long, int, boolean, boolean, boolean) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.RowTimeMiniBatchLatestChangeDeduplicateFunction
- RowTimeRangeBoundedPrecedingFunction<K> - Class in org.apache.flink.table.runtime.operators.over
-
Process Function for RANGE clause event-time bounded OVER window.
- RowTimeRangeBoundedPrecedingFunction(GeneratedAggsHandleFunction, LogicalType[], LogicalType[], long, int) - Constructor for class org.apache.flink.table.runtime.operators.over.RowTimeRangeBoundedPrecedingFunction
- RowTimeRangeUnboundedPrecedingFunction<K> - Class in org.apache.flink.table.runtime.operators.over
-
A ProcessFunction to support unbounded RANGE window.
- RowTimeRangeUnboundedPrecedingFunction(long, long, GeneratedAggsHandleFunction, LogicalType[], LogicalType[], int) - Constructor for class org.apache.flink.table.runtime.operators.over.RowTimeRangeUnboundedPrecedingFunction
- RowTimeRowsBoundedPrecedingFunction<K> - Class in org.apache.flink.table.runtime.operators.over
-
Process Function for ROWS clause event-time bounded OVER window.
- RowTimeRowsBoundedPrecedingFunction(long, long, GeneratedAggsHandleFunction, LogicalType[], LogicalType[], long, int) - Constructor for class org.apache.flink.table.runtime.operators.over.RowTimeRowsBoundedPrecedingFunction
- RowTimeRowsUnboundedPrecedingFunction<K> - Class in org.apache.flink.table.runtime.operators.over
-
A ProcessFunction to support unbounded ROWS window.
- RowTimeRowsUnboundedPrecedingFunction(long, long, GeneratedAggsHandleFunction, LogicalType[], LogicalType[], int) - Constructor for class org.apache.flink.table.runtime.operators.over.RowTimeRowsUnboundedPrecedingFunction
- RowTimeSortOperator - Class in org.apache.flink.table.runtime.operators.sort
-
Sort based on event-time and possibly additional secondary sort attributes.
- RowTimeSortOperator(InternalTypeInfo<RowData>, int, GeneratedRecordComparator) - Constructor for class org.apache.flink.table.runtime.operators.sort.RowTimeSortOperator
- RowTimeSyncStateWindowDeduplicateProcessor - Class in org.apache.flink.table.runtime.operators.deduplicate.window.processors
-
A rowtime window deduplicate processor.
- RowTimeSyncStateWindowDeduplicateProcessor(TypeSerializer<RowData>, WindowBuffer.Factory, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.window.processors.RowTimeSyncStateWindowDeduplicateProcessor
- RowTimeWindowDeduplicateOperatorBuilder - Class in org.apache.flink.table.runtime.operators.deduplicate.window
-
The
RowTimeWindowDeduplicateOperatorBuilder
is used to build aWindowAggOperator
for rowtime window deduplicate. - RowTimeWindowDeduplicateOperatorBuilder() - Constructor for class org.apache.flink.table.runtime.operators.deduplicate.window.RowTimeWindowDeduplicateOperatorBuilder
- RowUnboundedFollowingOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The row unboundedFollowing window frame calculates frames with the following SQL form: ...
- RowUnboundedFollowingOverFrame(RowType, GeneratedAggsHandleFunction, long) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.RowUnboundedFollowingOverFrame
- RowUnboundedPrecedingOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The row UnboundPreceding window frame calculates frames with the following SQL form: ...
- RowUnboundedPrecedingOverFrame(GeneratedAggsHandleFunction, long) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.RowUnboundedPrecedingOverFrame
- rpad(String, int, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Returns the string str right-padded with the string pad to a length of len characters.
- run() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat.InputSplitCacheLoadTask
- RuntimeFilterUtils - Class in org.apache.flink.table.runtime.operators.runtimefilter.util
-
Utilities for runtime filter.
- RuntimeFilterUtils() - Constructor for class org.apache.flink.table.runtime.operators.runtimefilter.util.RuntimeFilterUtils
S
- safeToString(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- saveTopNBufferToCache(RowData, TopNBuffer) - Method in class org.apache.flink.table.runtime.operators.rank.utils.AppendOnlyTopNHelper
- scale() - Method in class org.apache.flink.table.runtime.typeutils.BigDecimalTypeInfo
- scale() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- ScanRuntimeProviderContext - Class in org.apache.flink.table.runtime.connector.source
-
Implementation of
DynamicTableSource.Context
. - ScanRuntimeProviderContext() - Constructor for class org.apache.flink.table.runtime.connector.source.ScanRuntimeProviderContext
- ScriptTransformIOInfo - Class in org.apache.flink.table.runtime.script
-
The wrapper class of the input/out schema for script transform.
- ScriptTransformIOInfo(String, Map<String, String>, String, Map<String, String>, String, String, Serializable) - Constructor for class org.apache.flink.table.runtime.script.ScriptTransformIOInfo
- SecondInputOfTwoInput - Class in org.apache.flink.table.runtime.operators.multipleinput.input
-
Input
for the second input ofTwoInputStreamOperator
. - SecondInputOfTwoInput(TwoInputStreamOperator<RowData, RowData, RowData>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.input.SecondInputOfTwoInput
- SecondInputOfTwoInputStreamOperatorOutput - Class in org.apache.flink.table.runtime.operators.multipleinput.output
-
An
Output
that can be used to emit elements and other messages for the second input ofTwoInputStreamOperator
. - SecondInputOfTwoInputStreamOperatorOutput(TwoInputStreamOperator<RowData, RowData, RowData>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.output.SecondInputOfTwoInputStreamOperatorOutput
- seekToPosition(long) - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelReader
- segmentSize - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The size of the segments used by the hash join buckets.
- segmentSize - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- segmentSizeBits - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- segmentSizeMask - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- SegmentsUtil - Class in org.apache.flink.table.runtime.util
-
Util for data format segments calc.
- SegmentsUtil() - Constructor for class org.apache.flink.table.runtime.util.SegmentsUtil
- selectChannel(SerializationDelegate<StreamRecord<RowData>>) - Method in class org.apache.flink.table.runtime.partitioner.BinaryHashPartitioner
- selectChannel(SerializationDelegate<StreamRecord<RowData>>) - Method in class org.apache.flink.table.runtime.partitioner.RowDataCustomStreamPartitioner
- SEMI - org.apache.flink.table.runtime.operators.join.FlinkJoinType
- SEMI - org.apache.flink.table.runtime.operators.join.HashJoinType
- serialize(E, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- serialize(LinkedList<T>, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- serialize(ArrayData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- serialize(BinaryRowData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- serialize(DecimalData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- serialize(MapData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- serialize(RawValueData<T>, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- serialize(RowData) - Method in class org.apache.flink.formats.raw.RawFormatSerializationSchema
- serialize(RowData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- serialize(StringData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- serialize(TimestampData, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- serialize(CountWindow, DataOutputView) - Method in class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- serialize(TimeWindow, DataOutputView) - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- serialize(WindowKey, DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- serializeJson(JsonNode) - Static method in class org.apache.flink.table.runtime.functions.SqlJsonUtils
-
Serializes the given
JsonNode
to a JSON string. - serializer - Variable in class org.apache.flink.table.runtime.io.BinaryRowChannelInputViewIterator
- serializer - Variable in class org.apache.flink.table.runtime.operators.deduplicate.DeduplicateFunctionBase
- serializer - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- Serializer() - Constructor for class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- Serializer() - Constructor for class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- serializer1 - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- serializeToPages(BinaryRowData) - Method in class org.apache.flink.table.runtime.hashtable.LongHashPartition
- serializeToPages(BinaryRowData, AbstractPagedOutputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- serializeToPages(RowData, AbstractPagedOutputView) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- serializeToPages(WindowKey, AbstractPagedOutputView) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
-
Actually, the return value is just for saving checkSkipReadForFixLengthPart in the mapFromPages, the cost is very small.
- serializeToPages(T, AbstractPagedOutputView) - Method in class org.apache.flink.table.runtime.typeutils.PagedTypeSerializer
-
Serializes the given record to the given target paged output view.
- serializeWithoutLengthSlow(BinaryRowData, MemorySegmentWritable) - Static method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- session(int, ZoneId, Duration) - Static method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners
-
Creates a session window
UnsliceAssigner
that assigns elements to windows based on the timestamp. - session(Duration) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- SessionUnsliceAssigner(int, ZoneId, long) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.SessionUnsliceAssigner
- SessionWindowAssigner - Class in org.apache.flink.table.runtime.operators.window.groupwindow.assigners
-
A
GroupWindowAssigner
that windows elements into sessions based on the timestamp. - SessionWindowAssigner(long, boolean) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SessionWindowAssigner
- set(long) - Method in class org.apache.flink.table.runtime.hashtable.LongHashPartition.MatchIterator
- set(E) - Method in class org.apache.flink.table.runtime.util.SingleElementIterator
-
Resets the element.
- set(MemorySegment, MemorySegment[], BinaryHashPartition, int, int) - Method in class org.apache.flink.table.runtime.hashtable.LookupBucketIterator
- set(ChannelReaderInputViewIterator<BinaryRowData>) - Method in class org.apache.flink.table.runtime.hashtable.ProbeIterator
- setAccumulators(N, RowData) - Method in interface org.apache.flink.table.runtime.generated.NamespaceAggsHandleFunctionBase
-
Set the current accumulators (saved in a row) which contains the current aggregated results.
- setAccumulators(RowData) - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunctionBase
-
Set the current accumulators (saved in a row) which contains the current aggregated results.
- setBoolean(int, boolean) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setBoolean(int, boolean) - Method in class org.apache.flink.table.data.UpdatableRowData
- setBoolean(MemorySegment[], int, boolean) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
set boolean from segments.
- setByte(int, byte) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setByte(int, byte) - Method in class org.apache.flink.table.data.UpdatableRowData
- setByte(MemorySegment[], int, byte) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
set byte from segments.
- setCollectListener(ListenableCollector.CollectListener<T>) - Method in class org.apache.flink.table.runtime.collector.ListenableCollector
- setCollector(Collector<?>) - Method in class org.apache.flink.table.runtime.collector.TableFunctionCollector
-
Sets the current collector, which used to emit the final row.
- setCollector(Collector<T>) - Method in class org.apache.flink.table.runtime.collector.WrappingCollector
-
Sets the current collector which is used to emit the final result.
- setCurrentKey(RowData) - Method in interface org.apache.flink.table.runtime.context.ExecutionContext
-
Sets current key.
- setCurrentKey(RowData) - Method in class org.apache.flink.table.runtime.context.ExecutionContextImpl
- setCurrentKey(RowData) - Method in interface org.apache.flink.table.runtime.operators.window.tvf.state.StateKeyContext
-
Sets current state key to given value.
- setCurrentNamespace(N) - Method in interface org.apache.flink.table.runtime.dataview.StateDataView
-
Sets current namespace for state.
- setCurrentNamespace(N) - Method in class org.apache.flink.table.runtime.dataview.StateListView.KeyedStateListView
- setCurrentNamespace(N) - Method in class org.apache.flink.table.runtime.dataview.StateListView.NamespacedStateListView
- setCurrentNamespace(N) - Method in class org.apache.flink.table.runtime.dataview.StateMapView.KeyedStateMapViewWithKeysNotNull
- setCurrentNamespace(N) - Method in class org.apache.flink.table.runtime.dataview.StateMapView.KeyedStateMapViewWithKeysNullable
- setCurrentNamespace(N) - Method in class org.apache.flink.table.runtime.dataview.StateMapView.NamespacedStateMapViewWithKeysNotNull
- setCurrentNamespace(N) - Method in class org.apache.flink.table.runtime.dataview.StateMapView.NamespacedStateMapViewWithKeysNullable
- setDecimal(int, DecimalData, int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setDecimal(int, DecimalData, int) - Method in class org.apache.flink.table.data.UpdatableRowData
- setDouble(int, double) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setDouble(int, double) - Method in class org.apache.flink.table.data.UpdatableRowData
- setDouble(MemorySegment[], int, double) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
set double from segments.
- setField(int, Object) - Method in class org.apache.flink.table.data.UpdatableRowData
- setFloat(int, float) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setFloat(int, float) - Method in class org.apache.flink.table.data.UpdatableRowData
- setFloat(MemorySegment[], int, float) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
set float from segments.
- setInput(Object) - Method in class org.apache.flink.table.runtime.collector.TableFunctionCollector
-
Sets the input row from left table, which will be used to cross join with the result of table function.
- setInput(Object) - Method in class org.apache.flink.table.runtime.collector.TableFunctionResultFuture
-
Sets the input row from left table, which will be used to cross join with the result of right table.
- setInstance(RowData) - Method in class org.apache.flink.table.runtime.hashtable.ProbeIterator
- setInt(int, int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setInt(int, int) - Method in class org.apache.flink.table.data.UpdatableRowData
- setInt(MemorySegment[], int, int) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
set int from segments.
- setJoinKey(RowData) - Method in class org.apache.flink.table.runtime.operators.join.interval.IntervalJoinFunction
- setKeyContext(KeyContext) - Method in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
-
Sets keyContext to RankFunction.
- setKeyContextElement(StreamRecord<RowData>) - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputBase
- setList(List<EE>) - Method in class org.apache.flink.table.runtime.dataview.StateListView
- setLong(int, long) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setLong(int, long) - Method in class org.apache.flink.table.data.UpdatableRowData
- setLong(MemorySegment[], int, long) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
set long from segments.
- setManagedMemoryFraction(double) - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- setMap(Map<EK, EV>) - Method in class org.apache.flink.table.runtime.dataview.StateMapView
- setNonPrimitiveValue(int, Object) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setNull(BinaryArrayWriter, int) - Method in interface org.apache.flink.table.data.writer.BinaryArrayWriter.NullSetter
- setNullAt(int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setNullAt(int) - Method in class org.apache.flink.table.data.UpdatableRowData
- setNullAt(int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- setNullAt(int) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
-
Default not null.
- setNullAt(int) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
-
Set null to this field.
- setNullAt(int, LogicalType) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
-
Deprecated.Use
BinaryArrayWriter.createNullSetter(LogicalType)
for avoiding logical types during runtime. - setNullBit(int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- setNullBit(int) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- setNullBoolean(int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- setNullByte(int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- setNullDouble(int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- setNullFloat(int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- setNullInt(int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- setNullLong(int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- setNullShort(int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- setOffsetAndSize(int, int, long) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- setOffsetAndSize(int, int, long) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- setOutputFactory(Function<Object, RowData>) - Method in class org.apache.flink.table.runtime.operators.calc.async.DelegatingAsyncResultFuture
- setPartition(BinaryHashPartition) - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashBucketArea
- setPercentages(Double) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.PercentileAccumulator
- setPercentages(Double[]) - Method in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.PercentileAccumulator
- setReadPosition(long) - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashPartition
- setReadPosition(long) - Method in class org.apache.flink.table.runtime.hashtable.LongHashPartition
- setResultFuture(ResultFuture<?>) - Method in class org.apache.flink.table.runtime.collector.TableFunctionResultFuture
-
Sets the current collector, which used to emit the final row.
- setReuse(BinaryRowData) - Method in class org.apache.flink.table.runtime.hashtable.ProbeIterator
- setRowKind(RowKind) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setRowKind(RowKind) - Method in class org.apache.flink.table.data.UpdatableRowData
- setShort(int, short) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setShort(int, short) - Method in class org.apache.flink.table.data.UpdatableRowData
- setShort(MemorySegment[], int, short) - Static method in class org.apache.flink.table.runtime.util.SegmentsUtil
-
set short from segments.
- setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.UpdatableRowData
- setUserCodeClassLoader(ClassLoader) - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.LookupFullCache
- setValue(BinaryArrayWriter, int, Object) - Method in interface org.apache.flink.table.data.writer.BinaryWriter.ValueSetter
- setWindowAccumulators(W, RowData) - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction.Context
-
Sets the accumulators of the given window.
- setWindowSize(int) - Method in interface org.apache.flink.table.runtime.generated.AggsHandleFunction
-
Set window size for the aggregate function.
- shiftTimeZone - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- shiftTimeZone - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
-
The shift timezone of the window, if the proctime or rowtime type is TIMESTAMP_LTZ, the shift timezone is the timezone user configured in TableConfig, other cases the timezone is UTC which means never shift when assigning windows.
- shiftTimeZone - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- shiftTimeZone - Variable in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerServiceBase
- shiftTimeZone - Variable in class org.apache.flink.table.runtime.operators.window.tvf.operator.WindowTableFunctionOperatorBase
-
The shift timezone of the window, if the proctime or rowtime type is TIMESTAMP_LTZ, the shift timezone is the timezone user configured in TableConfig, other cases the timezone is UTC which means never shift when assigning windows.
- shiftTimeZone(ZoneId) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- shiftTimeZone(ZoneId) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.RowTimeWindowDeduplicateOperatorBuilder
- shiftTimeZone(ZoneId) - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- ShortApproxCountDistinctAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.ShortApproxCountDistinctAggFunction
- ShortHashSet - Class in org.apache.flink.table.runtime.util.collections
-
Short hash set.
- ShortHashSet() - Constructor for class org.apache.flink.table.runtime.util.collections.ShortHashSet
- ShortHashSet(int) - Constructor for class org.apache.flink.table.runtime.util.collections.ShortHashSet
- ShortHashSet(int, float) - Constructor for class org.apache.flink.table.runtime.util.collections.ShortHashSet
- shouldAutocastTo(BasicTypeInfo<?>) - Method in class org.apache.flink.table.runtime.typeutils.BigDecimalTypeInfo
- shouldFilter(boolean, boolean, int[], BinaryRowData) - Static method in class org.apache.flink.table.runtime.operators.join.NullAwareJoinHelper
- shouldReorderInputs() - Method in interface org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoin
-
Check if the adaptive join node needs to adjust the read order of the input sides.
- shouldReorderInputs() - Method in class org.apache.flink.table.runtime.operators.join.adaptive.AdaptiveJoinOperatorFactory
- sign(DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
-
SQL
SIGN
operator applied to BigDecimal values. preserve precision and scale. - sign(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- signum(DecimalData) - Static method in class org.apache.flink.table.data.DecimalDataUtils
-
Returns the signum function of this decimal.
- SimpleGauge<T> - Class in org.apache.flink.table.runtime.operators.metrics
-
A Simple gauge providing method for value updating.
- SimpleGauge(T) - Constructor for class org.apache.flink.table.runtime.operators.metrics.SimpleGauge
- sin(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- SingleElementIterator<E> - Class in org.apache.flink.table.runtime.util
-
Copied from
SingleElementIterator
. - SingleElementIterator() - Constructor for class org.apache.flink.table.runtime.util.SingleElementIterator
- SinglePercentileAggFunction(LogicalType, LogicalType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.SinglePercentileAggFunction
- sinh(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- SinkOperator - Class in org.apache.flink.table.runtime.operators.sink
-
A
StreamOperator
for executingSinkFunctions
. - SinkOperator(SinkFunction<RowData>, int) - Constructor for class org.apache.flink.table.runtime.operators.sink.SinkOperator
- SinkRuntimeProviderContext - Class in org.apache.flink.table.runtime.connector.sink
-
Implementation of
DynamicTableSink.Context
. - SinkRuntimeProviderContext(boolean) - Constructor for class org.apache.flink.table.runtime.connector.sink.SinkRuntimeProviderContext
- SinkRuntimeProviderContext(boolean, int[][]) - Constructor for class org.apache.flink.table.runtime.connector.sink.SinkRuntimeProviderContext
- SinkUpsertMaterializer - Class in org.apache.flink.table.runtime.operators.sink
-
An operator that maintains incoming records in state corresponding to the upsert keys and generates an upsert view for the downstream operator.
- SinkUpsertMaterializer(StateTtlConfig, TypeSerializer<RowData>, GeneratedRecordEqualiser, GeneratedRecordEqualiser, int[]) - Constructor for class org.apache.flink.table.runtime.operators.sink.SinkUpsertMaterializer
- size - Variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Number of entries in the set.
- size() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.LookupFullCache
- size() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.AssociatedRecords
- size() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- size() - Method in class org.apache.flink.table.runtime.util.ResettableExternalBuffer
- skipRecordFromPages(AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- skipRecordFromPages(AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.PagedTypeSerializer
-
Skip over bytes of one record from the paged input view, discarding the skipped bytes.
- skipRecordFromPages(AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- skipRecordFromPages(AbstractPagedInputView) - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- sliceAssigner - Variable in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- sliceAssigner - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- SliceAssigner - Interface in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
A
SliceAssigner
assigns element into a single slice. - SliceAssigners - Class in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
Utilities to create
SliceAssigner
s. - SliceAssigners.CumulativeSliceAssigner - Class in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
The
SliceAssigner
for cumulative windows. - SliceAssigners.HoppingSliceAssigner - Class in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
The
SliceAssigner
for hopping windows. - SliceAssigners.SlicedSharedSliceAssigner - Class in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
The
SliceAssigner
for elements have been attached slice end timestamp, and the slices are shared. - SliceAssigners.SlicedUnsharedSliceAssigner - Class in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
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 - Class in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
The
SliceAssigner
for tumbling windows. - SliceAssigners.WindowedSliceAssigner - Class in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
The
SliceAssigner
for elements have been attached window start and end timestamps. - sliced(int, SliceAssigner) - Static method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners
-
Creates a
SliceAssigner
that assigns elements which has been attached slice end timestamp. - SlicedSharedSliceAssigner(int, SliceSharedAssigner) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.SlicedSharedSliceAssigner
- SlicedUnsharedSliceAssigner(int, SliceAssigner) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.SlicedUnsharedSliceAssigner
- SliceEnd - Class in org.apache.flink.table.runtime.groupwindow
-
Deprecated.The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.
- SliceEnd(WindowReference) - Constructor for class org.apache.flink.table.runtime.groupwindow.SliceEnd
-
Deprecated.
- SliceSharedAssigner - Interface in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
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 - Class in org.apache.flink.table.runtime.operators.aggregate.window.processors
-
A window aggregate processor implementation which works for
SliceSharedAssigner
, e.g. - SliceSharedSyncStateWindowAggProcessor(GeneratedNamespaceAggsHandleFunction<Long>, WindowBuffer.Factory, SliceSharedAssigner, TypeSerializer<RowData>, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.processors.SliceSharedSyncStateWindowAggProcessor
- sliceStateMergeTarget(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
-
Returns the slice state target to merge the given slice into when firing windows.
- sliceStateMergeTarget(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AsyncStateSliceSharedWindowAggProcessor
- sliceStateMergeTarget(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AsyncStateSliceUnsharedWindowAggProcessor
- sliceStateMergeTarget(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
-
Returns the slice state target to merge the given slice into when firing windows.
- sliceStateMergeTarget(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.SliceSharedSyncStateWindowAggProcessor
- sliceStateMergeTarget(long) - Method in class org.apache.flink.table.runtime.operators.aggregate.window.processors.SliceUnsharedSyncStateWindowAggProcessor
- SliceUnsharedAssigner - Interface in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
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 - Class in org.apache.flink.table.runtime.operators.aggregate.window.processors
-
A window aggregate processor implementation which works for
SliceUnsharedAssigner
, e.g. - SliceUnsharedSyncStateWindowAggProcessor(GeneratedNamespaceAggsHandleFunction<Long>, WindowBuffer.Factory, SliceUnsharedAssigner, TypeSerializer<RowData>, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.processors.SliceUnsharedSyncStateWindowAggProcessor
- SlicingSyncStateWindowProcessor<W> - Interface in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
The
SlicingSyncStateWindowProcessor
is an optimized processing for aligned windows which can apply the slicing optimization. - SlicingWindowTimerServiceImpl - Class in org.apache.flink.table.runtime.operators.window.tvf.slicing
-
A
WindowTimerService
for slicing window. - SlicingWindowTimerServiceImpl(InternalTimerService<Long>, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.slicing.SlicingWindowTimerServiceImpl
- sliding(Duration, Duration) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- SlidingOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The sliding window frame.
- SlidingOverFrame(RowType, RowType, GeneratedAggsHandleFunction) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.SlidingOverFrame
- SlidingWindowAssigner - Class in org.apache.flink.table.runtime.operators.window.groupwindow.assigners
-
A
GroupWindowAssigner
that windows elements into sliding windows based on the timestamp of the elements. - SlidingWindowAssigner(long, long, long, boolean) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.operators.window.CountWindow.Serializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.RawValueDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.StringDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- snapshotConfiguration() - Method in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.table.runtime.operators.rank.async.AsyncStateFastTop1Function
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.table.runtime.operators.rank.FastTop1Function
- snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.table.runtime.operators.rank.UpdatableTopNFunction
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.table.runtime.operators.sort.StreamSortOperator
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.table.runtime.operators.window.async.tvf.common.AsyncStateWindowAggOperator
- snapshotState(StateSnapshotContext) - Method in class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- sortAndSpill(ArrayList<MemorySegment>, long, MemorySegmentPool) - Method in class org.apache.flink.table.runtime.operators.sort.BufferedKVExternalSorter
- SortedMapSerializer<K,V> - Class in org.apache.flink.table.runtime.typeutils
-
A serializer for
SortedMap
. - SortedMapSerializer(Comparator<K>, TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.table.runtime.typeutils.SortedMapSerializer
-
Constructor with given comparator, and the serializers for the keys and values in the map.
- SortedMapSerializerSnapshot<K,V> - Class in org.apache.flink.table.runtime.typeutils
-
Snapshot class for the
SortedMapSerializer
. - SortedMapSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.SortedMapSerializerSnapshot
- SortedMapTypeInfo<K,V> - Class in org.apache.flink.table.runtime.typeutils
-
The type information for sorted maps.
- SortedMapTypeInfo(Class<K>, Class<V>) - Constructor for class org.apache.flink.table.runtime.typeutils.SortedMapTypeInfo
- SortedMapTypeInfo(Class<K>, Class<V>, Comparator<K>) - Constructor for class org.apache.flink.table.runtime.typeutils.SortedMapTypeInfo
- SortedMapTypeInfo(TypeInformation<K>, TypeInformation<V>, Comparator<K>) - Constructor for class org.apache.flink.table.runtime.typeutils.SortedMapTypeInfo
- sortIndex - Variable in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- sortKeyComparator - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- sortKeyComparator - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- sortKeyComparator(GeneratedRecordComparator) - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- sortKeySelector - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- sortKeySelector - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- sortKeySelector(RowDataKeySelector) - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- SortLimitOperator - Class in org.apache.flink.table.runtime.operators.sort
-
Operator for batch sort limit.
- SortLimitOperator(boolean, long, long, GeneratedRecordComparator) - Constructor for class org.apache.flink.table.runtime.operators.sort.SortLimitOperator
- SortMergeFullOuterJoinIterator - Class in org.apache.flink.table.runtime.operators.join
-
Gets two matched rows for full outer join.
- SortMergeFullOuterJoinIterator(BinaryRowDataSerializer, BinaryRowDataSerializer, Projection<RowData, BinaryRowData>, Projection<RowData, BinaryRowData>, RecordComparator, MutableObjectIterator<BinaryRowData>, MutableObjectIterator<BinaryRowData>, ResettableExternalBuffer, ResettableExternalBuffer, boolean[]) - Constructor for class org.apache.flink.table.runtime.operators.join.SortMergeFullOuterJoinIterator
- SortMergeInnerJoinIterator - Class in org.apache.flink.table.runtime.operators.join
-
Gets probeRow and match rows for inner join.
- SortMergeInnerJoinIterator(BinaryRowDataSerializer, BinaryRowDataSerializer, Projection, Projection, RecordComparator, MutableObjectIterator<RowData>, MutableObjectIterator<BinaryRowData>, ResettableExternalBuffer, boolean[]) - Constructor for class org.apache.flink.table.runtime.operators.join.SortMergeInnerJoinIterator
- SortMergeJoinFunction - Class in org.apache.flink.table.runtime.operators.join
-
This function is used to process the main logic of sort merge join.
- SortMergeJoinFunction(double, FlinkJoinType, boolean, int, boolean, int, boolean, GeneratedJoinCondition, GeneratedProjection, GeneratedProjection, GeneratedNormalizedKeyComputer, GeneratedRecordComparator, GeneratedNormalizedKeyComputer, GeneratedRecordComparator, GeneratedRecordComparator, boolean[]) - Constructor for class org.apache.flink.table.runtime.operators.join.SortMergeJoinFunction
- SortMergeJoinIterator - Class in org.apache.flink.table.runtime.operators.join
-
Gets probeRow and match rows for inner/left/right join.
- SortMergeJoinIterator(BinaryRowDataSerializer, BinaryRowDataSerializer, Projection<RowData, BinaryRowData>, Projection<RowData, BinaryRowData>, RecordComparator, MutableObjectIterator<RowData>, MutableObjectIterator<BinaryRowData>, ResettableExternalBuffer, boolean[]) - Constructor for class org.apache.flink.table.runtime.operators.join.SortMergeJoinIterator
- SortMergeJoinOperator - Class in org.apache.flink.table.runtime.operators.join
-
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.
- SortMergeJoinOperator(SortMergeJoinFunction) - Constructor for class org.apache.flink.table.runtime.operators.join.SortMergeJoinOperator
- SortMergeOneSideOuterJoinIterator - Class in org.apache.flink.table.runtime.operators.join
-
Gets probeRow and match rows for left/right join.
- SortMergeOneSideOuterJoinIterator(BinaryRowDataSerializer, BinaryRowDataSerializer, Projection<RowData, BinaryRowData>, Projection<RowData, BinaryRowData>, RecordComparator, MutableObjectIterator<RowData>, MutableObjectIterator<BinaryRowData>, ResettableExternalBuffer, boolean[]) - Constructor for class org.apache.flink.table.runtime.operators.join.SortMergeOneSideOuterJoinIterator
- SortOperator - Class in org.apache.flink.table.runtime.operators.sort
-
Operator for batch sort.
- SortOperator(GeneratedNormalizedKeyComputer, GeneratedRecordComparator, int, boolean, int, boolean) - Constructor for class org.apache.flink.table.runtime.operators.sort.SortOperator
- SortUtil - Class in org.apache.flink.table.runtime.operators.sort
-
Util for sort.
- SortUtil() - Constructor for class org.apache.flink.table.runtime.operators.sort.SortUtil
- SourceWatermarkFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.SOURCE_WATERMARK
. - SourceWatermarkFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.SourceWatermarkFunction
- specialize(SpecializedFunction.SpecializedContext) - Method in class org.apache.flink.table.runtime.functions.table.UnnestRowsFunction
- SpillChannelManager - Class in org.apache.flink.table.runtime.operators.sort
-
Channel manager to manage the life cycle of spill channels.
- SpillChannelManager() - Constructor for class org.apache.flink.table.runtime.operators.sort.SpillChannelManager
- spillInBytes - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- spillInBytes - Variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- spillPartition() - Method in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
- spillPartition() - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
-
Selects a partition and spills it.
- spillPartition() - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- splitByWholeSeparatorPreserveAllTokens(BinaryStringData, BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Splits the provided text into an array, separator string specified.
- SplitFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.SPLIT
. - SplitFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.SplitFunction
- splitIndex(String, int, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Split target string with custom separator and pick the index-th(start with 0) result.
- splitIndex(String, String, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Split target string with custom separator and pick the index-th(start with 0) result.
- splitIntoPanes(TimeWindow) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- splitIntoPanes(TimeWindow) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- splitIntoPanes(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.PanedWindowAssigner
-
Splits the given window into panes collection.
- SqlDriver - Class in org.apache.flink.table.runtime.application
-
Driver to load the
ScriptRunner
and execute the script. - SqlDriver() - Constructor for class org.apache.flink.table.runtime.application.SqlDriver
- SqlFunctionUtils - Class in org.apache.flink.table.runtime.functions
-
Built-in scalar runtime functions.
- SqlFunctionUtils() - Constructor for class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- SqlJsonUtils - Class in org.apache.flink.table.runtime.functions
-
Utilities for JSON functions.
- SqlJsonUtils.JsonQueryReturnType - Enum in org.apache.flink.table.runtime.functions
- SqlJsonUtils.PathMode - Enum in org.apache.flink.table.runtime.functions
-
Path spec has two different modes: lax mode and strict mode.
- SqlLikeChainChecker - Class in org.apache.flink.table.runtime.functions
-
String Like util: Matches a chained sequence of checkers.
- SqlLikeChainChecker(String) - Constructor for class org.apache.flink.table.runtime.functions.SqlLikeChainChecker
- sround(byte) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to byte values. - sround(byte, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to byte values. - sround(double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to double values. - sround(double, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to double values. - sround(float) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to float values. - sround(float, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to float values. - sround(int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to int values. - sround(int, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to int values. - sround(long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to long values. - sround(long, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to long values. - sround(short) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to short values. - sround(short, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to short values. - sround(BigDecimal) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to BigDecimal values. - sround(BigDecimal, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to BigDecimal values. - sround(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to DecimalData values. - sround(DecimalData, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
-
SQL
ROUND
operator applied to BigDecimal values. - sround(DecimalData, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
ROUND
operator applied to DecimalData values. - start() - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- StartsWithFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.STARTS_WITH
. - StartsWithFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.StartsWithFunction
- startThreads() - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalSorter
-
Starts all the threads that are used by this sorter.
- stateCleaningEnabled - Variable in class org.apache.flink.table.runtime.functions.KeyedProcessFunctionWithCleanupState
- stateCleaningEnabled - Variable in class org.apache.flink.table.runtime.operators.join.temporal.BaseTwoInputStreamOperatorWithStateRetention
- StateConfigUtil - Class in org.apache.flink.table.runtime.util
-
Utility to create a
StateTtlConfig
object. - StateConfigUtil() - Constructor for class org.apache.flink.table.runtime.util.StateConfigUtil
- StateDataView<N> - Interface in org.apache.flink.table.runtime.dataview
-
A
DataView
which is implemented using state backend. - StateDataViewStore - Interface in org.apache.flink.table.runtime.dataview
-
This interface contains methods for registering
StateDataView
with a managed store. - StateKeyContext - Interface in org.apache.flink.table.runtime.operators.window.tvf.state
-
Context to switch current key in state backend.
- StateListView<N,EE> - Class in org.apache.flink.table.runtime.dataview
-
StateListView
is aListView
which is implemented using state backends. - StateListView() - Constructor for class org.apache.flink.table.runtime.dataview.StateListView
- StateListView.KeyedStateListView<N,T> - Class in org.apache.flink.table.runtime.dataview
-
StateListView.KeyedStateListView
is an default implementation ofStateListView
whose underlying representation is a keyed state. - StateListView.NamespacedStateListView<N,T> - Class in org.apache.flink.table.runtime.dataview
-
StateListView.NamespacedStateListView
is anStateListView
whose underlying representation is a keyed and namespaced state. - StateMapView<N,EK,EV> - Class in org.apache.flink.table.runtime.dataview
-
MapView
which is implemented using state backends. - StateMapView() - Constructor for class org.apache.flink.table.runtime.dataview.StateMapView
- StateMapView.KeyedStateMapViewWithKeysNotNull<N,EK,EV> - Class in org.apache.flink.table.runtime.dataview
-
A state
MapView
which does not support nullable keys and namespace. - StateMapView.KeyedStateMapViewWithKeysNullable<N,EK,EV> - Class in org.apache.flink.table.runtime.dataview
-
A state
MapView
which supports nullable keys but does not support namespace. - StateMapView.NamespacedStateMapViewWithKeysNotNull<N,EK,EV> - Class in org.apache.flink.table.runtime.dataview
-
A state
MapView
which supports namespace but does not support nullable keys. - StateMapView.NamespacedStateMapViewWithKeysNullable<N,EK,EV> - Class in org.apache.flink.table.runtime.dataview
-
A state
MapView
which supports nullable keys and namespace. - stateRetentionTime - Variable in class org.apache.flink.table.runtime.operators.deduplicate.DeduplicateFunctionBase
- STEP_INCREMENT - Static variable in class org.apache.flink.table.runtime.util.collections.binary.BytesMap
- StreamingJoinOperator - Class in org.apache.flink.table.runtime.operators.join.stream
-
Streaming unbounded Join operator which supports INNER/LEFT/RIGHT/FULL JOIN.
- StreamingJoinOperator(InternalTypeInfo<RowData>, InternalTypeInfo<RowData>, GeneratedJoinCondition, JoinInputSideSpec, JoinInputSideSpec, boolean, boolean, boolean[], long, long) - Constructor for class org.apache.flink.table.runtime.operators.join.stream.StreamingJoinOperator
- StreamingSemiAntiJoinOperator - Class in org.apache.flink.table.runtime.operators.join.stream
-
Streaming unbounded Join operator which supports SEMI/ANTI JOIN.
- StreamingSemiAntiJoinOperator(boolean, InternalTypeInfo<RowData>, InternalTypeInfo<RowData>, GeneratedJoinCondition, JoinInputSideSpec, JoinInputSideSpec, boolean[], long, long) - Constructor for class org.apache.flink.table.runtime.operators.join.stream.StreamingSemiAntiJoinOperator
- StreamRecordCollector<T> - Class in org.apache.flink.table.runtime.util
-
Wrapper around an
Output
for wrapT
toStreamRecord
. - StreamRecordCollector(Output<StreamRecord<T>>) - Constructor for class org.apache.flink.table.runtime.util.StreamRecordCollector
- StreamRecordTimestampInserter - Class in org.apache.flink.table.runtime.operators.sink
-
Operator which sets the timestamp on the StreamRecord from the corresponding column of each row.
- StreamRecordTimestampInserter(int) - Constructor for class org.apache.flink.table.runtime.operators.sink.StreamRecordTimestampInserter
- StreamRecordTimestampInserter(int, int) - Constructor for class org.apache.flink.table.runtime.operators.sink.StreamRecordTimestampInserter
- StreamSortOperator - Class in org.apache.flink.table.runtime.operators.sort
-
Operator for stream sort.
- StreamSortOperator(InternalTypeInfo<RowData>, GeneratedRecordComparator) - Constructor for class org.apache.flink.table.runtime.operators.sort.StreamSortOperator
- STRICT - org.apache.flink.table.runtime.functions.SqlJsonUtils.PathMode
- STRING - org.apache.flink.table.runtime.functions.SqlJsonUtils.JsonQueryReturnType
- StringApproxCountDistinctAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.StringApproxCountDistinctAggFunction
- StringByteArrayConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
CharType
/VarCharType
ofbyte[]
external type. - StringByteArrayConverter() - Constructor for class org.apache.flink.table.data.conversion.StringByteArrayConverter
- StringDataSerializer - Class in org.apache.flink.table.runtime.typeutils
-
Serializer for
StringData
. - StringDataSerializer.StringDataSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils
-
Serializer configuration snapshot for compatibility and format evolution.
- StringDataSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.StringDataSerializer.StringDataSerializerSnapshot
- StringDataTypeInfo - Class in org.apache.flink.table.runtime.typeutils
-
TypeInformation for
StringData
. - StringStringConverter - Class in org.apache.flink.table.data.conversion
- StringStringConverter() - Constructor for class org.apache.flink.table.data.conversion.StringStringConverter
- StringUtf8Utils - Class in org.apache.flink.table.runtime.util
-
String utf-8 utils.
- StringUtf8Utils() - Constructor for class org.apache.flink.table.runtime.util.StringUtf8Utils
- strToMap(String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Creates a map by parsing text.
- strToMap(String, String, String) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Creates a map by parsing text.
- StructuredObjectConverter<T> - Class in org.apache.flink.table.data.conversion
-
Converter for
StructuredType
of its implementation class. - struncate(double) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
TRUNCATE
operator applied to double values. - struncate(double, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- struncate(float) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
TRUNCATE
operator applied to double values. - struncate(float, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- struncate(int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
TRUNCATE
operator applied to int values. - struncate(int, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- struncate(long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
TRUNCATE
operator applied to long values. - struncate(long, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- struncate(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
SQL
TRUNCATE
operator applied to BigDecimal values. - struncate(DecimalData, int) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- subString(String, long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- subString(String, long, long) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- substringSQL(BinaryStringData, int) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- substringSQL(BinaryStringData, int, int) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- subtaskReset(int, long) - Method in class org.apache.flink.table.runtime.operators.dynamicfiltering.DynamicFilteringDataCollectorOperatorCoordinator
- subtract(DecimalData, DecimalData, int, int) - Static method in class org.apache.flink.table.data.DecimalDataUtils
- swap(int, int) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- swap(int, int, int, int) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
- swapKey(MemorySegment, int, MemorySegment, int) - Method in interface org.apache.flink.table.runtime.generated.NormalizedKeyComputer
-
Swaps two normalized keys in respective
MemorySegment
. - SyncStateWindowProcessor<W> - Interface in org.apache.flink.table.runtime.operators.window.tvf.common
-
A processor that processes elements for windows.
- SyncStateWindowProcessor.SyncStateContext<W> - Interface in org.apache.flink.table.runtime.operators.window.tvf.common
-
Information available in an invocation of methods of
SyncStateWindowProcessor
. - SyncStateWindowRankProcessor - Class in org.apache.flink.table.runtime.operators.rank.window.processors
-
A rowtime window rank processor.
- SyncStateWindowRankProcessor(TypeSerializer<RowData>, GeneratedRecordComparator, TypeSerializer<RowData>, WindowBuffer.Factory, long, long, boolean, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.rank.window.processors.SyncStateWindowRankProcessor
T
- TableAggregateWindowOperator<K,W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.operator
-
A
WindowOperator
for grouped and windowed table aggregates. - TableAggregateWindowOperatorBuilder(GeneratedNamespaceTableAggsHandleFunction<?>, WindowOperatorBuilder) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder.TableAggregateWindowOperatorBuilder
- TableAggregateWindowOperatorBuilder(NamespaceTableAggsHandleFunction<?>, WindowOperatorBuilder) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder.TableAggregateWindowOperatorBuilder
- TableAggsHandleFunction - Interface in org.apache.flink.table.runtime.generated
-
The base class for handling table aggregate functions.
- tableFieldsCount - Variable in class org.apache.flink.table.runtime.operators.join.lookup.LookupJoinRunner
- TableFunctionCollector<T> - Class in org.apache.flink.table.runtime.collector
-
The basic implementation of collector for
TableFunction
. - TableFunctionCollector() - Constructor for class org.apache.flink.table.runtime.collector.TableFunctionCollector
- TableFunctionResultFuture<T> - Class in org.apache.flink.table.runtime.collector
-
The basic implementation of collector for
ResultFuture
in table joining. - TableFunctionResultFuture() - Constructor for class org.apache.flink.table.runtime.collector.TableFunctionResultFuture
- TableOperatorWrapper<OP extends org.apache.flink.streaming.api.operators.StreamOperator<org.apache.flink.table.data.RowData>> - Class in org.apache.flink.table.runtime.operators.multipleinput
-
This class handles the close, endInput and other related logic of a
StreamOperator
. - TableOperatorWrapper(StreamOperatorFactory<RowData>, String, List<TypeInformation<?>>, TypeInformation<?>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- TableOperatorWrapper.Edge - Class in org.apache.flink.table.runtime.operators.multipleinput
-
The edge connecting two
TableOperatorWrapper
s. - TableOperatorWrapperGenerator - Class in org.apache.flink.table.runtime.operators.multipleinput
-
A generator that generates a
TableOperatorWrapper
graph from a graph ofTransformation
. - TableOperatorWrapperGenerator(List<Transformation<?>>, Transformation<?>) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- TableOperatorWrapperGenerator(List<Transformation<?>>, Transformation<?>, int[]) - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapperGenerator
- TableStreamOperator<OUT> - Class in org.apache.flink.table.runtime.operators
-
Table operator to invoke close always.
- TableStreamOperator() - Constructor for class org.apache.flink.table.runtime.operators.TableStreamOperator
- TableStreamOperator(StreamOperatorParameters<OUT>) - Constructor for class org.apache.flink.table.runtime.operators.TableStreamOperator
- TableStreamOperator.ContextImpl - Class in org.apache.flink.table.runtime.operators
-
Information available in an invocation of processElement.
- tan(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- tanh(DecimalData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
-
Calculates the hyperbolic tangent of a big decimal number.
- TemporalProcessTimeJoinOperator - Class in org.apache.flink.table.runtime.operators.join.temporal
-
The operator to temporal join a stream on processing time.
- TemporalProcessTimeJoinOperator(InternalTypeInfo<RowData>, GeneratedJoinCondition, long, long, boolean) - Constructor for class org.apache.flink.table.runtime.operators.join.temporal.TemporalProcessTimeJoinOperator
- TemporalRowTimeJoinOperator - Class in org.apache.flink.table.runtime.operators.join.temporal
-
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.
- TemporalRowTimeJoinOperator(InternalTypeInfo<RowData>, InternalTypeInfo<RowData>, GeneratedJoinCondition, int, int, long, long, boolean) - Constructor for class org.apache.flink.table.runtime.operators.join.temporal.TemporalRowTimeJoinOperator
- test(Throwable) - Method in class org.apache.flink.table.runtime.operators.calc.async.RetryPredicates.AnyExceptionStrategy
- test(Collection<RowData>) - Method in class org.apache.flink.table.runtime.operators.calc.async.RetryPredicates.EmptyResponseResultStrategy
- TimeApproxCountDistinctAggFunction() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.TimeApproxCountDistinctAggFunction
- TimeLocalTimeConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
TimeType
ofLocalTime
external type. - TimeLocalTimeConverter() - Constructor for class org.apache.flink.table.data.conversion.TimeLocalTimeConverter
- TimeLongConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
TimeType
ofLong
external type. - TimeLongConverter() - Constructor for class org.apache.flink.table.data.conversion.TimeLongConverter
- TIMEOUT_AFTER_INTERRUPT_MS - Static variable in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
- timerService - Variable in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator.ContextImpl
- timerService - Variable in class org.apache.flink.table.runtime.operators.TableStreamOperator.ContextImpl
- timerService() - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator.ContextImpl
- timerService() - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator.ContextImpl
- timestamp() - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator.ContextImpl
- timestamp() - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator.ContextImpl
- TimestampApproxCountDistinctAggFunction(TimestampType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.TimestampApproxCountDistinctAggFunction
- TimestampConverter(int) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.TimestampConverter
- TimestampDataConverter(int) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.TimestampDataConverter
- TimestampDataSerializer - Class in org.apache.flink.table.runtime.typeutils
-
Serializer for
TimestampData
. - TimestampDataSerializer(int) - Constructor for class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer
- TimestampDataSerializer.TimestampDataSerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils
-
TypeSerializerSnapshot
forTimestampDataSerializer
. - TimestampDataSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer.TimestampDataSerializerSnapshot
- TimestampDataTypeInfo - Class in org.apache.flink.table.runtime.typeutils
-
TypeInformation for
TimestampData
. - TimestampDataTypeInfo(int) - Constructor for class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- TimestampLocalDateTimeConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
TimestampType
ofLocalDateTime
external type. - TimestampLocalDateTimeConverter() - Constructor for class org.apache.flink.table.data.conversion.TimestampLocalDateTimeConverter
- TimestampLtzApproxCountDistinctAggFunction(LocalZonedTimestampType) - Constructor for class org.apache.flink.table.runtime.functions.aggregate.BatchApproxCountDistinctAggFunctions.TimestampLtzApproxCountDistinctAggFunction
- TimestampLtzConverter(int) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.TimestampLtzConverter
- TimestampTimestampConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
TimestampType
ofTimestamp
external type. - TimestampTimestampConverter() - Constructor for class org.apache.flink.table.data.conversion.TimestampTimestampConverter
- TimeTimeConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
TimeType
ofTime
external type. - TimeTimeConverter() - Constructor for class org.apache.flink.table.data.conversion.TimeTimeConverter
- TimeWindow - Class in org.apache.flink.table.runtime.operators.window
- TimeWindow(long, long) - Constructor for class org.apache.flink.table.runtime.operators.window.TimeWindow
- TimeWindow.Serializer - Class in org.apache.flink.table.runtime.operators.window
-
The serializer used to write the TimeWindow type.
- TimeWindow.Serializer.TimeWindowSerializerSnapshot - Class in org.apache.flink.table.runtime.operators.window
-
Serializer configuration snapshot for compatibility and format evolution.
- TimeWindowSerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.operators.window.TimeWindow.Serializer.TimeWindowSerializerSnapshot
- TimeWindowUtil - Class in org.apache.flink.table.runtime.util
-
Time util to deals window start and end in different timezone.
- TimeWindowUtil() - Constructor for class org.apache.flink.table.runtime.util.TimeWindowUtil
- toBase64(byte[]) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- toBase64(BinaryStringData) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- toBinaryArray(ArrayData) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer
- toBinaryMap(MapData) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer
- toBinaryRow(BinaryRowData) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer
- toBinaryRow(RowData) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer
-
Convert
RowData
intoBinaryRowData
. - toBinaryRow(T) - Method in class org.apache.flink.table.runtime.typeutils.AbstractRowDataSerializer
-
Convert a
RowData
to aBinaryRowData
. - toBoolean(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Parse a
StringData
to boolean. - toByte(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- toDate(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- toDecimal(BinaryStringData, int, int) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Parses a
BinaryStringData
toDecimalData
. - toDouble(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- toEpochMills(long, ZoneId) - Static method in class org.apache.flink.table.runtime.util.TimeWindowUtil
-
Convert a timestamp mills with the given timezone to epoch mills.
- toEpochMillsForTimer(long, ZoneId) - Static method in class org.apache.flink.table.runtime.util.TimeWindowUtil
-
Get a timer time according to the timestamp mills and the given shift timezone.
- toExternal(I) - Method in interface org.apache.flink.table.data.conversion.DataStructureConverter
-
Converts to external data structure.
- toExternal(I) - Method in class org.apache.flink.table.data.conversion.IdentityConverter
- toExternal(Internal) - Method in class org.apache.flink.table.data.util.DataFormatConverters.DataFormatConverter
-
Convert a internal data format to its external(Java) equivalent while automatically handling nulls.
- toExternal(Integer) - Method in class org.apache.flink.table.data.conversion.DateDateConverter
- toExternal(Integer) - Method in class org.apache.flink.table.data.conversion.DateLocalDateConverter
- toExternal(Integer) - Method in class org.apache.flink.table.data.conversion.TimeLocalTimeConverter
- toExternal(Integer) - Method in class org.apache.flink.table.data.conversion.TimeLongConverter
- toExternal(Integer) - Method in class org.apache.flink.table.data.conversion.TimeTimeConverter
- toExternal(Integer) - Method in class org.apache.flink.table.data.conversion.YearMonthIntervalPeriodConverter
- toExternal(Long) - Method in class org.apache.flink.table.data.conversion.DayTimeIntervalDurationConverter
- toExternal(ArrayData) - Method in class org.apache.flink.table.data.conversion.ArrayBooleanArrayConverter
- toExternal(ArrayData) - Method in class org.apache.flink.table.data.conversion.ArrayByteArrayConverter
- toExternal(ArrayData) - Method in class org.apache.flink.table.data.conversion.ArrayDoubleArrayConverter
- toExternal(ArrayData) - Method in class org.apache.flink.table.data.conversion.ArrayFloatArrayConverter
- toExternal(ArrayData) - Method in class org.apache.flink.table.data.conversion.ArrayIntArrayConverter
- toExternal(ArrayData) - Method in class org.apache.flink.table.data.conversion.ArrayListConverter
- toExternal(ArrayData) - Method in class org.apache.flink.table.data.conversion.ArrayLongArrayConverter
- toExternal(ArrayData) - Method in class org.apache.flink.table.data.conversion.ArrayObjectArrayConverter
- toExternal(ArrayData) - Method in class org.apache.flink.table.data.conversion.ArrayShortArrayConverter
- toExternal(DecimalData) - Method in class org.apache.flink.table.data.conversion.DecimalBigDecimalConverter
- toExternal(MapData) - Method in class org.apache.flink.table.data.conversion.MapMapConverter
- toExternal(RawValueData<T>) - Method in class org.apache.flink.table.data.conversion.RawByteArrayConverter
- toExternal(RawValueData<T>) - Method in class org.apache.flink.table.data.conversion.RawObjectConverter
- toExternal(RowData) - Method in class org.apache.flink.table.data.conversion.RowRowConverter
- toExternal(RowData) - Method in class org.apache.flink.table.data.conversion.StructuredObjectConverter
- toExternal(RowData, int) - Method in class org.apache.flink.table.data.util.DataFormatConverters.DataFormatConverter
-
Given a internalType row, convert the value at column `column` to its external(Java) equivalent.
- toExternal(StringData) - Method in class org.apache.flink.table.data.conversion.StringByteArrayConverter
- toExternal(StringData) - Method in class org.apache.flink.table.data.conversion.StringStringConverter
- toExternal(TimestampData) - Method in class org.apache.flink.table.data.conversion.LocalZonedTimestampInstantConverter
- toExternal(TimestampData) - Method in class org.apache.flink.table.data.conversion.LocalZonedTimestampIntConverter
- toExternal(TimestampData) - Method in class org.apache.flink.table.data.conversion.LocalZonedTimestampLongConverter
- toExternal(TimestampData) - Method in class org.apache.flink.table.data.conversion.LocalZonedTimestampTimestampConverter
- toExternal(TimestampData) - Method in class org.apache.flink.table.data.conversion.TimestampLocalDateTimeConverter
- toExternal(TimestampData) - Method in class org.apache.flink.table.data.conversion.TimestampTimestampConverter
- toExternalOrNull(I) - Method in interface org.apache.flink.table.data.conversion.DataStructureConverter
-
Converts to external data structure or
null
. - toFloat(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- toInt(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Parses this BinaryStringData to Int.
- toInternal(boolean[]) - Method in class org.apache.flink.table.data.conversion.ArrayBooleanArrayConverter
- toInternal(byte[]) - Method in class org.apache.flink.table.data.conversion.ArrayByteArrayConverter
- toInternal(byte[]) - Method in class org.apache.flink.table.data.conversion.RawByteArrayConverter
- toInternal(byte[]) - Method in class org.apache.flink.table.data.conversion.StringByteArrayConverter
- toInternal(double[]) - Method in class org.apache.flink.table.data.conversion.ArrayDoubleArrayConverter
- toInternal(float[]) - Method in class org.apache.flink.table.data.conversion.ArrayFloatArrayConverter
- toInternal(int[]) - Method in class org.apache.flink.table.data.conversion.ArrayIntArrayConverter
- toInternal(long[]) - Method in class org.apache.flink.table.data.conversion.ArrayLongArrayConverter
- toInternal(short[]) - Method in class org.apache.flink.table.data.conversion.ArrayShortArrayConverter
- toInternal(E) - Method in interface org.apache.flink.table.data.conversion.DataStructureConverter
-
Converts to internal data structure.
- toInternal(E[]) - Method in class org.apache.flink.table.data.conversion.ArrayObjectArrayConverter
- toInternal(External) - Method in class org.apache.flink.table.data.util.DataFormatConverters.DataFormatConverter
-
Converts a external(Java) data format to its internal equivalent while automatically handling nulls.
- toInternal(I) - Method in class org.apache.flink.table.data.conversion.IdentityConverter
- toInternal(Integer) - Method in class org.apache.flink.table.data.conversion.LocalZonedTimestampIntConverter
- toInternal(Long) - Method in class org.apache.flink.table.data.conversion.LocalZonedTimestampLongConverter
- toInternal(Long) - Method in class org.apache.flink.table.data.conversion.TimeLongConverter
- toInternal(String) - Method in class org.apache.flink.table.data.conversion.StringStringConverter
- toInternal(BigDecimal) - Method in class org.apache.flink.table.data.conversion.DecimalBigDecimalConverter
- toInternal(Date) - Method in class org.apache.flink.table.data.conversion.DateDateConverter
- toInternal(Time) - Method in class org.apache.flink.table.data.conversion.TimeTimeConverter
- toInternal(Timestamp) - Method in class org.apache.flink.table.data.conversion.LocalZonedTimestampTimestampConverter
- toInternal(Timestamp) - Method in class org.apache.flink.table.data.conversion.TimestampTimestampConverter
- toInternal(Duration) - Method in class org.apache.flink.table.data.conversion.DayTimeIntervalDurationConverter
- toInternal(Instant) - Method in class org.apache.flink.table.data.conversion.LocalZonedTimestampInstantConverter
- toInternal(LocalDate) - Method in class org.apache.flink.table.data.conversion.DateLocalDateConverter
- toInternal(LocalDateTime) - Method in class org.apache.flink.table.data.conversion.TimestampLocalDateTimeConverter
- toInternal(LocalTime) - Method in class org.apache.flink.table.data.conversion.TimeLocalTimeConverter
- toInternal(Period) - Method in class org.apache.flink.table.data.conversion.YearMonthIntervalPeriodConverter
- toInternal(List<E>) - Method in class org.apache.flink.table.data.conversion.ArrayListConverter
- toInternal(Map<K, V>) - Method in class org.apache.flink.table.data.conversion.MapMapConverter
- toInternal(Row) - Method in class org.apache.flink.table.data.conversion.RowRowConverter
- toInternal(T) - Method in class org.apache.flink.table.data.conversion.RawObjectConverter
- toInternal(T) - Method in class org.apache.flink.table.data.conversion.StructuredObjectConverter
- toInternalOrNull(E) - Method in interface org.apache.flink.table.data.conversion.DataStructureConverter
-
Converts to internal data structure or
null
. - toLogicalType() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- toLong(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Parses this BinaryStringData to Long.
- TopNBuffer - Class in org.apache.flink.table.runtime.operators.rank
-
TopNBuffer stores mapping from sort key to records list, sortKey is RowData type, each record is RowData type.
- TopNBuffer(Comparator<RowData>, Supplier<Collection<RowData>>) - Constructor for class org.apache.flink.table.runtime.operators.rank.TopNBuffer
- TopNBufferCacheRemovalListener<V> - Class in org.apache.flink.table.runtime.operators.rank
-
A common cache removal listener for rank node.
- TopNBufferCacheRemovalListener(KeyContext, BiConsumerWithException<RowData, V, Exception>) - Constructor for class org.apache.flink.table.runtime.operators.rank.TopNBufferCacheRemovalListener
- topNFunction - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- TopNRecordsCombiner - Class in org.apache.flink.table.runtime.operators.rank.window.combines
-
An implementation of
RecordsCombiner
that save topN records of incremental input records into the window state. - TopNRecordsCombiner(WindowTimerService<Long>, StateKeyContext, WindowMapState<Long, List<RowData>>, Comparator<RowData>, KeySelector<RowData, RowData>, long, TypeSerializer<RowData>, boolean) - Constructor for class org.apache.flink.table.runtime.operators.rank.window.combines.TopNRecordsCombiner
- TopNRecordsCombiner.Factory - Class in org.apache.flink.table.runtime.operators.rank.window.combines
-
Factory to create
TopNRecordsCombiner
. - topologicalOrderingOperators - Variable in class org.apache.flink.table.runtime.operators.multipleinput.MultipleInputStreamOperatorBase
-
all operator as topological ordering in this multiple input operator.
- toRowFieldNames() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
-
Deprecated.
TypeInformation
should just be a thin wrapper of a serializer. This method only exists for legacy code. It is recommended to use theRowType
instead for logical operations. - toRowFieldTypes() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
-
Deprecated.
TypeInformation
should just be a thin wrapper of a serializer. This method only exists for legacy code. It is recommended to use theRowType
instead for logical operations. - toRowSerializer() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- toRowSize() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
-
Deprecated.
TypeInformation
should just be a thin wrapper of a serializer. This method only exists for legacy code. It is recommended to use theRowType
instead for logical operations. - toRowType() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- toSerializer() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- toShort(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- toString() - Method in class org.apache.flink.table.data.BoxedWrapperRowData
- toString() - Method in class org.apache.flink.table.runtime.functions.DefaultExpressionEvaluator
- toString() - Method in class org.apache.flink.table.runtime.groupwindow.AbstractWindowProperty
-
Deprecated.
- toString() - Method in class org.apache.flink.table.runtime.groupwindow.ProctimeAttribute
-
Deprecated.
- toString() - Method in class org.apache.flink.table.runtime.groupwindow.RowtimeAttribute
-
Deprecated.
- toString() - Method in class org.apache.flink.table.runtime.groupwindow.SliceEnd
-
Deprecated.
- toString() - Method in class org.apache.flink.table.runtime.groupwindow.WindowEnd
-
Deprecated.
- toString() - Method in class org.apache.flink.table.runtime.groupwindow.WindowReference
-
Deprecated.
- toString() - Method in class org.apache.flink.table.runtime.groupwindow.WindowStart
-
Deprecated.
- toString() - Method in enum org.apache.flink.table.runtime.operators.join.FlinkJoinType
- toString() - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinInputSideSpec
- toString() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSelectionSpec
- toString() - Method in class org.apache.flink.table.runtime.operators.multipleinput.input.InputSpec
- toString() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper.Edge
- toString() - Method in class org.apache.flink.table.runtime.operators.multipleinput.TableOperatorWrapper
- toString() - Method in class org.apache.flink.table.runtime.operators.rank.ConstantRankRange
- toString() - Method in class org.apache.flink.table.runtime.operators.rank.ConstantRankRangeWithoutEnd
- toString() - Method in class org.apache.flink.table.runtime.operators.rank.VariableRankRange
- toString() - Method in class org.apache.flink.table.runtime.operators.window.CountWindow
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountSlidingWindowAssigner
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CountTumblingWindowAssigner
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.GroupWindowAssigner
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SessionWindowAssigner
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.TumblingWindowAssigner
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.MergingWindowSet
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.CountElement
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ElementTriggers.EveryElement
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowEarlyAndLate
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowNoLate
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindow
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindowNoLate
- toString() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterFirstElementPeriodic
- toString() - Method in class org.apache.flink.table.runtime.operators.window.TimeWindow
- toString() - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- toString() - Method in class org.apache.flink.table.runtime.partitioner.BinaryHashPartitioner
- toString() - Method in class org.apache.flink.table.runtime.partitioner.RowDataCustomStreamPartitioner
- toString() - Method in class org.apache.flink.table.runtime.script.ScriptTransformIOInfo
- toString() - Method in class org.apache.flink.table.runtime.typeutils.BigDecimalTypeInfo
- toString() - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataTypeInfo
- toString() - Method in class org.apache.flink.table.runtime.typeutils.ExternalTypeInfo
- toString() - Method in class org.apache.flink.table.runtime.typeutils.InternalTypeInfo
- toString() - Method in class org.apache.flink.table.runtime.typeutils.LegacyInstantTypeInfo
- toString() - Method in class org.apache.flink.table.runtime.typeutils.LegacyLocalDateTimeTypeInfo
- toString() - Method in class org.apache.flink.table.runtime.typeutils.LegacyTimestampTypeInfo
- toString() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializer
- toString() - Method in class org.apache.flink.table.runtime.typeutils.SortedMapTypeInfo
- toString() - Method in class org.apache.flink.table.runtime.typeutils.StringDataTypeInfo
- toString() - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataTypeInfo
- toString(List<String>) - Method in class org.apache.flink.table.runtime.operators.rank.ConstantRankRange
- toString(List<String>) - Method in class org.apache.flink.table.runtime.operators.rank.ConstantRankRangeWithoutEnd
- toString(List<String>) - Method in interface org.apache.flink.table.runtime.operators.rank.RankRange
- toString(List<String>) - Method in class org.apache.flink.table.runtime.operators.rank.VariableRankRange
- totalNumBuffers - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
The total reserved number of memory segments available to the hash join.
- toTime(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- toTimestamp(BinaryStringData, int) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Used by
CAST(x as TIMESTAMP)
. - toTimestamp(BinaryStringData, int, TimeZone) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Used by
CAST(x as TIMESTAMP_LTZ)
. - ToTimestampLtzFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.TO_TIMESTAMP_LTZ
. - ToTimestampLtzFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.ToTimestampLtzFunction
- toUtcTimestampMills(long, ZoneId) - Static method in class org.apache.flink.table.runtime.util.TimeWindowUtil
-
Convert a epoch mills to timestamp mills which can describe a locate date time.
- TranslateFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.TRANSLATE
. - TranslateFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.TranslateFunction
- trigger - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- Trigger<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A
Trigger
determines when a pane of a window should be evaluated to emit the results for that part of the window. - Trigger() - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.Trigger
- Trigger.OnMergeContext - Interface in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
Extension of
Trigger.TriggerContext
that is given toTrigger.onMerge(Window, OnMergeContext)
. - Trigger.TriggerContext - Interface in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A context object that is given to
Trigger
methods to allow them to register timer callbacks and deal with state. - triggering(Trigger<?>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- triggerReload() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.ReloadTriggerContext
- triggerTime(W) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.WindowTrigger
-
Returns the trigger time of the window, this should be called after TriggerContext initialized.
- trim(BinaryStringData, boolean, boolean, BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- trim(BinaryStringData, BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Walk each character of current string from both ends, remove the character if it is in trim string.
- trimLeft(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- trimLeft(BinaryStringData, BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Walk each character of current string from left end, remove the character if it is in trim string.
- trimRight(BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- trimRight(BinaryStringData, BinaryStringData) - Static method in class org.apache.flink.table.data.binary.BinaryStringDataUtil
-
Walk each character of current string from right end, remove the character if it is in trim string.
- TRUE_STRING - Static variable in class org.apache.flink.table.data.binary.BinaryStringDataUtil
- trueRsd() - Method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HyperLogLogPlusPlus
-
The
rsd
of HLL++ is always equal to or better than thersd
requested. - tryDistinctBuildRow - Variable in class org.apache.flink.table.runtime.hashtable.BaseHybridHashTable
-
Try to make the buildSide rows distinct.
- tryOptimizeAdaptiveJoin(OperatorsFinished, StreamGraphContext, ImmutableStreamNode, List<ImmutableStreamEdge>, AdaptiveJoin) - Method in class org.apache.flink.table.runtime.strategy.AdaptiveBroadcastJoinOptimizationStrategy
- tryOptimizeAdaptiveJoin(OperatorsFinished, StreamGraphContext, ImmutableStreamNode, List<ImmutableStreamEdge>, AdaptiveJoin) - Method in class org.apache.flink.table.runtime.strategy.PostProcessAdaptiveJoinStrategy
- tryProbe(RowData) - Method in class org.apache.flink.table.runtime.hashtable.BinaryHashTable
-
Find matched build side rows for a probe row.
- tryProbe(RowData) - Method in class org.apache.flink.table.runtime.hashtable.LongHybridHashTable
- ttlConfig - Variable in class org.apache.flink.table.runtime.operators.aggregate.GroupAggFunctionBase
-
State idle retention config.
- ttlConfig - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction.AbstractTopNHelper
- ttlConfig - Variable in class org.apache.flink.table.runtime.operators.rank.AbstractTopNFunction
- tumble(Duration) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- tumbling(int, ZoneId, Duration) - Static method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners
-
Creates a tumbling window
SliceAssigner
that assigns elements to slices of tumbling windows. - TumblingWindowAssigner - Class in org.apache.flink.table.runtime.operators.window.groupwindow.assigners
-
A
GroupWindowAssigner
that windows elements into fixed-size windows based on the timestamp of the elements. - TumblingWindowAssigner(long, long, boolean) - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.TumblingWindowAssigner
- TupleConverter(Class<Tuple>, DataType[]) - Constructor for class org.apache.flink.table.data.util.DataFormatConverters.TupleConverter
- type - Variable in class org.apache.flink.table.runtime.groupwindow.WindowReference
-
Deprecated.
- TypeCheckUtils - Class in org.apache.flink.table.runtime.typeutils
-
Utils for type.
- TypeCheckUtils() - Constructor for class org.apache.flink.table.runtime.typeutils.TypeCheckUtils
- typeInfo - Variable in class org.apache.flink.table.runtime.operators.deduplicate.DeduplicateFunctionBase
- TypeInfoDataTypeConverter - Class in org.apache.flink.table.runtime.types
-
Deprecated.Use
InternalTypeInfo.of(LogicalType)
instead ifTypeInformation
is really required. In many cases,InternalSerializers.create(LogicalType)
should be sufficient. - TypeInfoDataTypeConverter() - Constructor for class org.apache.flink.table.runtime.types.TypeInfoDataTypeConverter
-
Deprecated.
- TypeInfoLogicalTypeConverter - Class in org.apache.flink.table.runtime.types
-
Deprecated.
- TypeInfoLogicalTypeConverter() - Constructor for class org.apache.flink.table.runtime.types.TypeInfoLogicalTypeConverter
-
Deprecated.
- TypeOfFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.TYPE_OF
. - TypeOfFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.TypeOfFunction
U
- UnalignedWindowTableFunctionOperator - Class in org.apache.flink.table.runtime.operators.window.tvf.operator
-
The operator for unaligned window table function.
- UnalignedWindowTableFunctionOperator(GroupWindowAssigner<TimeWindow>, TypeSerializer<TimeWindow>, TypeSerializer<RowData>, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.operator.UnalignedWindowTableFunctionOperator
- UnboundedFollowingOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The UnboundedFollowing window frame.
- UnboundedFollowingOverFrame(RowType, GeneratedAggsHandleFunction) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.UnboundedFollowingOverFrame
- UnboundedOverWindowFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The unbounded window frame calculates frames with the following SQL forms: ...
- UnboundedOverWindowFrame(GeneratedAggsHandleFunction, RowType) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.UnboundedOverWindowFrame
- UnboundedPrecedingOverFrame - Class in org.apache.flink.table.runtime.operators.over.frame
-
The UnboundedPreceding window frame.
- UnboundedPrecedingOverFrame(GeneratedAggsHandleFunction) - Constructor for class org.apache.flink.table.runtime.operators.over.frame.UnboundedPrecedingOverFrame
- UnhexFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.UNHEX
. - UnhexFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.UnhexFunction
- UnionStreamOperator - Class in org.apache.flink.table.runtime.operators.multipleinput
-
A special operator which collects all inputs' records and forwards them in
MultipleInputStreamOperatorBase
. - UnionStreamOperator() - Constructor for class org.apache.flink.table.runtime.operators.multipleinput.UnionStreamOperator
- UNKNOWN - org.apache.flink.table.runtime.functions.SqlJsonUtils.PathMode
- UnnestRowsFunction - Class in org.apache.flink.table.runtime.functions.table
-
Flattens ARRAY, MAP, and MULTISET using a table function.
- UnnestRowsFunction() - Constructor for class org.apache.flink.table.runtime.functions.table.UnnestRowsFunction
- UnnestRowsFunction.CollectionUnnestTableFunction - Class in org.apache.flink.table.runtime.functions.table
-
Table function that unwraps the elements of a collection (array or multiset).
- UnnestRowsFunction.MapUnnestTableFunction - Class in org.apache.flink.table.runtime.functions.table
-
Table function that unwraps the elements of a map.
- unregisterCache(String) - Method in class org.apache.flink.table.runtime.functions.table.lookup.LookupCacheManager
-
Release the cache with the given identifier from the manager.
- UNSAFE - Static variable in class org.apache.flink.table.data.binary.BinaryRowDataUtil
- UnsliceAssigner<W extends Window> - Interface in org.apache.flink.table.runtime.operators.window.tvf.unslicing
-
A
UnsliceAssigner
assigns each element into a single window and not divides the window into finite number of non-overlapping slice. - UnsliceAssigners - Class in org.apache.flink.table.runtime.operators.window.tvf.unslicing
-
Utilities to create
UnsliceAssigner
s. - UnsliceAssigners() - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners
- UnsliceAssigners.SessionUnsliceAssigner - Class in org.apache.flink.table.runtime.operators.window.tvf.unslicing
-
The
UnsliceAssigner
for session windows. - UnsliceAssigners.WindowedUnsliceAssigner - Class in org.apache.flink.table.runtime.operators.window.tvf.unslicing
-
The
UnsliceAssigner
for elements have been merged into unslicing windows and attached window start and end timestamps. - UnsliceSyncStateWindowAggProcessor - Class in org.apache.flink.table.runtime.operators.aggregate.window.processors
-
An window aggregate processor implementation which works for
UnsliceAssigner
, e.g. - UnsliceSyncStateWindowAggProcessor(GeneratedNamespaceAggsHandleFunction<TimeWindow>, UnsliceAssigner<TimeWindow>, TypeSerializer<RowData>, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.processors.UnsliceSyncStateWindowAggProcessor
- UnslicingSyncStateWindowProcessor<W> - Interface in org.apache.flink.table.runtime.operators.window.tvf.unslicing
-
The
UnslicingSyncStateWindowProcessor
is an optimized processing for unaligned windows. - UnslicingWindowTimerServiceImpl - Class in org.apache.flink.table.runtime.operators.window.tvf.unslicing
-
A
WindowTimerService
for unslicing window. - UnslicingWindowTimerServiceImpl(InternalTimerService<TimeWindow>, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnslicingWindowTimerServiceImpl
- UnsupportedStateDataViewStore - Class in org.apache.flink.table.runtime.dataview
- UnsupportedStateDataViewStore(RuntimeContext) - Constructor for class org.apache.flink.table.runtime.dataview.UnsupportedStateDataViewStore
- UpdatableRowData - Class in org.apache.flink.table.data
-
An implementation of
RowData
which is backed by aRowData
and an updated Java object array. - UpdatableRowData(RowData, int) - Constructor for class org.apache.flink.table.data.UpdatableRowData
- UpdatableTopNFunction - Class in org.apache.flink.table.runtime.operators.rank
-
A TopN function could handle updating stream.
- UpdatableTopNFunction(StateTtlConfig, InternalTypeInfo<RowData>, RowDataKeySelector, GeneratedRecordComparator, RowDataKeySelector, RankType, RankRange, boolean, boolean, long) - Constructor for class org.apache.flink.table.runtime.operators.rank.UpdatableTopNFunction
- update(T) - Method in class org.apache.flink.table.runtime.operators.metrics.SimpleGauge
- update(W, RowData) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowValueState
-
Update the state with the given value under current key and the given window.
- updateAccumulatorsState(RowData) - Method in class org.apache.flink.table.runtime.operators.aggregate.utils.GroupAggHelper
- updateByHashcode(HllBuffer, long) - Method in class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.HyperLogLogPlusPlus
-
Update the HLL++ buffer.
- updateCache() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.CacheLoader
- updateCache() - Method in class org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat.InputFormatCacheLoader
- updateDeduplicateResult(boolean, boolean, RowData, RowData, Collector<RowData>) - Static method in class org.apache.flink.table.runtime.operators.deduplicate.utils.DeduplicateFunctionHelper
-
Collect the updated result for duplicate row.
- updateNumOfAssociations(RowData, int) - Method in interface org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state.OuterJoinRecordAsyncStateView
-
Updates the number of associations belongs to the record.
- updateNumOfAssociations(RowData, int) - Method in interface org.apache.flink.table.runtime.operators.join.stream.state.OuterJoinRecordStateView
-
Updates the number of associations belongs to the record.
- updateNumOfAssociationsInOuterSide(OUTER_STATE_VIEW, RowData, int) - Method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinHelper
- updateState(RowData) - Method in class org.apache.flink.table.runtime.operators.deduplicate.utils.RowTimeDeduplicateFunctionHelper
- updateState(RowData, List<RowData>) - Method in class org.apache.flink.table.runtime.operators.rank.utils.AppendOnlyTopNHelper
- UrlDecodeFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.URL_DECODE
. - UrlDecodeFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.UrlDecodeFunction
- UrlEncodeFunction - Class in org.apache.flink.table.runtime.functions.scalar
-
Implementation of
BuiltInFunctionDefinitions.URL_ENCODE
. - UrlEncodeFunction(SpecializedFunction.SpecializedContext) - Constructor for class org.apache.flink.table.runtime.functions.scalar.UrlEncodeFunction
- used - Variable in class org.apache.flink.table.runtime.util.collections.ByteHashSet
- used - Variable in class org.apache.flink.table.runtime.util.collections.OptimizableHashSet
-
Used array for dense mode.
- useDayLightSaving - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
-
The shift timezone is using DayLightSaving time or not.
- useSplittableTimers() - Method in class org.apache.flink.table.runtime.operators.AsyncStateTableStreamOperator
- useSplittableTimers() - Method in class org.apache.flink.table.runtime.operators.join.temporal.BaseTwoInputStreamOperatorWithStateRetention
- useSplittableTimers() - Method in class org.apache.flink.table.runtime.operators.TableStreamOperator
- useSplittableTimers() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- uuid() - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
- uuid(byte[]) - Static method in class org.apache.flink.table.runtime.functions.SqlFunctionUtils
V
- value(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowValueState
-
Returns the current value for the state under current key and the given window.
- valueCount - Variable in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction.PercentileAccumulator
- valueOf(String) - Static method in enum org.apache.flink.table.runtime.functions.SqlJsonUtils.JsonQueryReturnType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.runtime.functions.SqlJsonUtils.PathMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.runtime.operators.join.FlinkJoinType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.runtime.operators.join.HashJoinType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.runtime.operators.rank.RankType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.flink.table.runtime.functions.SqlJsonUtils.JsonQueryReturnType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.runtime.functions.SqlJsonUtils.PathMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.runtime.operators.join.FlinkJoinType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.runtime.operators.join.HashJoinType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.runtime.operators.rank.RankType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values(W) - Method in class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
-
Returns all the values in the state.
- ValuesInputFormat - Class in org.apache.flink.table.runtime.operators.values
-
Generated ValuesInputFormat.
- ValuesInputFormat(GeneratedInput<GenericInputFormat<RowData>>, InternalTypeInfo<RowData>) - Constructor for class org.apache.flink.table.runtime.operators.values.ValuesInputFormat
- valueToOrderMap - Variable in class org.apache.flink.table.runtime.functions.aggregate.FirstValueWithRetractAggFunction.FirstValueWithRetractAccumulator
- valueToOrderMap - Variable in class org.apache.flink.table.runtime.functions.aggregate.LastValueWithRetractAggFunction.LastValueWithRetractAccumulator
- valueType - Variable in class org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction
- VariableRankRange - Class in org.apache.flink.table.runtime.operators.rank
-
changing rank limit depends on input.
- VariableRankRange(int) - Constructor for class org.apache.flink.table.runtime.operators.rank.VariableRankRange
- visit(AtomicDataType) - Method in class org.apache.flink.table.runtime.types.DataTypePrecisionFixer
- visit(CollectionDataType) - Method in class org.apache.flink.table.runtime.types.DataTypePrecisionFixer
- visit(FieldsDataType) - Method in class org.apache.flink.table.runtime.types.DataTypePrecisionFixer
- visit(KeyValueDataType) - Method in class org.apache.flink.table.runtime.types.DataTypePrecisionFixer
- visitDownstreamAdaptiveJoinNode(OperatorsFinished, StreamGraphContext) - Method in class org.apache.flink.table.runtime.strategy.BaseAdaptiveJoinOperatorOptimizationStrategy
W
- WatermarkAssignerOperator - Class in org.apache.flink.table.runtime.operators.wmassigners
-
A stream operator that extracts timestamps from stream elements and generates periodic watermarks.
- WatermarkAssignerOperator(StreamOperatorParameters<RowData>, int, WatermarkGenerator, long, ProcessingTimeService) - Constructor for class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperator
-
Create a watermark assigner operator.
- WatermarkAssignerOperatorFactory - Class in org.apache.flink.table.runtime.operators.wmassigners
-
The factory of
WatermarkAssignerOperator
. - WatermarkAssignerOperatorFactory(int, long, GeneratedWatermarkGenerator) - Constructor for class org.apache.flink.table.runtime.operators.wmassigners.WatermarkAssignerOperatorFactory
- WatermarkGenerator - Class in org.apache.flink.table.runtime.generated
-
The
WatermarkGenerator
is used to generate watermark based the input elements. - WatermarkGenerator() - Constructor for class org.apache.flink.table.runtime.generated.WatermarkGenerator
- WatermarkGeneratorCodeGeneratorFunctionContextWrapper - Class in org.apache.flink.table.runtime.generated
-
A function wrapper for
FunctionContext
if the source supportsSupportsWatermarkPushDown
. - WatermarkGeneratorCodeGeneratorFunctionContextWrapper(WatermarkGeneratorSupplier.Context) - Constructor for class org.apache.flink.table.runtime.generated.WatermarkGeneratorCodeGeneratorFunctionContextWrapper
- Window - Class in org.apache.flink.table.runtime.operators.window
-
A
Window
is a grouping of elements into finite buckets. - Window() - Constructor for class org.apache.flink.table.runtime.operators.window.Window
- WINDOW_IN_BYTES - Static variable in class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- WindowAggOperator<K,W> - Class in org.apache.flink.table.runtime.operators.window.tvf.common
-
We divide windows into 2 categories: Aligned Windows and Unaligned Windows.
- WindowAggOperator(SyncStateWindowProcessor<W>, boolean) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.common.WindowAggOperator
- WindowAggOperatorBuilder - Class in org.apache.flink.table.runtime.operators.aggregate.window
-
The
WindowAggOperatorBuilder
is used to build aWindowAggOperator
withSlicingSyncStateWindowProcessor
or aUnslicingSyncStateWindowProcessor
. - WindowAggOperatorBuilder() - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.WindowAggOperatorBuilder
- WindowAggProcessorBase<W,C extends WindowProcessor.Context<W>> - Class in org.apache.flink.table.runtime.operators.aggregate.window.processors
- WindowAggProcessorBase(GeneratedNamespaceAggsHandleFunction<W>, TypeSerializer<RowData>, boolean, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- windowAggregator - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
- windowAggregator - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- windowAssigner - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.internal.InternalWindowProcessFunction
- windowAssigner - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- windowAssigner - Variable in class org.apache.flink.table.runtime.operators.window.tvf.operator.WindowTableFunctionOperatorBase
- WindowAssigner - Interface in org.apache.flink.table.runtime.operators.window.tvf.common
-
WindowAssigner is used to assign windows to elements.
- WindowAsyncState<W> - Interface in org.apache.flink.table.runtime.operators.window.async.tvf.state
-
A base interface for manipulate async state with window namespace.
- WindowAsyncState<W> - Interface in org.apache.flink.table.runtime.operators.window.tvf.asyncprocessing.state
-
A base interface for manipulate state with window namespace.
- WindowAsyncValueState<W> - Class in org.apache.flink.table.runtime.operators.window.async.tvf.state
-
A wrapper of
ValueState
which is easier to update based on window namespace. - WindowAsyncValueState(InternalValueState<RowData, W, RowData>) - Constructor for class org.apache.flink.table.runtime.operators.window.async.tvf.state.WindowAsyncValueState
- windowBuffer - Variable in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- windowBuffer - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- WindowBuffer - Interface in org.apache.flink.table.runtime.operators.aggregate.window.buffers
-
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 - Interface in org.apache.flink.table.runtime.operators.aggregate.window.buffers
-
A factory that creates a
WindowBuffer
. - WindowBuffer.LocalFactory - Interface in org.apache.flink.table.runtime.operators.aggregate.window.buffers
-
A factory that creates a
WindowBuffer
. - windowBufferFactory - Variable in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- windowBufferFactory - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- WindowBytesHashMap - Class in org.apache.flink.table.runtime.util.collections.binary
-
A binary map in the structure like
Map<WindowKey, BinaryRowData>
. - WindowBytesHashMap(Object, MemoryManager, long, PagedTypeSerializer<RowData>, int) - Constructor for class org.apache.flink.table.runtime.util.collections.binary.WindowBytesHashMap
- WindowBytesMultiMap - Class in org.apache.flink.table.runtime.util.collections.binary
-
A binary map in the structure like
Map<WindowKey, List<BinaryRowData>>
. - WindowBytesMultiMap(Object, MemoryManager, long, PagedTypeSerializer<RowData>, int) - Constructor for class org.apache.flink.table.runtime.util.collections.binary.WindowBytesMultiMap
- windowed(int, int, UnsliceAssigner<TimeWindow>) - Static method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners
-
Creates a
UnsliceAssigner
that assigns elements which has been attached window start and window end timestamp to windows. - windowed(int, SliceAssigner) - Static method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners
-
Creates a
SliceAssigner
that assigns elements which has been attached window start and window end timestamp to slices. - WindowedSliceAssigner(int, SliceAssigner) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.WindowedSliceAssigner
- WindowedUnsliceAssigner(int, int, UnsliceAssigner<TimeWindow>) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- WindowEnd - Class in org.apache.flink.table.runtime.groupwindow
-
Deprecated.The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.
- WindowEnd(WindowReference) - Constructor for class org.apache.flink.table.runtime.groupwindow.WindowEnd
-
Deprecated.
- windowEndIndex(int) - Method in class org.apache.flink.table.runtime.operators.deduplicate.window.RowTimeWindowDeduplicateOperatorBuilder
- windowEndIndex(int) - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- windowFunction - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.UnsliceSyncStateWindowAggProcessor
- windowFunction - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperator
- windowInterval - Variable in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateSliceWindowAggProcessor
- windowInterval - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSliceSyncStateWindowAggProcessor
- WindowJoinHelper - Class in org.apache.flink.table.runtime.operators.join.window.utils
-
A helper to do the window join operations for
WindowJoinOperator
andAsyncStateWindowJoinOperator
. - WindowJoinHelper(RowDataSerializer, RowDataSerializer, ZoneId, WindowTimerService<Long>, JoinConditionWithNullFilters, TimestampedCollector<RowData>, FlinkJoinType) - Constructor for class org.apache.flink.table.runtime.operators.join.window.utils.WindowJoinHelper
- WindowJoinOperator - Class in org.apache.flink.table.runtime.operators.join.window
-
A streaming window join operator implemented by sync state api.
- WindowJoinOperatorBuilder - Class in org.apache.flink.table.runtime.operators.join.window
-
The
WindowJoinOperatorBuilder
is used to build aWindowJoinOperator
for window join. - WindowJoinOperatorBuilder() - Constructor for class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
- WindowKey - Class in org.apache.flink.table.runtime.util
-
The
WindowKey
structure represents a combination of key and window. - WindowKey(long, RowData) - Constructor for class org.apache.flink.table.runtime.util.WindowKey
- WindowKeySerializer - Class in org.apache.flink.table.runtime.typeutils
-
Serializer for
WindowKey
which is composite with aBinaryRowData
and a long value. - WindowKeySerializer(PagedTypeSerializer<RowData>) - Constructor for class org.apache.flink.table.runtime.typeutils.WindowKeySerializer
- WindowKeySerializer.WindowKeySerializerSnapshot - Class in org.apache.flink.table.runtime.typeutils
-
A
TypeSerializerSnapshot
forWindowKeySerializer
. - WindowKeySerializerSnapshot() - Constructor for class org.apache.flink.table.runtime.typeutils.WindowKeySerializer.WindowKeySerializerSnapshot
-
This empty nullary constructor is required for deserializing the configuration.
- WindowKeySerializerSnapshot(WindowKeySerializer) - Constructor for class org.apache.flink.table.runtime.typeutils.WindowKeySerializer.WindowKeySerializerSnapshot
- WindowListAsyncState<W> - Class in org.apache.flink.table.runtime.operators.window.tvf.asyncprocessing.state
-
A wrapper of
ListState
which is easier to update based on window namespace. - WindowListAsyncState(InternalListState<RowData, W, RowData>) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.asyncprocessing.state.WindowListAsyncState
- WindowListState<W> - Class in org.apache.flink.table.runtime.operators.window.tvf.state
-
A wrapper of
ListState
which is easier to update based on window namespace. - WindowListState(InternalListState<RowData, W, RowData>) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.state.WindowListState
- WindowMapState<W,UV> - Class in org.apache.flink.table.runtime.operators.window.tvf.state
-
A wrapper of
MapState
which is easier to update based on window namespace. - WindowMapState(InternalMapState<RowData, W, RowData, UV>) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.state.WindowMapState
- WindowOperator<K,W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.operator
-
An operator that implements the logic for windowing based on a
GroupWindowAssigner
andTrigger
. - WindowOperatorBuilder - Class in org.apache.flink.table.runtime.operators.window.groupwindow.operator
-
The
WindowOperatorBuilder
is used to buildWindowOperator
fluently. - WindowOperatorBuilder() - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- WindowOperatorBuilder.AggregateWindowOperatorBuilder - Class in org.apache.flink.table.runtime.operators.window.groupwindow.operator
-
The builder which is used to build
AggregateWindowOperator
fluently. - WindowOperatorBuilder.TableAggregateWindowOperatorBuilder - Class in org.apache.flink.table.runtime.operators.window.groupwindow.operator
-
The builder which is used to build
TableAggregateWindowOperator
fluently. - WindowProcessor<W,C extends WindowProcessor.Context<W>> - Interface in org.apache.flink.table.runtime.operators.window.tvf.common
-
A base window processor provides common methods used for
SyncStateWindowProcessor
andAsyncStateWindowProcessor
. - WindowProcessor.Context<W> - Interface in org.apache.flink.table.runtime.operators.window.tvf.common
-
Information available in an invocation of methods of
WindowProcessor
. - WindowProperty - Interface in org.apache.flink.table.runtime.groupwindow
-
Deprecated.The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.
- windowPropertyTypes - Variable in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- WindowRankOperatorBuilder - Class in org.apache.flink.table.runtime.operators.rank.window
-
The
WindowRankOperatorBuilder
is used to build aWindowAggOperator
for window rank. - WindowRankOperatorBuilder() - Constructor for class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- WindowReference - Class in org.apache.flink.table.runtime.groupwindow
-
Deprecated.The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they are also used to configure Python operators.
- WindowReference(String, LogicalType) - Constructor for class org.apache.flink.table.runtime.groupwindow.WindowReference
-
Deprecated.
- WindowsGrouping - Class in org.apache.flink.table.runtime.operators.window.grouping
-
Assigning windows from the sorted input buffers.
- WindowStart - Class in org.apache.flink.table.runtime.groupwindow
-
Deprecated.The POJOs in this package are used to represent the deprecated Group Window feature. Currently, they also used to configure Python operators.
- WindowStart(WindowReference) - Constructor for class org.apache.flink.table.runtime.groupwindow.WindowStart
-
Deprecated.
- windowState - Variable in class org.apache.flink.table.runtime.operators.aggregate.asyncwindow.processors.AbstractAsyncStateWindowAggProcessor
-
state schema: [key, window, accumulator].
- windowState - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.AbstractSyncStateWindowAggProcessor
-
state schema: [key, window, accumulator].
- WindowState<W> - Interface in org.apache.flink.table.runtime.operators.window.tvf.state
-
A base interface for manipulate state with window namespace.
- WindowTableFunctionOperatorBase - Class in org.apache.flink.table.runtime.operators.window.tvf.operator
-
The
WindowTableFunctionOperatorBase
acts as a table-valued function to assign windows for input row. - WindowTableFunctionOperatorBase(GroupWindowAssigner<TimeWindow>, int, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.operator.WindowTableFunctionOperatorBase
- windowTimerService - Variable in class org.apache.flink.table.runtime.operators.aggregate.window.processors.WindowAggProcessorBase
- WindowTimerService<W> - Interface in org.apache.flink.table.runtime.operators.window.tvf.common
-
Interface for working with window time and timers which considers timezone for window splitting.
- WindowTimerServiceBase<W> - Class in org.apache.flink.table.runtime.operators.window.tvf.common
-
A base implement of
WindowTimerService
. - WindowTimerServiceBase(InternalTimerService<W>, ZoneId) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.common.WindowTimerServiceBase
- WindowTrigger<W extends Window> - Class in org.apache.flink.table.runtime.operators.window.groupwindow.triggers
-
A
WindowTrigger
determines when a window should be evaluated to emit the results. - WindowTrigger() - Constructor for class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.WindowTrigger
- WindowValueState<W> - Class in org.apache.flink.table.runtime.operators.window.tvf.state
-
A wrapper of
ValueState
which is easier to update based on window namespace. - WindowValueState(InternalValueState<RowData, W, RowData>) - Constructor for class org.apache.flink.table.runtime.operators.window.tvf.state.WindowValueState
- withAllowedLateness(Duration) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- withEarlyFirings(Trigger<W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
-
Creates a new
Trigger
like the this, except that it fires repeatedly whenever the givenTrigger
fires before the watermark has passed the end of the window. - withEarlyFirings(Trigger<W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.ProcessingTimeTriggers.AfterEndOfWindow
-
Creates a new
Trigger
like the this, except that it fires repeatedly whenever the givenTrigger
fires before the processing time has passed the end of the window. - withEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- withEventTime() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.assigners.InternalTimeWindowAssigner
- withEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SessionWindowAssigner
- withEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- withEventTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.TumblingWindowAssigner
- withEventTime() - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- withEventTime(int) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- withEventTime(Boolean) - Method in class org.apache.flink.table.runtime.operators.rank.window.WindowRankOperatorBuilder
- withGap(Duration) - Static method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SessionWindowAssigner
-
Creates a new
SessionWindowAssigner
GroupWindowAssigner
that assigns elements to sessions based on the timestamp. - withInputCountIndex(int) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
-
The index of COUNT(*) in the aggregates. -1 when the input doesn't * contain COUNT(*), i.e.
- withInputFields(LogicalType[]) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- withLateFirings(Trigger<W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindow
-
Creates a new
Trigger
like the this, except that it fires repeatedly whenever the givenTrigger
fires after the watermark has passed the end of the window. - withLateFirings(Trigger<W>) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.triggers.EventTimeTriggers.AfterEndOfWindowNoLate
-
Creates a new
Trigger
like the this, except that it fires repeatedly whenever the givenTrigger
fires after the watermark has passed the end of the window. - withOffset(Duration) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- withOffset(Duration) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- withOffset(Duration) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.TumblingWindowAssigner
-
Creates a new
TumblingWindowAssigner
GroupWindowAssigner
that assigns elements to time windows based on the element timestamp and offset. - withOffset(Duration) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.CumulativeSliceAssigner
-
Creates a new
SliceAssigners.CumulativeSliceAssigner
with a new specified offset. - withOffset(Duration) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.HoppingSliceAssigner
-
Creates a new
SliceAssigners.HoppingSliceAssigner
with a new specified offset. - withOffset(Duration) - Method in class org.apache.flink.table.runtime.operators.window.tvf.slicing.SliceAssigners.TumblingSliceAssigner
-
Creates a new
SliceAssigners.TumblingSliceAssigner
with a new specified offset. - withoutUniqueKey() - Static method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinInputSideSpec
-
Creates a
JoinInputSideSpec
that input hasn't any unique keys. - withProcessingTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.CumulativeWindowAssigner
- withProcessingTime() - Method in interface org.apache.flink.table.runtime.operators.window.groupwindow.assigners.InternalTimeWindowAssigner
- withProcessingTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SessionWindowAssigner
- withProcessingTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.SlidingWindowAssigner
- withProcessingTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.assigners.TumblingWindowAssigner
- withProcessingTime() - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
- withProcessingTime() - Method in class org.apache.flink.table.runtime.operators.window.tvf.unslicing.UnsliceAssigners.WindowedUnsliceAssigner
- withShiftTimezone(ZoneId) - Method in class org.apache.flink.table.runtime.operators.join.window.WindowJoinOperatorBuilder
-
The shift timezone of the window, if the proctime or rowtime type is TIMESTAMP_LTZ, the shift timezone is the timezone user configured in TableConfig, other cases the timezone is UTC which means never shift when assigning windows.
- withShiftTimezone(ZoneId) - Method in class org.apache.flink.table.runtime.operators.window.groupwindow.operator.WindowOperatorBuilder
-
The shift timezone of the window, if the proctime or rowtime type is TIMESTAMP_LTZ, the shift timezone is the timezone user configured in TableConfig, other cases the timezone is UTC which means never shift when assigning windows.
- withUniqueKey(InternalTypeInfo<RowData>, KeySelector<RowData, RowData>) - Static method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinInputSideSpec
-
Creates a
JoinInputSideSpec
that the input has an unique key. - withUniqueKeyContainedByJoinKey(InternalTypeInfo<RowData>, KeySelector<RowData, RowData>) - Static method in class org.apache.flink.table.runtime.operators.join.stream.utils.JoinInputSideSpec
-
Creates a
JoinInputSideSpec
that input has an unique key and the unique key is contained by the join key. - WrappedRowIterator<T extends org.apache.flink.table.data.RowData> - Class in org.apache.flink.table.runtime.hashtable
-
Wrap
MutableObjectIterator
to javaRowIterator
. - WrappedRowIterator(MutableObjectIterator<T>, T) - Constructor for class org.apache.flink.table.runtime.hashtable.WrappedRowIterator
- WrappingCollector<T> - Class in org.apache.flink.table.runtime.collector
-
A
Collector
that wraps another collector. - WrappingCollector() - Constructor for class org.apache.flink.table.runtime.collector.WrappingCollector
- write(RowData) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalSorter
- write(RowData) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryInMemorySortBuffer
-
Writes a given record to this sort buffer.
- write(BinaryWriter, int, Object, LogicalType, TypeSerializer<?>) - Static method in interface org.apache.flink.table.data.writer.BinaryWriter
-
Deprecated.Use
BinaryWriter.createValueSetter(LogicalType)
for avoiding logical types during runtime. - write(MutableObjectIterator<BinaryRowData>) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalSorter
- writeArray(int, ArrayData, ArrayDataSerializer) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeBinary(int, byte[]) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeBlock(MemorySegment) - Method in class org.apache.flink.table.runtime.io.CompressedBlockChannelWriter
- writeBoolean(int, boolean) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- writeBoolean(int, boolean) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- writeBoolean(int, boolean) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeByte(int, byte) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- writeByte(int, byte) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- writeByte(int, byte) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeDecimal(int, DecimalData, int) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeDouble(int, double) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- writeDouble(int, double) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- writeDouble(int, double) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeFloat(int, float) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- writeFloat(int, float) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- writeFloat(int, float) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeIndexAndNormalizedKey(RowData, long) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
-
Write of index and normalizedKey.
- writeInt(int, int) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- writeInt(int, int) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- writeInt(int, int) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeLong(int, long) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- writeLong(int, long) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- writeLong(int, long) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeMap(int, MapData, MapDataSerializer) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeMergingOutput(MutableObjectIterator<Entry>, AbstractPagedOutputView) - Method in class org.apache.flink.table.runtime.operators.sort.AbstractBinaryExternalMerger
-
read the merged stream and write the data back.
- writeMergingOutput(MutableObjectIterator<Tuple2<BinaryRowData, BinaryRowData>>, AbstractPagedOutputView) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryKVExternalMerger
- writeMergingOutput(MutableObjectIterator<BinaryRowData>, AbstractPagedOutputView) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryExternalMerger
- writeOuterSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.ExternalSerializer.ExternalSerializerSnapshot
- writeOuterSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.LinkedListSerializer.LinkedListSerializerSnapshot
- writeRawValue(int, RawValueData<?>, RawValueDataSerializer<?>) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeRow(int, RowData, RowDataSerializer) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeRowKind(RowKind) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- writeShort(int, short) - Method in class org.apache.flink.table.data.writer.BinaryArrayWriter
- writeShort(int, short) - Method in class org.apache.flink.table.data.writer.BinaryRowWriter
- writeShort(int, short) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.ArrayDataSerializer.ArrayDataSerializerSnapshot
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.BinaryRowDataSerializer.BinaryRowDataSerializerSnapshot
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.DecimalDataSerializer.DecimalSerializerSnapshot
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.MapDataSerializer.MapDataSerializerSnapshot
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.RowDataSerializer.RowDataSerializerSnapshot
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.SortedMapSerializerSnapshot
- writeSnapshot(DataOutputView) - Method in class org.apache.flink.table.runtime.typeutils.TimestampDataSerializer.TimestampDataSerializerSnapshot
- writeString(int, StringData) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeTimestamp(int, TimestampData, int) - Method in interface org.apache.flink.table.data.writer.BinaryWriter
- writeToOutput(AbstractPagedOutputView) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryIndexedSortable
-
Spill: Write all records to a
AbstractPagedOutputView
. - writeToOutput(AbstractPagedOutputView) - Method in class org.apache.flink.table.runtime.operators.sort.BinaryKVInMemorySortBuffer
X
- XXH64 - Class in org.apache.flink.table.runtime.functions.aggregate.hyperloglog
-
xxHash64.
- XXH64() - Constructor for class org.apache.flink.table.runtime.functions.aggregate.hyperloglog.XXH64
Y
- YearMonthIntervalPeriodConverter - Class in org.apache.flink.table.data.conversion
-
Converter for
YearMonthIntervalType
ofPeriod
external type.
All Classes All Packages