Package | Description |
---|---|
org.apache.flink.streaming.api.functions.source | |
org.apache.flink.streaming.api.operators |
Modifier and Type | Method and Description |
---|---|
void |
ContinuousFileMonitoringFunction.run(SourceFunction.SourceContext<org.apache.flink.core.fs.FileInputSplit> context) |
void |
StatefulSequenceSource.run(SourceFunction.SourceContext<Long> ctx) |
void |
InputFormatSourceFunction.run(SourceFunction.SourceContext<OUT> ctx) |
void |
SocketTextStreamFunction.run(SourceFunction.SourceContext<String> ctx) |
void |
FromSplittableIteratorFunction.run(SourceFunction.SourceContext<T> ctx) |
void |
SourceFunction.run(SourceFunction.SourceContext<T> ctx)
Starts the source.
|
void |
FromIteratorFunction.run(SourceFunction.SourceContext<T> ctx) |
void |
FromElementsFunction.run(SourceFunction.SourceContext<T> ctx) |
void |
FileMonitoringFunction.run(SourceFunction.SourceContext<org.apache.flink.api.java.tuple.Tuple3<String,Long,Long>> ctx)
Deprecated.
|
Modifier and Type | Class and Description |
---|---|
static class |
StreamSource.AutomaticWatermarkContext<T>
SourceFunction.SourceContext to be used for sources with automatic timestamps
and watermark emission. |
static class |
StreamSource.ManualWatermarkContext<T>
A SourceContext for event time.
|
static class |
StreamSource.NonTimestampContext<T>
A source context that attached
-1 as a timestamp to all records, and that
does not forward watermarks. |
Copyright © 2014–2016 The Apache Software Foundation. All rights reserved.