Uses of Class
com.google.cloud.pubsublite.TopicPath
-
-
Uses of TopicPath in com.google.cloud.pubsublite
Methods in com.google.cloud.pubsublite that return TopicPath Modifier and Type Method Description abstract TopicPath
TopicPath.Builder. build()
Build a new TopicPath.static TopicPath
TopicPath. parse(String path)
Methods in com.google.cloud.pubsublite that return types with arguments of type TopicPath Modifier and Type Method Description com.google.api.core.ApiFuture<List<TopicPath>>
AdminClient. listReservationTopics(ReservationPath path)
Get the list of topics for the reservation with idid
if it exists.Methods in com.google.cloud.pubsublite with parameters of type TopicPath Modifier and Type Method Description com.google.api.core.ApiFuture<Void>
AdminClient. deleteTopic(TopicPath path)
Delete the topic with idid
if it exists.com.google.api.core.ApiFuture<Topic>
AdminClient. getTopic(TopicPath path)
Get the topic with idid
if it exists.com.google.api.core.ApiFuture<Long>
AdminClient. getTopicPartitionCount(TopicPath path)
Get the partitioning info for the topic with idid
if it exists.com.google.api.core.ApiFuture<List<SubscriptionPath>>
AdminClient. listTopicSubscriptions(TopicPath path)
Get the list of subscriptions for the topic with idid
if it exists.static int
PartitionLookupUtils. numPartitions(TopicPath topic)
Look up the number of partitions in a topic.static int
PartitionLookupUtils. numPartitions(TopicPath topic, AdminClient client)
Look up the number of partitions in a topic using the provided AdminClient. -
Uses of TopicPath in com.google.cloud.pubsublite.cloudpubsub
Methods in com.google.cloud.pubsublite.cloudpubsub with parameters of type TopicPath Modifier and Type Method Description abstract PublisherSettings.Builder
PublisherSettings.Builder. setTopicPath(TopicPath path)
The topic path to publish to. -
Uses of TopicPath in com.google.cloud.pubsublite.internal
Methods in com.google.cloud.pubsublite.internal that return types with arguments of type TopicPath Modifier and Type Method Description com.google.api.core.ApiFuture<List<TopicPath>>
AdminClientImpl. listReservationTopics(ReservationPath path)
Methods in com.google.cloud.pubsublite.internal with parameters of type TopicPath Modifier and Type Method Description 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)
com.google.api.core.ApiFuture<Void>
AdminClientImpl. deleteTopic(TopicPath path)
com.google.api.core.ApiFuture<Topic>
AdminClientImpl. getTopic(TopicPath path)
com.google.api.core.ApiFuture<Long>
AdminClientImpl. getTopicPartitionCount(TopicPath path)
com.google.api.core.ApiFuture<List<SubscriptionPath>>
AdminClientImpl. listTopicSubscriptions(TopicPath path)
-
Uses of TopicPath in com.google.cloud.pubsublite.internal.testing
Methods in com.google.cloud.pubsublite.internal.testing that return TopicPath Modifier and Type Method Description static TopicPath
UnitTestExamples. exampleTopicPath()
-
Uses of TopicPath in com.google.cloud.pubsublite.internal.wire
Methods in com.google.cloud.pubsublite.internal.wire with parameters of type TopicPath Modifier and Type Method Description static RoutingMetadata
RoutingMetadata. of(TopicPath topic, Partition partition)
abstract PartitionCountWatchingPublisherSettings.Builder
PartitionCountWatchingPublisherSettings.Builder. setTopic(TopicPath path)
abstract PublisherBuilder.Builder
PublisherBuilder.Builder. setTopic(TopicPath path)
abstract RoutingPublisherBuilder.Builder
RoutingPublisherBuilder.Builder. setTopic(TopicPath path)
abstract SinglePartitionPublisherBuilder.Builder
SinglePartitionPublisherBuilder.Builder. setTopic(TopicPath topic)
Constructors in com.google.cloud.pubsublite.internal.wire with parameters of type TopicPath Constructor Description Factory(TopicPath topicPath, AdminClient adminClient, AlarmFactory alarmFactory)
-