Modifier and Type | Method and Description |
---|---|
void |
FileSinkProgram.Generator.run(SourceFunction.SourceContext<Tuple2<Integer,Integer>> ctx) |
Modifier and Type | Method and Description |
---|---|
void |
StreamSQLTestProgram.Generator.run(SourceFunction.SourceContext<Row> ctx) |
Modifier and Type | Method and Description |
---|---|
void |
StatefulSequenceSource.run(SourceFunction.SourceContext<Long> ctx) |
void |
InputFormatSourceFunction.run(SourceFunction.SourceContext<OUT> ctx) |
void |
SocketTextStreamFunction.run(SourceFunction.SourceContext<String> ctx) |
void |
SourceFunction.run(SourceFunction.SourceContext<T> ctx)
Starts the source.
|
void |
FromIteratorFunction.run(SourceFunction.SourceContext<T> ctx) |
void |
FromSplittableIteratorFunction.run(SourceFunction.SourceContext<T> ctx) |
void |
FromElementsFunction.run(SourceFunction.SourceContext<T> ctx) |
void |
ContinuousFileMonitoringFunction.run(SourceFunction.SourceContext<TimestampedFileInputSplit> context) |
void |
FileMonitoringFunction.run(SourceFunction.SourceContext<Tuple3<String,Long,Long>> ctx)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
DataGeneratorSource.run(SourceFunction.SourceContext<T> ctx) |
Modifier and Type | Method and Description |
---|---|
static <OUT> SourceFunction.SourceContext<OUT> |
StreamSourceContexts.getSourceContext(TimeCharacteristic timeCharacteristic,
ProcessingTimeService processingTimeService,
Object checkpointLock,
Output<StreamRecord<OUT>> output,
long watermarkInterval,
long idleTimeout,
boolean emitProgressiveWatermarks)
Depending on the
TimeCharacteristic , this method will return the adequate SourceFunction.SourceContext . |
Modifier and Type | Method and Description |
---|---|
void |
PubSubSource.run(SourceFunction.SourceContext<OUT> sourceContext) |
Modifier and Type | Method and Description |
---|---|
protected AbstractFetcher<T,?> |
FlinkKafkaConsumer.createFetcher(SourceFunction.SourceContext<T> sourceContext,
Map<KafkaTopicPartition,Long> assignedPartitionsWithInitialOffsets,
SerializedValue<WatermarkStrategy<T>> watermarkStrategy,
StreamingRuntimeContext runtimeContext,
OffsetCommitMode offsetCommitMode,
MetricGroup consumerMetricGroup,
boolean useMetrics)
Deprecated.
|
protected abstract AbstractFetcher<T,?> |
FlinkKafkaConsumerBase.createFetcher(SourceFunction.SourceContext<T> sourceContext,
Map<KafkaTopicPartition,Long> subscribedPartitionsToStartOffsets,
SerializedValue<WatermarkStrategy<T>> watermarkStrategy,
StreamingRuntimeContext runtimeContext,
OffsetCommitMode offsetCommitMode,
MetricGroup kafkaMetricGroup,
boolean useMetrics)
Creates the fetcher that connect to the Kafka brokers, pulls data, deserialized the data, and
emits it into the data streams.
|
void |
FlinkKafkaConsumerBase.run(SourceFunction.SourceContext<T> sourceContext) |
Modifier and Type | Field and Description |
---|---|
protected SourceFunction.SourceContext<T> |
AbstractFetcher.sourceContext
The source context to emit records and watermarks to.
|
Constructor and Description |
---|
AbstractFetcher(SourceFunction.SourceContext<T> sourceContext,
Map<KafkaTopicPartition,Long> seedPartitionsWithInitialOffsets,
SerializedValue<WatermarkStrategy<T>> watermarkStrategy,
ProcessingTimeService processingTimeProvider,
long autoWatermarkInterval,
ClassLoader userCodeClassLoader,
MetricGroup consumerMetricGroup,
boolean useMetrics) |
KafkaFetcher(SourceFunction.SourceContext<T> sourceContext,
Map<KafkaTopicPartition,Long> assignedPartitionsWithInitialOffsets,
SerializedValue<WatermarkStrategy<T>> watermarkStrategy,
ProcessingTimeService processingTimeProvider,
long autoWatermarkInterval,
ClassLoader userCodeClassLoader,
String taskNameWithSubtasks,
KafkaDeserializationSchema<T> deserializer,
Properties kafkaProperties,
long pollTimeout,
MetricGroup subtaskMetricGroup,
MetricGroup consumerMetricGroup,
boolean useMetrics) |
KafkaShuffleFetcher(SourceFunction.SourceContext<T> sourceContext,
Map<KafkaTopicPartition,Long> assignedPartitionsWithInitialOffsets,
SerializedValue<WatermarkStrategy<T>> watermarkStrategy,
ProcessingTimeService processingTimeProvider,
long autoWatermarkInterval,
ClassLoader userCodeClassLoader,
String taskNameWithSubtasks,
KafkaDeserializationSchema<T> deserializer,
Properties kafkaProperties,
long pollTimeout,
MetricGroup subtaskMetricGroup,
MetricGroup consumerMetricGroup,
boolean useMetrics,
TypeSerializer<T> typeSerializer,
int producerParallelism) |
SourceContextWatermarkOutputAdapter(SourceFunction.SourceContext<T> sourceContext) |
Modifier and Type | Method and Description |
---|---|
protected AbstractFetcher<T,?> |
FlinkKafkaShuffleConsumer.createFetcher(SourceFunction.SourceContext<T> sourceContext,
Map<KafkaTopicPartition,Long> assignedPartitionsWithInitialOffsets,
SerializedValue<WatermarkStrategy<T>> watermarkStrategy,
StreamingRuntimeContext runtimeContext,
OffsetCommitMode offsetCommitMode,
MetricGroup consumerMetricGroup,
boolean useMetrics) |
Modifier and Type | Method and Description |
---|---|
protected KinesisDataFetcher<T> |
FlinkDynamoDBStreamsConsumer.createFetcher(List<String> streams,
SourceFunction.SourceContext<T> sourceContext,
RuntimeContext runtimeContext,
Properties configProps,
KinesisDeserializationSchema<T> deserializationSchema) |
protected KinesisDataFetcher<T> |
FlinkKinesisConsumer.createFetcher(List<String> streams,
SourceFunction.SourceContext<T> sourceContext,
RuntimeContext runtimeContext,
Properties configProps,
KinesisDeserializationSchema<T> deserializationSchema)
This method is exposed for tests that need to mock the KinesisDataFetcher in the consumer.
|
void |
FlinkKinesisConsumer.run(SourceFunction.SourceContext<T> sourceContext) |
Modifier and Type | Method and Description |
---|---|
void |
NiFiSource.run(SourceFunction.SourceContext<NiFiDataPacket> ctx)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
void |
RMQSource.run(SourceFunction.SourceContext<OUT> ctx) |
Modifier and Type | Method and Description |
---|---|
void |
WikipediaEditsSource.run(SourceFunction.SourceContext<WikipediaEditEvent> ctx) |
Modifier and Type | Method and Description |
---|---|
void |
SimpleSource.run(SourceFunction.SourceContext<Integer> ctx) |
Modifier and Type | Method and Description |
---|---|
void |
EventsGeneratorSource.run(SourceFunction.SourceContext<Event> sourceContext) |
Modifier and Type | Method and Description |
---|---|
void |
CarSource.run(SourceFunction.SourceContext<Tuple4<Integer,Integer,Double,Long>> ctx) |
Modifier and Type | Method and Description |
---|---|
void |
SequenceGeneratorSource.run(SourceFunction.SourceContext<Event> ctx) |
void |
PeriodicStreamingJob.PeriodicSourceGenerator.run(SourceFunction.SourceContext<Tuple> ctx) |
Modifier and Type | Method and Description |
---|---|
void |
FiniteTestSource.run(SourceFunction.SourceContext<T> ctx) |
Modifier and Type | Method and Description |
---|---|
void |
SocketSourceFunction.run(SourceFunction.SourceContext<RowData> ctx) |
Modifier and Type | Method and Description |
---|---|
void |
ArrowSourceFunction.run(SourceFunction.SourceContext<RowData> ctx) |
Modifier and Type | Method and Description |
---|---|
void |
StatefulStreamingJob.MySource.run(SourceFunction.SourceContext<Integer> ctx) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.