public class SparkUnboundedSource
extends java.lang.Object
UnboundedSources.
 This read is a composite of the following steps:
Source and an optional UnboundedSource.CheckpointMark to start from.JavaPairDStream.mapWithState(StateSpec)
 using the StateSpecFunctions.mapSourceFunction(org.apache.beam.runners.core.construction.SerializablePipelineOptions, java.lang.String) mapping function,
 which manages the state of the CheckpointMark per partition.| Modifier and Type | Class and Description | 
|---|---|
| static class  | SparkUnboundedSource.MetadataA metadata holder for an input stream partition. | 
| Constructor and Description | 
|---|
| SparkUnboundedSource() | 
| Modifier and Type | Method and Description | 
|---|---|
| static <T,CheckpointMarkT extends UnboundedSource.CheckpointMark> | read(org.apache.spark.streaming.api.java.JavaStreamingContext jssc,
    org.apache.beam.runners.core.construction.SerializablePipelineOptions rc,
    UnboundedSource<T,CheckpointMarkT> source,
    java.lang.String stepName) | 
public static <T,CheckpointMarkT extends UnboundedSource.CheckpointMark> org.apache.beam.runners.spark.translation.streaming.UnboundedDataset<T> read(org.apache.spark.streaming.api.java.JavaStreamingContext jssc, org.apache.beam.runners.core.construction.SerializablePipelineOptions rc, UnboundedSource<T,CheckpointMarkT> source, java.lang.String stepName)