Class LazyFlinkSourceSplitEnumerator<T>

java.lang.Object
org.apache.beam.runners.flink.translation.wrappers.streaming.io.source.LazyFlinkSourceSplitEnumerator<T>
Type Parameters:
T - The output type of the encapsulated Beam Source.
All Implemented Interfaces:
AutoCloseable, org.apache.flink.api.common.state.CheckpointListener, org.apache.flink.api.connector.source.SplitEnumerator<FlinkSourceSplit<T>,Map<Integer,List<FlinkSourceSplit<T>>>>

public class LazyFlinkSourceSplitEnumerator<T> extends Object implements org.apache.flink.api.connector.source.SplitEnumerator<FlinkSourceSplit<T>,Map<Integer,List<FlinkSourceSplit<T>>>>
A Flink SplitEnumerator implementation that holds a Beam Source and does the following:
  • Split the Beam Source to desired number of splits.
  • Lazily assign the splits to the Flink Source Reader.