Uses of Interface
org.apache.flink.streaming.api.operators.OneInputStreamOperator
-
-
Uses of OneInputStreamOperator in org.apache.flink.cep.operator
Classes in org.apache.flink.cep.operator that implement OneInputStreamOperator Modifier and Type Class Description class
CepOperator<IN,KEY,OUT>
CEP pattern operator for a keyed input stream. -
Uses of OneInputStreamOperator in org.apache.flink.connector.file.sink.compactor.operator
Classes in org.apache.flink.connector.file.sink.compactor.operator that implement OneInputStreamOperator Modifier and Type Class Description class
CompactCoordinator
Coordinator that coordinates file compaction for theFileSink
.class
CompactCoordinatorStateHandler
Handler that processes the state ofCompactCoordinator
when compaction is disabled.class
CompactorOperator
An operator that perform compaction for theFileSink
.class
CompactorOperatorStateHandler
Handler that processes the state ofCompactorOperator
when compaction is disabled. -
Uses of OneInputStreamOperator in org.apache.flink.connector.file.table.batch.compact
Classes in org.apache.flink.connector.file.table.batch.compact that implement OneInputStreamOperator Modifier and Type Class Description class
BatchCompactCoordinator
Coordinator for compaction in batch mode.class
BatchCompactOperator<T>
CompactOperator for compaction in batch mode.class
BatchFileWriter<T>
An operator for writing files in batch mode. -
Uses of OneInputStreamOperator in org.apache.flink.connector.file.table.stream
Classes in org.apache.flink.connector.file.table.stream that implement OneInputStreamOperator Modifier and Type Class Description class
AbstractStreamingWriter<IN,OUT>
Operator for file system sink.class
PartitionCommitter
Committer operator for partitions.class
StreamingFileWriter<IN>
Writer for emittingPartitionCommitInfo
to downstream. -
Uses of OneInputStreamOperator in org.apache.flink.connector.file.table.stream.compact
Classes in org.apache.flink.connector.file.table.stream.compact that implement OneInputStreamOperator Modifier and Type Class Description class
CompactCoordinator
This is the single (non-parallel) monitoring task which coordinate input files to compaction units. - Receives in-flight input files inside checkpoint. - Receives all upstream end input messages after the checkpoint completes successfully, starts coordination.class
CompactFileWriter<T>
Writer for emittingCompactMessages.InputFile
andCompactMessages.EndCheckpoint
to downstream.class
CompactOperator<T>
Receives compaction units to do compaction. -
Uses of OneInputStreamOperator in org.apache.flink.datastream.impl.operators
Classes in org.apache.flink.datastream.impl.operators that implement OneInputStreamOperator Modifier and Type Class Description class
KeyedProcessOperator<KEY,IN,OUT>
Operator forOneInputStreamProcessFunction
inKeyedPartitionStream
.class
KeyedTwoOutputProcessOperator<KEY,IN,OUT_MAIN,OUT_SIDE>
class
ProcessOperator<IN,OUT>
Operator forOneInputStreamProcessFunction
.class
TwoOutputProcessOperator<IN,OUT_MAIN,OUT_SIDE>
Operator forTwoOutputStreamProcessFunction
. -
Uses of OneInputStreamOperator in org.apache.flink.datastream.impl.utils
Methods in org.apache.flink.datastream.impl.utils with parameters of type OneInputStreamOperator Modifier and Type Method Description static <T,R,K>
OneInputTransformation<T,R>StreamUtils. getOneInputKeyedTransformation(String operatorName, AbstractDataStream<T> inputStream, TypeInformation<R> outTypeInformation, OneInputStreamOperator<T,R> operator, KeySelector<T,K> keySelector, TypeInformation<K> keyType)
Construct and return aOneInputTransformation
from keyed input streams.static <T,R>
OneInputTransformation<T,R>StreamUtils. getOneInputTransformation(String operatorName, AbstractDataStream<T> inputStream, TypeInformation<R> outTypeInformation, OneInputStreamOperator<T,R> operator)
Construct and return aOneInputTransformation
from non-keyed input streams. -
Uses of OneInputStreamOperator in org.apache.flink.state.api.output
Classes in org.apache.flink.state.api.output that implement OneInputStreamOperator Modifier and Type Class Description class
BootstrapStreamTaskRunner<IN>
The runtime for aBootstrapStreamTask
. -
Uses of OneInputStreamOperator in org.apache.flink.state.api.output.operators
Classes in org.apache.flink.state.api.output.operators with type parameters of type OneInputStreamOperator Modifier and Type Class Description class
StateBootstrapWrapperOperator<IN,OUT,OP extends AbstractStreamOperator<OUT> & OneInputStreamOperator<IN,OUT>>
Wraps an existing operator so it can be bootstrapped.class
StateBootstrapWrapperOperatorFactory<IN,OUT,OP extends AbstractStreamOperator<OUT> & OneInputStreamOperator<IN,OUT>,OPF extends OneInputStreamOperatorFactory<IN,OUT>>
Classes in org.apache.flink.state.api.output.operators that implement OneInputStreamOperator Modifier and Type Class Description class
BroadcastStateBootstrapOperator<IN>
AStreamOperator
for executingBroadcastStateBootstrapFunction
's.class
GroupReduceOperator<IN,OUT>
An operator for executing aGroupReduceFunction
on a bounded DataStream.class
KeyedStateBootstrapOperator<K,IN>
AStreamOperator
for executingKeyedStateBootstrapFunction
's.class
StateBootstrapOperator<IN>
AStreamOperator
for executingStateBootstrapFunction
's.class
StateBootstrapWrapperOperator<IN,OUT,OP extends AbstractStreamOperator<OUT> & OneInputStreamOperator<IN,OUT>>
Wraps an existing operator so it can be bootstrapped. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.api.datastream
Methods in org.apache.flink.streaming.api.datastream with parameters of type OneInputStreamOperator Modifier and Type Method Description <R> SingleOutputStreamOperator<R>
DataStream. transform(String operatorName, TypeInformation<R> outTypeInfo, OneInputStreamOperator<T,R> operator)
Method for passing user defined operators along with the type information that will transform the DataStream. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.api.functions.query
Classes in org.apache.flink.streaming.api.functions.query that implement OneInputStreamOperator Modifier and Type Class Description class
QueryableAppendingStateOperator<IN>
Internal operator handling queryable AppendingState instances.class
QueryableValueStateOperator<IN>
Internal operator handling queryable ValueState instances. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.api.functions.source
Classes in org.apache.flink.streaming.api.functions.source that implement OneInputStreamOperator Modifier and Type Class Description class
ContinuousFileReaderOperator<OUT,T extends TimestampedInputSplit>
The operator that reads thesplits
received from the precedingContinuousFileMonitoringFunction
. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.api.operators
Classes in org.apache.flink.streaming.api.operators that implement OneInputStreamOperator Modifier and Type Class Description class
BatchGroupedReduceOperator<IN,KEY>
AStreamOperator
for executing aReduceFunction
on aKeyedStream
in aRuntimeExecutionMode.BATCH
mode.class
KeyedProcessOperator<K,IN,OUT>
AStreamOperator
for executingKeyedProcessFunctions
.class
LegacyKeyedProcessOperator<K,IN,OUT>
Deprecated.Replaced byKeyedProcessOperator
which takesKeyedProcessFunction
class
MapPartitionOperator<IN,OUT>
TheMapPartitionOperator
is used to process all records in each partition on non-keyed stream.class
PartitionAggregateOperator<IN,ACC,OUT>
ThePartitionAggregateOperator
is used to apply the aggregate transformation on all records of each partition.class
PartitionReduceOperator<IN>
ThePartitionReduceOperator
is used to apply the reduce transformation on all records of each partition.class
ProcessOperator<IN,OUT>
AStreamOperator
for executingProcessFunctions
.class
StreamFilter<IN>
AStreamOperator
for executingFilterFunctions
.class
StreamFlatMap<IN,OUT>
AStreamOperator
for executingFlatMapFunctions
.class
StreamGroupedReduceOperator<IN>
class
StreamMap<IN,OUT>
AStreamOperator
for executingMapFunctions
.class
StreamProject<IN,OUT extends Tuple>
AStreamOperator
for executing projections on streams.class
StreamSink<IN>
AStreamOperator
for executingSinkFunctions
. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.api.operators.async
Classes in org.apache.flink.streaming.api.operators.async that implement OneInputStreamOperator Modifier and Type Class Description class
AsyncWaitOperator<IN,OUT>
TheAsyncWaitOperator
allows to asynchronously process incoming stream records. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.api.operators.collect
Classes in org.apache.flink.streaming.api.operators.collect that implement OneInputStreamOperator Modifier and Type Class Description class
CollectSinkOperator<IN>
AStreamSink
that collects query results and sends them back to the client. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.api.operators.python.embedded
Classes in org.apache.flink.streaming.api.operators.python.embedded that implement OneInputStreamOperator Modifier and Type Class Description class
AbstractOneInputEmbeddedPythonFunctionOperator<IN,OUT>
AbstractOneInputEmbeddedPythonFunctionOperator
is responsible for run Python DataStream operators with one input in Embedded Python environment.class
EmbeddedPythonKeyedProcessOperator<K,IN,OUT>
EmbeddedPythonKeyedProcessOperator
is responsible for executing user defined python KeyedProcessFunction in embedded Python environment.class
EmbeddedPythonProcessOperator<IN,OUT>
EmbeddedPythonProcessOperator
is responsible for executing Python ProcessFunction in embedded Python environment.class
EmbeddedPythonWindowOperator<K,IN,OUT,W extends Window>
EmbeddedPythonWindowOperator
is responsible for executing user defined python ProcessWindowFunction in embedded Python environment. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.api.operators.python.process
Classes in org.apache.flink.streaming.api.operators.python.process that implement OneInputStreamOperator Modifier and Type Class Description class
AbstractExternalOneInputPythonFunctionOperator<IN,OUT>
AbstractExternalOneInputPythonFunctionOperator
is responsible for launching beam runner which will start a python harness to execute user defined python function.class
ExternalPythonKeyedProcessOperator<OUT>
ExternalPythonKeyedProcessOperator
is responsible for launching beam runner which will start a python harness to execute user defined python function.class
ExternalPythonProcessOperator<IN,OUT>
ExternalPythonProcessOperator
is responsible for launching beam runner which will start a python harness to execute user defined python ProcessFunction. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.api.operators.sortpartition
Classes in org.apache.flink.streaming.api.operators.sortpartition that implement OneInputStreamOperator Modifier and Type Class Description class
KeyedSortPartitionOperator<INPUT,KEY>
TheKeyedSortPartitionOperator
sorts records of a partition onKeyedStream
.class
SortPartitionOperator<INPUT>
TheSortPartitionOperator
sorts records of a partition on non-keyed data stream. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.api.transformations
Methods in org.apache.flink.streaming.api.transformations that return OneInputStreamOperator Modifier and Type Method Description OneInputStreamOperator<IN,OUT>
OneInputTransformation. getOperator()
Constructors in org.apache.flink.streaming.api.transformations with parameters of type OneInputStreamOperator Constructor Description OneInputTransformation(Transformation<IN> input, String name, OneInputStreamOperator<IN,OUT> operator, TypeInformation<OUT> outputType, int parallelism)
Creates a newOneInputTransformation
from the given input and operator.OneInputTransformation(Transformation<IN> input, String name, OneInputStreamOperator<IN,OUT> operator, TypeInformation<OUT> outputType, int parallelism, boolean parallelismConfigured)
-
Uses of OneInputStreamOperator in org.apache.flink.streaming.runtime.operators
Classes in org.apache.flink.streaming.runtime.operators that implement OneInputStreamOperator Modifier and Type Class Description class
GenericWriteAheadSink<IN>
Generic Sink that emits its input elements into an arbitrary backend.class
TimestampsAndWatermarksOperator<T>
A stream operator that may do one or both of the following: extract timestamps from events and generate watermarks. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.runtime.operators.windowing
Classes in org.apache.flink.streaming.runtime.operators.windowing that implement OneInputStreamOperator Modifier and Type Class Description class
EvictingWindowOperator<K,IN,OUT,W extends Window>
AWindowOperator
that also allows anEvictor
to be used.class
WindowOperator<K,IN,ACC,OUT,W extends Window>
An operator that implements the logic for windowing based on aWindowAssigner
andTrigger
. -
Uses of OneInputStreamOperator in org.apache.flink.streaming.runtime.translators
Classes in org.apache.flink.streaming.runtime.translators that implement OneInputStreamOperator Modifier and Type Class Description static class
CacheTransformationTranslator.IdentityStreamOperator<T>
TheCacheTransformationTranslator.IdentityStreamOperator
acts as a dummy source to consume cached intermediate dataset.static class
CacheTransformationTranslator.NoOpStreamOperator<T>
TheCacheTransformationTranslator.NoOpStreamOperator
acts as a dummy sink so that the upstream can produce the intermediate dataset to be cached. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.aggregate.window
Classes in org.apache.flink.table.runtime.operators.aggregate.window that implement OneInputStreamOperator Modifier and Type Class Description class
LocalSlicingWindowAggOperator
The operator used for local window aggregation. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.bundle
Classes in org.apache.flink.table.runtime.operators.bundle that implement OneInputStreamOperator Modifier and Type Class Description class
AbstractMapBundleOperator<K,V,IN,OUT>
TheAbstractMapBundleOperator
simply used a java Map to store the input elements in key-value form.class
KeyedMapBundleOperator<K,V,IN,OUT>
TheKeyedMapBundleOperator
uses framework's key as bundle map key, thus can only be used onKeyedStream
.class
MapBundleOperator<K,V,IN,OUT>
TheMapBundleOperator
uses aKeySelector
to extract bundle key, thus can be used with non-keyed-stream. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.dynamicfiltering
Classes in org.apache.flink.table.runtime.operators.dynamicfiltering that implement OneInputStreamOperator Modifier and Type Class Description class
DynamicFilteringDataCollectorOperator
Operator to collect and build theDynamicFilteringData
for sources that supports dynamic filtering. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.multipleinput
Classes in org.apache.flink.table.runtime.operators.multipleinput that implement OneInputStreamOperator Modifier and Type Class Description class
UnionStreamOperator
A special operator which collects all inputs' records and forwards them inMultipleInputStreamOperatorBase
. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.multipleinput.input
Constructors in org.apache.flink.table.runtime.operators.multipleinput.input with parameters of type OneInputStreamOperator Constructor Description OneInput(OneInputStreamOperator<RowData,RowData> operator)
-
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.multipleinput.output
Constructors in org.apache.flink.table.runtime.operators.multipleinput.output with parameters of type OneInputStreamOperator Constructor Description CopyingOneInputStreamOperatorOutput(OneInputStreamOperator<RowData,RowData> operator, TypeSerializer<RowData> serializer)
OneInputStreamOperatorOutput(OneInputStreamOperator<RowData,RowData> operator)
-
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.over
Classes in org.apache.flink.table.runtime.operators.over that implement OneInputStreamOperator Modifier and Type Class Description class
BufferDataOverWindowOperator
the operator for OVER window need cache data by ResettableExternalBuffer forOverWindowFrame
.class
NonBufferOverWindowOperator
The operator for OVER window don't need cache data. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.python
Classes in org.apache.flink.table.runtime.operators.python that implement OneInputStreamOperator Modifier and Type Class Description class
AbstractEmbeddedStatelessFunctionOperator
Base class for all stream operators to execute Python Stateless Functions in embedded Python environment.class
AbstractOneInputPythonFunctionOperator<IN,OUT>
Base class for all one input stream operators to execute Python functions.class
AbstractStatelessFunctionOperator<IN,OUT,UDFIN>
Base class for all stream operators to execute Python Stateless Functions. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.python.aggregate
Classes in org.apache.flink.table.runtime.operators.python.aggregate that implement OneInputStreamOperator Modifier and Type Class Description class
AbstractPythonStreamAggregateOperator
Base class forAbstractPythonStreamGroupAggregateOperator
andPythonStreamGroupWindowAggregateOperator
.class
AbstractPythonStreamGroupAggregateOperator
Base class forPythonStreamGroupAggregateOperator
andPythonStreamGroupTableAggregateOperator
.class
PythonStreamGroupAggregateOperator
The Python AggregateFunction operator.class
PythonStreamGroupTableAggregateOperator
The Python TableAggregateFunction operator.class
PythonStreamGroupWindowAggregateOperator<K,W extends Window>
The Python Group Window AggregateFunction operator. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.python.aggregate.arrow
Classes in org.apache.flink.table.runtime.operators.python.aggregate.arrow that implement OneInputStreamOperator Modifier and Type Class Description class
AbstractArrowPythonAggregateFunctionOperator
The Abstract class of Arrow Aggregate Operator for PandasAggregateFunction
. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch
Classes in org.apache.flink.table.runtime.operators.python.aggregate.arrow.batch that implement OneInputStreamOperator Modifier and Type Class Description class
BatchArrowPythonGroupAggregateFunctionOperator
The Batch Arrow PythonAggregateFunction
Operator for Group Aggregation.class
BatchArrowPythonGroupWindowAggregateFunctionOperator
The Batch Arrow PythonAggregateFunction
Operator for Group Window Aggregation.class
BatchArrowPythonOverWindowAggregateFunctionOperator
The Batch Arrow PythonAggregateFunction
Operator for Over Window Aggregation. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream
Classes in org.apache.flink.table.runtime.operators.python.aggregate.arrow.stream that implement OneInputStreamOperator Modifier and Type Class Description class
AbstractStreamArrowPythonBoundedRangeOperator<K>
The Abstract class of Stream Arrow PythonAggregateFunction
Operator for RANGE clause bounded Over Window Aggregation.class
AbstractStreamArrowPythonBoundedRowsOperator<K>
The Abstract class of Stream Arrow PythonAggregateFunction
Operator for ROWS clause bounded Over Window Aggregation.class
AbstractStreamArrowPythonOverWindowAggregateFunctionOperator<K>
The Abstract class of Stream Arrow PythonAggregateFunction
Operator for Over Window Aggregation.class
StreamArrowPythonGroupWindowAggregateFunctionOperator<K,W extends Window>
The Stream Arrow PythonAggregateFunction
Operator for Group Window Aggregation.class
StreamArrowPythonProcTimeBoundedRangeOperator<K>
The Stream Arrow PythonAggregateFunction
Operator for ROWS clause proc-time bounded OVER window.class
StreamArrowPythonProcTimeBoundedRowsOperator<K>
The Stream Arrow PythonAggregateFunction
Operator for ROWS clause proc-time bounded OVER window.class
StreamArrowPythonRowTimeBoundedRangeOperator<K>
The Stream Arrow PythonAggregateFunction
Operator for RANGE clause event-time bounded OVER window.class
StreamArrowPythonRowTimeBoundedRowsOperator<K>
The Stream Arrow PythonAggregateFunction
Operator for RANGE clause event-time bounded OVER window. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.python.scalar
Classes in org.apache.flink.table.runtime.operators.python.scalar that implement OneInputStreamOperator Modifier and Type Class Description class
AbstractPythonScalarFunctionOperator
Base class for all stream operators to execute PythonScalarFunction
s.class
EmbeddedPythonScalarFunctionOperator
The PythonScalarFunction
operator in embedded Python environment.class
PythonScalarFunctionOperator
The PythonScalarFunction
operator. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.python.scalar.arrow
Classes in org.apache.flink.table.runtime.operators.python.scalar.arrow that implement OneInputStreamOperator Modifier and Type Class Description class
ArrowPythonScalarFunctionOperator
Arrow PythonScalarFunction
operator. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.python.table
Classes in org.apache.flink.table.runtime.operators.python.table that implement OneInputStreamOperator Modifier and Type Class Description class
EmbeddedPythonTableFunctionOperator
The PythonTableFunction
operator in embedded Python environment.class
PythonTableFunctionOperator
The PythonTableFunction
operator. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.runtimefilter
Classes in org.apache.flink.table.runtime.operators.runtimefilter that implement OneInputStreamOperator Modifier and Type Class Description class
GlobalRuntimeFilterBuilderOperator
Global runtime filter builder operator.class
LocalRuntimeFilterBuilderOperator
Local runtime filter builder operator. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.sink
Classes in org.apache.flink.table.runtime.operators.sink that implement OneInputStreamOperator Modifier and Type Class Description class
ConstraintEnforcer
ProcessesRowData
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.class
OutputConversionOperator
Operator that converts to external data structures and unwraps atomic records if necessary.class
RowKindSetter
An operator that sets the row kind of the incoming records to a specific row kind.class
SinkOperator
AStreamOperator
for executingSinkFunctions
.class
SinkUpsertMaterializer
An operator that maintains incoming records in state corresponding to the upsert keys and generates an upsert view for the downstream operator.class
StreamRecordTimestampInserter
Operator which sets the timestamp on the StreamRecord from the corresponding column of each row. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.sort
Classes in org.apache.flink.table.runtime.operators.sort that implement OneInputStreamOperator Modifier and Type Class Description class
LimitOperator
Operator for batch limit.class
ProcTimeSortOperator
Sort on proc-time and additional secondary sort attributes.class
RankOperator
Rank operator to compute top N.class
RowTimeSortOperator
Sort based on event-time and possibly additional secondary sort attributes.class
SortLimitOperator
Operator for batch sort limit.class
SortOperator
Operator for batch sort.class
StreamSortOperator
Operator for stream sort. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.source
Classes in org.apache.flink.table.runtime.operators.source that implement OneInputStreamOperator Modifier and Type Class Description class
InputConversionOperator<E>
Operator that converts to internal data structures and wraps atomic records if necessary. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.window.groupwindow.operator
Classes in org.apache.flink.table.runtime.operators.window.groupwindow.operator that implement OneInputStreamOperator Modifier and Type Class Description class
AggregateWindowOperator<K,W extends Window>
AWindowOperator
for grouped window aggregates.class
TableAggregateWindowOperator<K,W extends Window>
AWindowOperator
for grouped and windowed table aggregates.class
WindowOperator<K,W extends Window>
An operator that implements the logic for windowing based on aGroupWindowAssigner
andTrigger
. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.window.tvf.common
Classes in org.apache.flink.table.runtime.operators.window.tvf.common that implement OneInputStreamOperator Modifier and Type Class Description class
WindowAggOperator<K,W>
We divide windows into 2 categories: Aligned Windows and Unaligned Windows. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.window.tvf.operator
Classes in org.apache.flink.table.runtime.operators.window.tvf.operator that implement OneInputStreamOperator Modifier and Type Class Description class
AlignedWindowTableFunctionOperator
The operator for aligned window table function.class
UnalignedWindowTableFunctionOperator
The operator for unaligned window table function.class
WindowTableFunctionOperatorBase
TheWindowTableFunctionOperatorBase
acts as a table-valued function to assign windows for input row. -
Uses of OneInputStreamOperator in org.apache.flink.table.runtime.operators.wmassigners
Classes in org.apache.flink.table.runtime.operators.wmassigners that implement OneInputStreamOperator Modifier and Type Class Description class
ProcTimeMiniBatchAssignerOperator
A stream operator that emits mini-batch marker in a given period.class
RowTimeMiniBatchAssginerOperator
A stream operator that emits watermark in a given event-time interval.class
WatermarkAssignerOperator
A stream operator that extracts timestamps from stream elements and generates periodic watermarks.
-