Performs an out-of-band seek for a subscription to a specified target,
which may be timestamps or named positions within the message backlog.
Seek translates these targets to cursors for each partition and
orchestrates subscribers to start consuming messages from these seek
cursors.
If an operation is returned, the seek has been registered and subscribers
will eventually receive messages from the seek cursors (i.e. eventual
consistency), as long as they are using a minimum supported client library
version and not a system that tracks cursors independently of Pub/Sub Lite
(e.g. Apache Beam, Dataflow, Spark). The seek operation will fail for
unsupported clients.
If clients would like to know when subscribers react to the seek (or not),
they can poll the operation. The seek operation will succeed and complete
once subscribers are ready to receive messages from the seek cursors for
all partitions of the topic. This means that the seek operation will not
complete until all subscribers come online.
If the previous seek operation has not yet completed, it will be aborted
and the new invocation of seek will supersede it.
[[["Easy to understand","easyToUnderstand","thumb-up"],["Solved my problem","solvedMyProblem","thumb-up"],["Other","otherUp","thumb-up"]],[["Hard to understand","hardToUnderstand","thumb-down"],["Incorrect information or sample code","incorrectInformationOrSampleCode","thumb-down"],["Missing the information/samples I need","missingTheInformationSamplesINeed","thumb-down"],["Other","otherDown","thumb-down"]],["Last updated 2025-08-28 UTC."],[],[],null,["# Class AdminServiceGrpc.AdminServiceBlockingV2Stub (1.15.13)\n\nVersion latestkeyboard_arrow_down\n\n- [1.15.13 (latest)](/java/docs/reference/google-cloud-pubsublite/latest/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.15.12](/java/docs/reference/google-cloud-pubsublite/1.15.12/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.14.8](/java/docs/reference/google-cloud-pubsublite/1.14.8/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.13.8](/java/docs/reference/google-cloud-pubsublite/1.13.8/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.12.22](/java/docs/reference/google-cloud-pubsublite/1.12.22/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.11.2](/java/docs/reference/google-cloud-pubsublite/1.11.2/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.10.0](/java/docs/reference/google-cloud-pubsublite/1.10.0/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.9.4](/java/docs/reference/google-cloud-pubsublite/1.9.4/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.8.0](/java/docs/reference/google-cloud-pubsublite/1.8.0/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.7.1](/java/docs/reference/google-cloud-pubsublite/1.7.1/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.6.3](/java/docs/reference/google-cloud-pubsublite/1.6.3/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.5.5](/java/docs/reference/google-cloud-pubsublite/1.5.5/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub)\n- [1.4.12](/java/docs/reference/google-cloud-pubsublite/1.4.12/com.google.cloud.pubsublite.proto.AdminServiceGrpc.AdminServiceBlockingV2Stub) \n\n public static final class AdminServiceGrpc.AdminServiceBlockingV2Stub extends AbstractBlockingStub\u003cAdminServiceGrpc.AdminServiceBlockingV2Stub\u003e\n\nA stub to allow clients to do synchronous rpc calls to service AdminService.\n\nThe service that a client application uses to manage topics and\nsubscriptions, such creating, listing, and deleting topics and subscriptions. \n\nInheritance\n-----------\n\n[java.lang.Object](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html) \\\u003e io.grpc.stub.AbstractStub \\\u003e io.grpc.stub.AbstractBlockingStub \\\u003e AdminServiceGrpc.AdminServiceBlockingV2Stub \n\nInherited Members\n-----------------\n\nio.grpc.stub.AbstractBlockingStub.\\\u003cT\\\u003enewStub(io.grpc.stub.AbstractStub.StubFactory\\\u003cT\\\u003e,io.grpc.Channel) \nio.grpc.stub.AbstractBlockingStub.\\\u003cT\\\u003enewStub(io.grpc.stub.AbstractStub.StubFactory\\\u003cT\\\u003e,io.grpc.Channel,io.grpc.CallOptions) \nio.grpc.stub.AbstractStub.\\\u003cT\\\u003ewithOption(io.grpc.CallOptions.Key\\\u003cT\\\u003e,T) \nio.grpc.stub.AbstractStub.build(io.grpc.Channel,io.grpc.CallOptions) \nio.grpc.stub.AbstractStub.getCallOptions() \nio.grpc.stub.AbstractStub.getChannel() \nio.grpc.stub.AbstractStub.withCallCredentials(io.grpc.CallCredentials) \nio.grpc.stub.AbstractStub.withChannel(io.grpc.Channel) \nio.grpc.stub.AbstractStub.withCompression(java.lang.String) \nio.grpc.stub.AbstractStub.withDeadline(io.grpc.Deadline) \nio.grpc.stub.AbstractStub.withDeadlineAfter(java.time.Duration) \nio.grpc.stub.AbstractStub.withDeadlineAfter(long,java.util.concurrent.TimeUnit) \nio.grpc.stub.AbstractStub.withExecutor(java.util.concurrent.Executor) \nio.grpc.stub.AbstractStub.withInterceptors(io.grpc.ClientInterceptor...) \nio.grpc.stub.AbstractStub.withMaxInboundMessageSize(int) \nio.grpc.stub.AbstractStub.withMaxOutboundMessageSize(int) \nio.grpc.stub.AbstractStub.withOnReadyThreshold(int) \nio.grpc.stub.AbstractStub.withWaitForReady() \n[Object.clone()](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#clone--) \n[Object.equals(Object)](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#equals-java.lang.Object-) \n[Object.finalize()](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#finalize--) \n[Object.getClass()](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#getClass--) \n[Object.hashCode()](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#hashCode--) \n[Object.notify()](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#notify--) \n[Object.notifyAll()](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#notifyAll--) \n[Object.toString()](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#toString--) \n[Object.wait()](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#wait--) \n[Object.wait(long)](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#wait-long-) \n[Object.wait(long,int)](https://docs.oracle.com/javase/8/docs/api/java/lang/Object.html#wait-long-int-)\n\nMethods\n-------\n\n### build(Channel channel, CallOptions callOptions)\n\n protected AdminServiceGrpc.AdminServiceBlockingV2Stub build(Channel channel, CallOptions callOptions)\n\n**Overrides** \nio.grpc.stub.AbstractStub.build(io.grpc.Channel,io.grpc.CallOptions)\n\n### createReservation(CreateReservationRequest request)\n\n public Reservation createReservation(CreateReservationRequest request)\n\nCreates a new reservation.\n\n### createSubscription(CreateSubscriptionRequest request)\n\n public Subscription createSubscription(CreateSubscriptionRequest request)\n\nCreates a new subscription.\n\n### createTopic(CreateTopicRequest request)\n\n public Topic createTopic(CreateTopicRequest request)\n\nCreates a new topic.\n\n### deleteReservation(DeleteReservationRequest request)\n\n public Empty deleteReservation(DeleteReservationRequest request)\n\nDeletes the specified reservation.\n\n### deleteSubscription(DeleteSubscriptionRequest request)\n\n public Empty deleteSubscription(DeleteSubscriptionRequest request)\n\nDeletes the specified subscription.\n\n### deleteTopic(DeleteTopicRequest request)\n\n public Empty deleteTopic(DeleteTopicRequest request)\n\nDeletes the specified topic.\n\n### getReservation(GetReservationRequest request)\n\n public Reservation getReservation(GetReservationRequest request)\n\nReturns the reservation configuration.\n\n### getSubscription(GetSubscriptionRequest request)\n\n public Subscription getSubscription(GetSubscriptionRequest request)\n\nReturns the subscription configuration.\n\n### getTopic(GetTopicRequest request)\n\n public Topic getTopic(GetTopicRequest request)\n\nReturns the topic configuration.\n\n### getTopicPartitions(GetTopicPartitionsRequest request)\n\n public TopicPartitions getTopicPartitions(GetTopicPartitionsRequest request)\n\nReturns the partition information for the requested topic.\n\n### listReservationTopics(ListReservationTopicsRequest request)\n\n public ListReservationTopicsResponse listReservationTopics(ListReservationTopicsRequest request)\n\nLists the topics attached to the specified reservation.\n\n### listReservations(ListReservationsRequest request)\n\n public ListReservationsResponse listReservations(ListReservationsRequest request)\n\nReturns the list of reservations for the given project.\n\n### listSubscriptions(ListSubscriptionsRequest request)\n\n public ListSubscriptionsResponse listSubscriptions(ListSubscriptionsRequest request)\n\nReturns the list of subscriptions for the given project.\n\n### listTopicSubscriptions(ListTopicSubscriptionsRequest request)\n\n public ListTopicSubscriptionsResponse listTopicSubscriptions(ListTopicSubscriptionsRequest request)\n\nLists the subscriptions attached to the specified topic.\n\n### listTopics(ListTopicsRequest request)\n\n public ListTopicsResponse listTopics(ListTopicsRequest request)\n\nReturns the list of topics for the given project.\n\n### seekSubscription(SeekSubscriptionRequest request)\n\n public Operation seekSubscription(SeekSubscriptionRequest request)\n\nPerforms an out-of-band seek for a subscription to a specified target,\nwhich may be timestamps or named positions within the message backlog.\nSeek translates these targets to cursors for each partition and\norchestrates subscribers to start consuming messages from these seek\ncursors.\nIf an operation is returned, the seek has been registered and subscribers\nwill eventually receive messages from the seek cursors (i.e. eventual\nconsistency), as long as they are using a minimum supported client library\nversion and not a system that tracks cursors independently of Pub/Sub Lite\n(e.g. Apache Beam, Dataflow, Spark). The seek operation will fail for\nunsupported clients.\nIf clients would like to know when subscribers react to the seek (or not),\nthey can poll the operation. The seek operation will succeed and complete\nonce subscribers are ready to receive messages from the seek cursors for\nall partitions of the topic. This means that the seek operation will not\ncomplete until all subscribers come online.\nIf the previous seek operation has not yet completed, it will be aborted\nand the new invocation of seek will supersede it.\n\n### updateReservation(UpdateReservationRequest request)\n\n public Reservation updateReservation(UpdateReservationRequest request)\n\nUpdates properties of the specified reservation.\n\n### updateSubscription(UpdateSubscriptionRequest request)\n\n public Subscription updateSubscription(UpdateSubscriptionRequest request)\n\nUpdates properties of the specified subscription.\n\n### updateTopic(UpdateTopicRequest request)\n\n public Topic updateTopic(UpdateTopicRequest request)\n\nUpdates properties of the specified topic."]]