Interface | Description |
---|---|
ParallelSourceFunction<OUT> |
A stream data source that is executed in parallel.
|
SourceFunction<T> |
Base interface for all stream data sources in Flink.
|
SourceFunction.SourceContext<T> |
Interface that source functions use to emit elements, and possibly watermarks.
|
Class | Description |
---|---|
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.
Deciding which files should be further read and processed.
Creating the splits corresponding to those files.
Assigning them to downstream tasks for further processing.
|
ContinuousFileReaderOperator<OUT> |
The operator that reads the
splits received from the preceding
ContinuousFileMonitoringFunction . |
FileMonitoringFunction | Deprecated
Internal class deprecated in favour of
ContinuousFileMonitoringFunction . |
FileReadFunction | Deprecated
Internal class deprecated in favour of
ContinuousFileMonitoringFunction . |
FromElementsFunction<T> |
A stream source function that returns a sequence of elements.
|
FromIteratorFunction<T> |
A
SourceFunction that reads elements from an Iterator and emits them. |
FromSplittableIteratorFunction<T> |
A
SourceFunction that reads elements from an SplittableIterator and emits them. |
InputFormatSourceFunction<OUT> |
A
SourceFunction that reads data using an InputFormat . |
MessageAcknowledgingSourceBase<Type,UId> |
Abstract base class for data sources that receive elements from a message queue and
acknowledge them back by IDs.
|
MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId> |
Abstract base class for data sources that receive elements from a message queue and
acknowledge them back by IDs.
|
RichParallelSourceFunction<OUT> |
Base class for implementing a parallel data source.
|
RichSourceFunction<OUT> |
Base class for implementing a parallel data source that has access to context information
(via
AbstractRichFunction.getRuntimeContext() ) and additional life-cycle methods
(AbstractRichFunction.open(org.apache.flink.configuration.Configuration) and AbstractRichFunction.close() . |
SocketTextStreamFunction |
A source function that reads strings from a socket.
|
StatefulSequenceSource |
A stateful streaming source that emits each number from a given interval exactly once,
possibly in parallel.
|
TimestampedFileInputSplit |
An extended
FileInputSplit that also includes information about:
The modification time of the file this split belongs to.
When checkpointing, the state of the split at the moment of the checkpoint.
This class is used by the ContinuousFileMonitoringFunction and the
ContinuousFileReaderOperator to perform continuous file processing. |
Enum | Description |
---|---|
FileMonitoringFunction.WatchType |
The watch type of the
FileMonitoringFunction . |
FileProcessingMode |
The mode in which the
ContinuousFileMonitoringFunction operates. |
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.