Package | Description |
---|---|
org.apache.flink.streaming.api.environment | |
org.apache.flink.streaming.api.functions.source | |
org.apache.flink.streaming.api.operators | |
org.apache.flink.streaming.runtime.tasks |
This package contains classes that realize streaming tasks.
|
Modifier and Type | Method and Description |
---|---|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function)
Adds a Data Source to the streaming topology.
|
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
String sourceName)
Ads a data source with a custom type information thus opening a
DataStream . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
String sourceName,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo)
Ads a data source with a custom type information thus opening a
DataStream . |
<OUT> DataStreamSource<OUT> |
StreamExecutionEnvironment.addSource(SourceFunction<OUT> function,
org.apache.flink.api.common.typeinfo.TypeInformation<OUT> typeInfo)
Ads a data source with a custom type information thus opening a
DataStream . |
Modifier and Type | Interface and Description |
---|---|
interface |
ParallelSourceFunction<OUT>
A stream data source that is executed in parallel.
|
Modifier and Type | Class and Description |
---|---|
class |
ConnectorSource<OUT> |
class |
ContinuousFileMonitoringFunction<OUT>
This is the single (non-parallel) task which takes a
FileInputFormat and is responsible for
i) monitoring a user-provided path, ii) deciding which files should be further read and processed,
iii) creating the FileInputSplits corresponding to those files, and iv) assigning
them to downstream tasks for further reading and processing. |
class |
FileMonitoringFunction
Deprecated.
|
class |
FromElementsFunction<T>
A stream source function that returns a sequence of elements.
|
class |
FromIteratorFunction<T> |
class |
FromSplittableIteratorFunction<T> |
class |
InputFormatSourceFunction<OUT> |
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 |
RichParallelSourceFunction<OUT>
Base class for implementing a parallel data source.
|
class |
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() . |
class |
SocketTextStreamFunction
A source function that reads strings from a socket.
|
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 |
StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & org.apache.flink.api.common.functions.StoppableFunction>
|
class |
StreamSource<OUT,SRC extends SourceFunction<OUT>>
StreamOperator for streaming sources. |
Modifier and Type | Class and Description |
---|---|
class |
SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>>
Task for executing streaming sources.
|
class |
StoppableSourceStreamTask<OUT,SRC extends SourceFunction<OUT> & org.apache.flink.api.common.functions.StoppableFunction>
Stoppable task for executing stoppable streaming sources.
|
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.