Modifier and Type | Interface and Description |
---|---|
interface |
ExternallyInducedSourceReader<T,SplitT extends SourceSplit>
Sources that implement this interface do not trigger checkpoints when receiving a trigger message
from the checkpoint coordinator, but when their input data/events indicate that a checkpoint
should be triggered.
|
Modifier and Type | Method and Description |
---|---|
SourceReader<T,SplitT> |
Source.createReader(SourceReaderContext readerContext)
Creates a new reader to read data from the splits it gets assigned.
|
Modifier and Type | Method and Description |
---|---|
SourceReader<Long,NumberSequenceSource.NumberSequenceSplit> |
NumberSequenceSource.createReader(SourceReaderContext readerContext) |
Modifier and Type | Class and Description |
---|---|
class |
IteratorSourceReader<E,IterT extends Iterator<E>,SplitT extends IteratorSourceSplit<E,IterT>>
A
SourceReader that returns the values of an iterator, supplied via an IteratorSourceSplit . |
Modifier and Type | Class and Description |
---|---|
class |
SingleThreadMultiplexSourceReaderBase<E,T,SplitT extends SourceSplit,SplitStateT>
A base for
SourceReader s that read splits with one thread using one SplitReader . |
class |
SourceReaderBase<E,T,SplitT extends SourceSplit,SplitStateT>
An abstract implementation of
SourceReader which provides some sychronization between the
mail box main thread and the SourceReader internal threads. |
Modifier and Type | Method and Description |
---|---|
SourceReader<T,SplitT> |
AbstractFileSource.createReader(SourceReaderContext readerContext) |
Modifier and Type | Class and Description |
---|---|
class |
FileSourceReader<T,SplitT extends FileSourceSplit>
A
SourceReader that read records from FileSourceSplit . |
Modifier and Type | Method and Description |
---|---|
SourceReader<OUT,KafkaPartitionSplit> |
KafkaSource.createReader(SourceReaderContext readerContext) |
Modifier and Type | Class and Description |
---|---|
class |
KafkaSourceReader<T>
The source reader for Kafka partitions.
|
Modifier and Type | Method and Description |
---|---|
protected abstract SourceReader<Integer,SplitT> |
SourceReaderTestBase.createReader() |
Modifier and Type | Method and Description |
---|---|
SourceReader<OUT,SplitT> |
SourceOperator.getSourceReader() |
Constructor and Description |
---|
SourceOperator(FunctionWithException<SourceReaderContext,SourceReader<OUT,SplitT>,Exception> readerFactory,
OperatorEventGateway operatorEventGateway,
SimpleVersionedSerializer<SplitT> splitSerializer,
WatermarkStrategy<OUT> watermarkStrategy,
ProcessingTimeService timeService,
Configuration configuration,
String localHostname,
boolean emitProgressiveWatermarks) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.