Uses of Class
com.google.cloud.pubsublite.Offset
-
Packages that use Offset Package Description com.google.cloud.pubsublite com.google.cloud.pubsublite.internal com.google.cloud.pubsublite.internal.testing com.google.cloud.pubsublite.internal.wire -
-
Uses of Offset in com.google.cloud.pubsublite
Methods in com.google.cloud.pubsublite that return Offset Modifier and Type Method Description static Offset
Offset. of(long offset)
Create an offset.abstract Offset
MessageMetadata. offset()
The offset a message was assigned.abstract Offset
SequencedMessage. offset()
The offset for this message.Methods in com.google.cloud.pubsublite with parameters of type Offset Modifier and Type Method Description int
Offset. compareTo(Offset o)
static MessageMetadata
MessageMetadata. of(Partition partition, Offset offset)
Construct a MessageMetadata from a Partition and Offset.static SequencedMessage
SequencedMessage. of(Message message, com.google.protobuf.Timestamp publishTime, Offset offset, long byteSize)
Construct a SequencedMessage from its components. -
Uses of Offset in com.google.cloud.pubsublite.internal
Methods in com.google.cloud.pubsublite.internal that return types with arguments of type Offset Modifier and Type Method Description com.google.api.core.ApiFuture<Map<Partition,Offset>>
CursorClient. listPartitionCursors(SubscriptionPath path)
List the cursors for a given subscription.com.google.api.core.ApiFuture<Map<Partition,Offset>>
CursorClientImpl. listPartitionCursors(SubscriptionPath path)
Optional<Offset>
BufferingPullSubscriber. nextOffset()
Optional<Offset>
PullSubscriber. nextOffset()
Methods in com.google.cloud.pubsublite.internal with parameters of type Offset Modifier and Type Method Description com.google.api.core.ApiFuture<Void>
CursorClient. commitCursor(SubscriptionPath path, Partition partition, Offset offset)
Commit a single cursor.com.google.api.core.ApiFuture<Void>
CursorClientImpl. commitCursor(SubscriptionPath path, Partition partition, Offset offset)
com.google.api.core.ApiFuture<ComputeMessageStatsResponse>
TopicStatsClient. computeMessageStats(TopicPath path, Partition partition, Offset start, Offset end)
Compute statistics about the messages between two cursors in a topic partition.com.google.api.core.ApiFuture<ComputeMessageStatsResponse>
TopicStatsClientImpl. computeMessageStats(TopicPath path, Partition partition, Offset start, Offset end)
-
Uses of Offset in com.google.cloud.pubsublite.internal.testing
Methods in com.google.cloud.pubsublite.internal.testing that return Offset Modifier and Type Method Description static Offset
UnitTestExamples. exampleOffset()
-
Uses of Offset in com.google.cloud.pubsublite.internal.wire
Methods in com.google.cloud.pubsublite.internal.wire that return types with arguments of type Offset Modifier and Type Method Description Publisher<Offset>
PublisherBuilder.Builder. build()
SequencedPublisher<Offset>
PublisherBuilder.Builder. buildSequenced()
Builds the underlying publisher that can accept externally assigned sequence numbers for each message.com.google.api.core.ApiFuture<Offset>
PublisherImpl. publish(PubSubMessage message, PublishSequenceNumber sequenceNumber)
com.google.api.core.ApiFuture<Offset>
SequenceAssigningPublisher. publish(PubSubMessage message)
Methods in com.google.cloud.pubsublite.internal.wire with parameters of type Offset Modifier and Type Method Description void
ConnectedCommitterImpl. commit(Offset offset)
com.google.api.core.ApiFuture<Void>
BatchingCommitter. commitOffset(Offset offset)
com.google.api.core.ApiFuture<Void>
Committer. commitOffset(Offset offset)
com.google.api.core.ApiFuture<Void>
CommitterImpl. commitOffset(Offset offset)
-