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 |
---|---|
ConnectorSource<OUT> | |
FileMonitoringFunction | |
FileReadFunction | |
FileSourceFunction<OUT> | |
FromElementsFunction<T> |
A stream source function that returns a sequence of elements.
|
FromIteratorFunction<T> | |
FromSplittableIteratorFunction<T> | |
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.
|
Enum | Description |
---|---|
FileMonitoringFunction.WatchType |
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.