Modifier and Type | Class and Description |
---|---|
class |
TwoPhaseCommitSinkFunction<IN,TXN,CONTEXT>
This is a recommended base class for all of the
SinkFunction that intend to implement
exactly-once semantic. |
Modifier and Type | Class and Description |
---|---|
class |
StreamingFileSink<IN>
Deprecated.
Use
org.apache.flink.connector.file.sink.FileSink instead. |
Modifier and Type | Class and Description |
---|---|
class |
ContinuousFileMonitoringFunction<OUT>
This is the single (non-parallel) monitoring task which takes a
FileInputFormat and,
depending on the FileProcessingMode and the FilePathFilter , it is responsible
for:
Monitoring a user-provided path. |
class |
FromElementsFunction<T>
A stream source function that returns a sequence of elements.
|
class |
MessageAcknowledgingSourceBase<Type,UId>
Abstract base class for data sources that receive elements from a message queue and acknowledge
them back by IDs.
|
class |
MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId>
Abstract base class for data sources that receive elements from a message queue and acknowledge
them back by IDs.
|
class |
StatefulSequenceSource
A stateful streaming source that emits each number from a given interval exactly once, possibly
in parallel.
|
Modifier and Type | Class and Description |
---|---|
class |
DataGeneratorSource<T>
Deprecated.
Use
org.apache.flink.connector.datagen.source.DataGeneratorSource instead. |
Modifier and Type | Class and Description |
---|---|
class |
CollectSinkFunction<IN>
A sink function that collects query results and sends them back to the client.
|
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.