Class PslMicroBatchReader (0.3.4)

public class PslMicroBatchReader implements MicroBatchReader

Inheritance

java.lang.Object > PslMicroBatchReader

Implements

org.apache.spark.sql.sources.v2.reader.streaming.MicroBatchReader

Constructors

PslMicroBatchReader(CursorClient cursorClient, MultiPartitionCommitter committer, PartitionSubscriberFactory partitionSubscriberFactory, PerTopicHeadOffsetReader headOffsetReader, SubscriptionPath subscriptionPath, FlowControlSettings flowControlSettings, long maxMessagesPerBatch)

public PslMicroBatchReader(CursorClient cursorClient, MultiPartitionCommitter committer, PartitionSubscriberFactory partitionSubscriberFactory, PerTopicHeadOffsetReader headOffsetReader, SubscriptionPath subscriptionPath, FlowControlSettings flowControlSettings, long maxMessagesPerBatch)
Parameters
NameDescription
cursorClientcom.google.cloud.pubsublite.internal.CursorClient
committerMultiPartitionCommitter
partitionSubscriberFactoryPartitionSubscriberFactory
headOffsetReaderPerTopicHeadOffsetReader
subscriptionPathcom.google.cloud.pubsublite.SubscriptionPath
flowControlSettingscom.google.cloud.pubsublite.cloudpubsub.FlowControlSettings
maxMessagesPerBatchlong

Methods

commit(Offset end)

public void commit(Offset end)
Parameter
NameDescription
endorg.apache.spark.sql.sources.v2.reader.streaming.Offset

deserializeOffset(String json)

public Offset deserializeOffset(String json)
Parameter
NameDescription
jsonString
Returns
TypeDescription
org.apache.spark.sql.sources.v2.reader.streaming.Offset

getEndOffset()

public Offset getEndOffset()
Returns
TypeDescription
org.apache.spark.sql.sources.v2.reader.streaming.Offset

getStartOffset()

public Offset getStartOffset()
Returns
TypeDescription
org.apache.spark.sql.sources.v2.reader.streaming.Offset

planInputPartitions()

public List<InputPartition<InternalRow>> planInputPartitions()
Returns
TypeDescription
List<org.apache.spark.sql.sources.v2.reader.InputPartition<org.apache.spark.sql.catalyst.InternalRow>>

readSchema()

public StructType readSchema()
Returns
TypeDescription
org.apache.spark.sql.types.StructType

setOffsetRange(Optional<Offset> start, Optional<Offset> end)

public void setOffsetRange(Optional<Offset> start, Optional<Offset> end)
Parameters
NameDescription
startOptional<org.apache.spark.sql.sources.v2.reader.streaming.Offset>
endOptional<org.apache.spark.sql.sources.v2.reader.streaming.Offset>

stop()

public void stop()