java.lang.Object
org.apache.beam.runners.flink.translation.wrappers.streaming.io.source.FlinkSourceSplit<T>
Type Parameters:
T - The output type of the encapsulated Beam Source.
All Implemented Interfaces:
Serializable, org.apache.flink.api.connector.source.SourceSplit

public class FlinkSourceSplit<T> extends Object implements org.apache.flink.api.connector.source.SourceSplit, Serializable
A Flink SourceSplit implementation that encapsulates a Beam Source. This class also serves as the holder of the checkpoint state of the Beam Reader created from the encapsulated source. So, the Source can recreate the Reader from the checkpointed state upon failure recovery.
See Also:
  • Constructor Details

  • Method Details

    • splitIndex

      public int splitIndex()
    • getSplitState

      public byte @Nullable [] getSplitState()
    • getBeamSplitSource

      public Source<T> getBeamSplitSource()
    • splitId

      public String splitId()
      Specified by:
      splitId in interface org.apache.flink.api.connector.source.SourceSplit
    • getCheckpointMark

      public @Nullable UnboundedSource.CheckpointMark getCheckpointMark()
    • toString

      public String toString()
      Overrides:
      toString in class Object
    • serializer

      public static <T> org.apache.flink.core.io.SimpleVersionedSerializer<FlinkSourceSplit<T>> serializer()