Uses of Class
com.google.cloud.pubsublite.Partition
-
-
Uses of Partition in com.google.cloud.pubsublite
Methods in com.google.cloud.pubsublite that return Partition Modifier and Type Method Description static Partition
Partition. of(long partition)
Create a partition from its long value.abstract Partition
MessageMetadata. partition()
The partition a message was published to.Methods in com.google.cloud.pubsublite with parameters of type Partition Modifier and Type Method Description static MessageMetadata
MessageMetadata. of(Partition partition, Offset offset)
Construct a MessageMetadata from a Partition and Offset. -
Uses of Partition in com.google.cloud.pubsublite.cloudpubsub
Methods in com.google.cloud.pubsublite.cloudpubsub with parameters of type Partition Modifier and Type Method Description SubscriberServiceClient
PartitionSubscriberClientSupplier. get(SubscriptionPath subscription, Partition partition)
Creates a new SubscriberServiceClient for the specified subscription and partition.Method parameters in com.google.cloud.pubsublite.cloudpubsub with type arguments of type Partition Modifier and Type Method Description void
ReassignmentHandler. handleReassignment(Set<Partition> before, Set<Partition> after)
Called with the previous and new assignment delivered to this client on an assignment change.abstract SubscriberSettings.Builder
SubscriberSettings.Builder. setPartitions(List<Partition> partition)
The partitions this subscriber should connect to to receive messages. -
Uses of Partition in com.google.cloud.pubsublite.cloudpubsub.internal
Methods in com.google.cloud.pubsublite.cloudpubsub.internal with parameters of type Partition Modifier and Type Method Description Subscriber
PartitionSubscriberFactory. newSubscriber(Partition partition)
-
Uses of Partition in com.google.cloud.pubsublite.internal
Methods in com.google.cloud.pubsublite.internal that return Partition Modifier and Type Method Description Partition
DefaultRoutingPolicy. route(PubSubMessage message)
Partition
RoutingPolicy. route(PubSubMessage messageKey)
Methods in com.google.cloud.pubsublite.internal that return types with arguments of type Partition 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)
Methods in com.google.cloud.pubsublite.internal with parameters of type Partition 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<Optional<Cursor>>
TopicStatsClient. computeCursorForEventTime(TopicPath path, Partition partition, com.google.protobuf.Timestamp eventTime)
Compute the cursor of the first message with event time greater than or equal to the specified event time, for a topic partition.com.google.api.core.ApiFuture<Optional<Cursor>>
TopicStatsClientImpl. computeCursorForEventTime(TopicPath path, Partition partition, com.google.protobuf.Timestamp eventTime)
com.google.api.core.ApiFuture<Optional<Cursor>>
TopicStatsClient. computeCursorForPublishTime(TopicPath path, Partition partition, com.google.protobuf.Timestamp publishTime)
Compute the cursor of the first message with publish time greater than or equal to the specified publish time, for a topic partition.com.google.api.core.ApiFuture<Optional<Cursor>>
TopicStatsClientImpl. computeCursorForPublishTime(TopicPath path, Partition partition, com.google.protobuf.Timestamp publishTime)
com.google.api.core.ApiFuture<Cursor>
TopicStatsClient. computeHeadCursor(TopicPath path, Partition partition)
Compute the head cursor for the partition.com.google.api.core.ApiFuture<Cursor>
TopicStatsClientImpl. computeHeadCursor(TopicPath path, Partition partition)
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 Partition in com.google.cloud.pubsublite.internal.testing
Methods in com.google.cloud.pubsublite.internal.testing that return Partition Modifier and Type Method Description static Partition
UnitTestExamples. examplePartition()
-
Uses of Partition in com.google.cloud.pubsublite.internal.wire
Methods in com.google.cloud.pubsublite.internal.wire with parameters of type Partition Modifier and Type Method Description Publisher<MessageMetadata>
PartitionPublisherFactory. newPublisher(Partition partition)
static RoutingMetadata
RoutingMetadata. of(SubscriptionPath subscription, Partition partition)
static RoutingMetadata
RoutingMetadata. of(TopicPath topic, Partition partition)
abstract CommitterSettings.Builder
CommitterSettings.Builder. setPartition(Partition partition)
abstract PublisherBuilder.Builder
PublisherBuilder.Builder. setPartition(Partition partition)
abstract SinglePartitionPublisherBuilder.Builder
SinglePartitionPublisherBuilder.Builder. setPartition(Partition partition)
abstract SubscriberBuilder.Builder
SubscriberBuilder.Builder. setPartition(Partition partition)
Method parameters in com.google.cloud.pubsublite.internal.wire with type arguments of type Partition Modifier and Type Method Description void
PartitionAssignmentReceiver. handleAssignment(Set<Partition> assignment)
-