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
Name Description
cursorClient com.google.cloud.pubsublite.internal.CursorClient
committer MultiPartitionCommitter
partitionSubscriberFactory PartitionSubscriberFactory
headOffsetReader PerTopicHeadOffsetReader
subscriptionPath com.google.cloud.pubsublite.SubscriptionPath
flowControlSettings com.google.cloud.pubsublite.cloudpubsub.FlowControlSettings
maxMessagesPerBatch long

Methods

commit(Offset end)

public void commit(Offset end)
Parameter
Name Description
end org.apache.spark.sql.sources.v2.reader.streaming.Offset

deserializeOffset(String json)

public Offset deserializeOffset(String json)
Parameter
Name Description
json String
Returns
Type Description
org.apache.spark.sql.sources.v2.reader.streaming.Offset

getEndOffset()

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

getStartOffset()

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

planInputPartitions()

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

readSchema()

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

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

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

stop()

public void stop()