Index

A B C D F G H I L M N O P R S T U V 
All Classes and Interfaces|All Packages|Constant Field Values

A

ack() - Method in interface com.google.cloud.pubsub.v1.AckReplyConsumer
Acknowledges that the message has been successfully processed.
ack() - Method in class com.google.cloud.pubsub.v1.AckReplyConsumerImpl
 
ack() - Method in interface com.google.cloud.pubsub.v1.AckReplyConsumerWithResponse
Acknowledges that the message has been successfully processed.
ack() - Method in class com.google.cloud.pubsub.v1.AckReplyConsumerWithResponseImpl
 
acknowledge(AcknowledgeRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Acknowledges the messages associated with the `ack_ids` in the `AcknowledgeRequest`.
acknowledge(ProjectSubscriptionName, List<String>) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
acknowledge(SubscriptionName, List<String>) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Acknowledges the messages associated with the `ack_ids` in the `AcknowledgeRequest`.
acknowledge(String, List<String>) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Acknowledges the messages associated with the `ack_ids` in the `AcknowledgeRequest`.
acknowledgeCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
acknowledgeCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
acknowledgeCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
acknowledgeCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Acknowledges the messages associated with the `ack_ids` in the `AcknowledgeRequest`.
acknowledgeSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to acknowledge.
acknowledgeSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to acknowledge.
acknowledgeSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to acknowledge.
acknowledgeSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to acknowledge.
AckReplyConsumer - Interface in com.google.cloud.pubsub.v1
Accepts a reply, sending it to the service.
AckReplyConsumerImpl - Class in com.google.cloud.pubsub.v1
 
AckReplyConsumerImpl(SettableApiFuture<MessageDispatcher.AckReply>) - Constructor for class com.google.cloud.pubsub.v1.AckReplyConsumerImpl
 
AckReplyConsumerWithResponse - Interface in com.google.cloud.pubsub.v1
Acknowledging a message in Pub/Sub means that you are done with it, and it will not be delivered to this subscription again.
AckReplyConsumerWithResponseImpl - Class in com.google.cloud.pubsub.v1
 
AckReplyConsumerWithResponseImpl(SettableApiFuture<MessageDispatcher.AckReply>, SettableApiFuture<AckResponse>) - Constructor for class com.google.cloud.pubsub.v1.AckReplyConsumerWithResponseImpl
 
AckRequestData - Class in com.google.cloud.pubsub.v1
 
AckRequestData(AckRequestData.Builder) - Constructor for class com.google.cloud.pubsub.v1.AckRequestData
 
AckRequestData.Builder - Class in com.google.cloud.pubsub.v1
Builder of AckRequestData.
AckResponse - Enum in com.google.cloud.pubsub.v1
 
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.pubsub.v1.Publisher
Wait for all work has completed execution after a Publisher.shutdown() request, or the timeout occurs, or the current thread is interrupted.
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
 

B

build() - Method in class com.google.cloud.pubsub.v1.AckRequestData.Builder
 
build() - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
 
build() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
 
build() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
 
build() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
 
build() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
 
build() - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
 
build() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
 
build() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
 
Builder() - Constructor for class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
 
Builder() - Constructor for class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
 
Builder() - Constructor for class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
 
Builder() - Constructor for class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
 
Builder() - Constructor for class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
 
Builder() - Constructor for class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
 
Builder(SchemaServiceSettings) - Constructor for class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
 
Builder(PublisherStubSettings) - Constructor for class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
 
Builder(PublisherStubSettings.Builder) - Constructor for class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
 
Builder(SchemaServiceStubSettings) - Constructor for class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
 
Builder(SchemaServiceStubSettings.Builder) - Constructor for class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
 
Builder(SubscriberStubSettings) - Constructor for class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
 
Builder(SubscriberStubSettings.Builder) - Constructor for class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
 
Builder(SubscriptionAdminSettings) - Constructor for class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
 
Builder(TopicAdminSettings) - Constructor for class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
 
Builder(String) - Constructor for class com.google.cloud.pubsub.v1.AckRequestData.Builder
 

C

close() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
 
close() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
close() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
close() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
close() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
close() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
close() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
close() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
close() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
close() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
close() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
 
close() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
 
com.google.cloud.pubsub.v1 - package com.google.cloud.pubsub.v1
A client to Cloud Pub/Sub API
com.google.cloud.pubsub.v1.stub - package com.google.cloud.pubsub.v1.stub
 
commitSchema(CommitSchemaRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Commits a new schema revision to an existing schema.
commitSchema(SchemaName, Schema) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Commits a new schema revision to an existing schema.
commitSchema(String, Schema) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Commits a new schema revision to an existing schema.
commitSchemaCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Commits a new schema revision to an existing schema.
commitSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
commitSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
commitSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
commitSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to commitSchema.
commitSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to commitSchema.
commitSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to commitSchema.
commitSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to commitSchema.
create() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Constructs an instance of SchemaServiceClient with default settings.
create() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Constructs an instance of SubscriptionAdminClient with default settings.
create() - Static method in class com.google.cloud.pubsub.v1.TopicAdminClient
Constructs an instance of TopicAdminClient with default settings.
create(ClientContext) - Static method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
create(ClientContext) - Static method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
create(ClientContext) - Static method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
create(ClientContext) - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
create(ClientContext) - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
create(ClientContext) - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
create(ClientContext, GrpcStubCallableFactory) - Static method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
create(ClientContext, GrpcStubCallableFactory) - Static method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
create(ClientContext, GrpcStubCallableFactory) - Static method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
create(ClientContext, HttpJsonStubCallableFactory) - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
create(ClientContext, HttpJsonStubCallableFactory) - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
create(ClientContext, HttpJsonStubCallableFactory) - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
create(SchemaServiceSettings) - Static method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Constructs an instance of SchemaServiceClient, using the given settings.
create(PublisherStub) - Static method in class com.google.cloud.pubsub.v1.TopicAdminClient
Constructs an instance of TopicAdminClient, using the given stub for making calls.
create(PublisherStubSettings) - Static method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
create(PublisherStubSettings) - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
create(PublisherStubSettings) - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
 
create(SchemaServiceStub) - Static method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Constructs an instance of SchemaServiceClient, using the given stub for making calls.
create(SchemaServiceStubSettings) - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
 
create(SchemaServiceStubSettings) - Static method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
create(SchemaServiceStubSettings) - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
create(SubscriberStub) - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Constructs an instance of SubscriptionAdminClient, using the given stub for making calls.
create(SubscriberStubSettings) - Static method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
create(SubscriberStubSettings) - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
create(SubscriberStubSettings) - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
 
create(SubscriptionAdminSettings) - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Constructs an instance of SubscriptionAdminClient, using the given settings.
create(TopicAdminSettings) - Static method in class com.google.cloud.pubsub.v1.TopicAdminClient
Constructs an instance of TopicAdminClient, using the given settings.
createAsync(PageContext<ListSchemaRevisionsRequest, ListSchemaRevisionsResponse, Schema>, ApiFuture<ListSchemaRevisionsResponse>) - Static method in class com.google.cloud.pubsub.v1.SchemaServiceClient.ListSchemaRevisionsPagedResponse
 
createAsync(PageContext<ListSchemasRequest, ListSchemasResponse, Schema>, ApiFuture<ListSchemasResponse>) - Static method in class com.google.cloud.pubsub.v1.SchemaServiceClient.ListSchemasPagedResponse
 
createAsync(PageContext<ListSnapshotsRequest, ListSnapshotsResponse, Snapshot>, ApiFuture<ListSnapshotsResponse>) - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient.ListSnapshotsPagedResponse
 
createAsync(PageContext<ListSubscriptionsRequest, ListSubscriptionsResponse, Subscription>, ApiFuture<ListSubscriptionsResponse>) - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient.ListSubscriptionsPagedResponse
 
createAsync(PageContext<ListTopicSnapshotsRequest, ListTopicSnapshotsResponse, String>, ApiFuture<ListTopicSnapshotsResponse>) - Static method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicSnapshotsPagedResponse
 
createAsync(PageContext<ListTopicsRequest, ListTopicsResponse, Topic>, ApiFuture<ListTopicsResponse>) - Static method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicsPagedResponse
 
createAsync(PageContext<ListTopicSubscriptionsRequest, ListTopicSubscriptionsResponse, String>, ApiFuture<ListTopicSubscriptionsResponse>) - Static method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicSubscriptionsPagedResponse
 
createBatchingCallable(GrpcCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherCallableFactory
 
createBatchingCallable(GrpcCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceCallableFactory
 
createBatchingCallable(GrpcCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberCallableFactory
 
createBatchingCallable(HttpJsonCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherCallableFactory
 
createBatchingCallable(HttpJsonCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceCallableFactory
 
createBatchingCallable(HttpJsonCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberCallableFactory
 
createBidiStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherCallableFactory
 
createBidiStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceCallableFactory
 
createBidiStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberCallableFactory
 
createClientStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherCallableFactory
 
createClientStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceCallableFactory
 
createClientStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberCallableFactory
 
createCollection(List<SchemaServiceClient.ListSchemaRevisionsPage>, int) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient.ListSchemaRevisionsFixedSizeCollection
 
createCollection(List<SchemaServiceClient.ListSchemasPage>, int) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient.ListSchemasFixedSizeCollection
 
createCollection(List<SubscriptionAdminClient.ListSnapshotsPage>, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient.ListSnapshotsFixedSizeCollection
 
createCollection(List<SubscriptionAdminClient.ListSubscriptionsPage>, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient.ListSubscriptionsFixedSizeCollection
 
createCollection(List<TopicAdminClient.ListTopicSnapshotsPage>, int) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicSnapshotsFixedSizeCollection
 
createCollection(List<TopicAdminClient.ListTopicsPage>, int) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicsFixedSizeCollection
 
createCollection(List<TopicAdminClient.ListTopicSubscriptionsPage>, int) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicSubscriptionsFixedSizeCollection
 
createOperationCallable(GrpcCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherCallableFactory
 
createOperationCallable(GrpcCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceCallableFactory
 
createOperationCallable(GrpcCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberCallableFactory
 
createOperationCallable(HttpJsonCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherCallableFactory
 
createOperationCallable(HttpJsonCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceCallableFactory
 
createOperationCallable(HttpJsonCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberCallableFactory
 
createPage(PageContext<ListSchemaRevisionsRequest, ListSchemaRevisionsResponse, Schema>, ListSchemaRevisionsResponse) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient.ListSchemaRevisionsPage
 
createPage(PageContext<ListSchemasRequest, ListSchemasResponse, Schema>, ListSchemasResponse) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient.ListSchemasPage
 
createPage(PageContext<ListSnapshotsRequest, ListSnapshotsResponse, Snapshot>, ListSnapshotsResponse) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient.ListSnapshotsPage
 
createPage(PageContext<ListSubscriptionsRequest, ListSubscriptionsResponse, Subscription>, ListSubscriptionsResponse) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient.ListSubscriptionsPage
 
createPage(PageContext<ListTopicSnapshotsRequest, ListTopicSnapshotsResponse, String>, ListTopicSnapshotsResponse) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicSnapshotsPage
 
createPage(PageContext<ListTopicsRequest, ListTopicsResponse, Topic>, ListTopicsResponse) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicsPage
 
createPage(PageContext<ListTopicSubscriptionsRequest, ListTopicSubscriptionsResponse, String>, ListTopicSubscriptionsResponse) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicSubscriptionsPage
 
createPageAsync(PageContext<ListSchemaRevisionsRequest, ListSchemaRevisionsResponse, Schema>, ApiFuture<ListSchemaRevisionsResponse>) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient.ListSchemaRevisionsPage
 
createPageAsync(PageContext<ListSchemasRequest, ListSchemasResponse, Schema>, ApiFuture<ListSchemasResponse>) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient.ListSchemasPage
 
createPageAsync(PageContext<ListSnapshotsRequest, ListSnapshotsResponse, Snapshot>, ApiFuture<ListSnapshotsResponse>) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient.ListSnapshotsPage
 
createPageAsync(PageContext<ListSubscriptionsRequest, ListSubscriptionsResponse, Subscription>, ApiFuture<ListSubscriptionsResponse>) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient.ListSubscriptionsPage
 
createPageAsync(PageContext<ListTopicSnapshotsRequest, ListTopicSnapshotsResponse, String>, ApiFuture<ListTopicSnapshotsResponse>) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicSnapshotsPage
 
createPageAsync(PageContext<ListTopicsRequest, ListTopicsResponse, Topic>, ApiFuture<ListTopicsResponse>) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicsPage
 
createPageAsync(PageContext<ListTopicSubscriptionsRequest, ListTopicSubscriptionsResponse, String>, ApiFuture<ListTopicSubscriptionsResponse>) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient.ListTopicSubscriptionsPage
 
createPagedCallable(GrpcCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherCallableFactory
 
createPagedCallable(GrpcCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceCallableFactory
 
createPagedCallable(GrpcCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberCallableFactory
 
createPagedCallable(HttpJsonCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherCallableFactory
 
createPagedCallable(HttpJsonCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceCallableFactory
 
createPagedCallable(HttpJsonCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberCallableFactory
 
createSchema(CreateSchemaRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Creates a schema.
createSchema(ProjectName, Schema, String) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Creates a schema.
createSchema(String, Schema, String) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Creates a schema.
createSchemaCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Creates a schema.
createSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
createSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
createSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
createSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to createSchema.
createSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to createSchema.
createSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to createSchema.
createSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to createSchema.
createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherCallableFactory
 
createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceCallableFactory
 
createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberCallableFactory
 
createServerStreamingCallable(HttpJsonCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherCallableFactory
 
createServerStreamingCallable(HttpJsonCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceCallableFactory
 
createServerStreamingCallable(HttpJsonCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberCallableFactory
 
createSnapshot(CreateSnapshotRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a snapshot from the requested subscription.
createSnapshot(ProjectSnapshotName, ProjectSubscriptionName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
createSnapshot(ProjectSnapshotName, String) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
createSnapshot(SnapshotName, SubscriptionName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a snapshot from the requested subscription.
createSnapshot(SnapshotName, String) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a snapshot from the requested subscription.
createSnapshot(String, ProjectSubscriptionName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
createSnapshot(String, SubscriptionName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a snapshot from the requested subscription.
createSnapshot(String, String) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a snapshot from the requested subscription.
createSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
createSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
createSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
createSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a snapshot from the requested subscription.
createSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to createSnapshot.
createSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to createSnapshot.
createSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to createSnapshot.
createSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to createSnapshot.
createStub() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
 
createStub() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
 
createStub() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
 
createSubscription(ProjectSubscriptionName, ProjectTopicName, PushConfig, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
createSubscription(ProjectSubscriptionName, TopicName, PushConfig, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
createSubscription(ProjectSubscriptionName, String, PushConfig, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
createSubscription(Subscription) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a subscription to a given topic.
createSubscription(SubscriptionName, TopicName, PushConfig, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a subscription to a given topic.
createSubscription(SubscriptionName, String, PushConfig, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a subscription to a given topic.
createSubscription(String, TopicName, PushConfig, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a subscription to a given topic.
createSubscription(String, String, PushConfig, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a subscription to a given topic.
createSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
createSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
createSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
createSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Creates a subscription to a given topic.
createSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to createSubscription.
createSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to createSubscription.
createSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to createSubscription.
createSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to createSubscription.
createTopic(ProjectTopicName) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Deprecated.
createTopic(Topic) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Creates the given topic with the given name.
createTopic(TopicName) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Creates the given topic with the given name.
createTopic(String) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Creates the given topic with the given name.
createTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
createTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
createTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
createTopicCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Creates the given topic with the given name.
createTopicSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to createTopic.
createTopicSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to createTopic.
createTopicSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to createTopic.
createTopicSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to createTopic.
createUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherCallableFactory
 
createUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceCallableFactory
 
createUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberCallableFactory
 
createUnaryCallable(HttpJsonCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherCallableFactory
 
createUnaryCallable(HttpJsonCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceCallableFactory
 
createUnaryCallable(HttpJsonCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberCallableFactory
 

D

defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
 
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
 
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
 
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
 
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
 
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
 
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns a builder for the default credentials for this service.
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns a builder for the default credentials for this service.
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns a builder for the default credentials for this service.
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns a builder for the default credentials for this service.
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns a builder for the default credentials for this service.
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns a builder for the default credentials for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns a builder for the default ExecutorProvider for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns a builder for the default ExecutorProvider for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns a builder for the default ExecutorProvider for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns a builder for the default ExecutorProvider for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns a builder for the default ExecutorProvider for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns a builder for the default ExecutorProvider for this service.
defaultGrpcApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
 
defaultGrpcApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
 
defaultGrpcApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
 
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns a builder for the default gRPC ChannelProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns a builder for the default gRPC ChannelProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns a builder for the default gRPC ChannelProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns a builder for the default gRPC ChannelProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns a builder for the default gRPC ChannelProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns a builder for the default gRPC ChannelProvider for this service.
defaultHttpJsonApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
 
defaultHttpJsonApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
 
defaultHttpJsonApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
 
defaultHttpJsonTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns a builder for the default REST ChannelProvider for this service.
defaultHttpJsonTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns a builder for the default REST ChannelProvider for this service.
defaultHttpJsonTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns a builder for the default REST ChannelProvider for this service.
defaultHttpJsonTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns a builder for the default REST ChannelProvider for this service.
defaultHttpJsonTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns a builder for the default REST ChannelProvider for this service.
defaultHttpJsonTransportProviderBuilder() - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns a builder for the default REST ChannelProvider for this service.
defaultTransportChannelProvider() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
 
defaultTransportChannelProvider() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
 
defaultTransportChannelProvider() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
 
defaultTransportChannelProvider() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
 
defaultTransportChannelProvider() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
 
defaultTransportChannelProvider() - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
 
deleteSchema(DeleteSchemaRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Deletes a schema.
deleteSchema(SchemaName) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Deletes a schema.
deleteSchema(String) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Deletes a schema.
deleteSchemaCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Deletes a schema.
deleteSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
deleteSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
deleteSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
deleteSchemaRevision(DeleteSchemaRevisionRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Deletes a specific schema revision.
deleteSchemaRevision(SchemaName, String) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Deletes a specific schema revision.
deleteSchemaRevision(String, String) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Deletes a specific schema revision.
deleteSchemaRevisionCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Deletes a specific schema revision.
deleteSchemaRevisionCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
deleteSchemaRevisionCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
deleteSchemaRevisionCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
deleteSchemaRevisionSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to deleteSchemaRevision.
deleteSchemaRevisionSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to deleteSchemaRevision.
deleteSchemaRevisionSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to deleteSchemaRevision.
deleteSchemaRevisionSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to deleteSchemaRevision.
deleteSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to deleteSchema.
deleteSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to deleteSchema.
deleteSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to deleteSchema.
deleteSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to deleteSchema.
deleteSnapshot(DeleteSnapshotRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Removes an existing snapshot.
deleteSnapshot(ProjectSnapshotName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
deleteSnapshot(SnapshotName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Removes an existing snapshot.
deleteSnapshot(String) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Removes an existing snapshot.
deleteSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
deleteSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
deleteSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
deleteSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Removes an existing snapshot.
deleteSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to deleteSnapshot.
deleteSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to deleteSnapshot.
deleteSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to deleteSnapshot.
deleteSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to deleteSnapshot.
deleteSubscription(DeleteSubscriptionRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Deletes an existing subscription.
deleteSubscription(ProjectSubscriptionName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
deleteSubscription(SubscriptionName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Deletes an existing subscription.
deleteSubscription(String) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Deletes an existing subscription.
deleteSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
deleteSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
deleteSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
deleteSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Deletes an existing subscription.
deleteSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to deleteSubscription.
deleteSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to deleteSubscription.
deleteSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to deleteSubscription.
deleteSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to deleteSubscription.
deleteTopic(DeleteTopicRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Deletes the topic with the given name.
deleteTopic(ProjectTopicName) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Deprecated.
deleteTopic(TopicName) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Deletes the topic with the given name.
deleteTopic(String) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Deletes the topic with the given name.
deleteTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
deleteTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
deleteTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
deleteTopicCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Deletes the topic with the given name.
deleteTopicSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to deleteTopic.
deleteTopicSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to deleteTopic.
deleteTopicSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to deleteTopic.
deleteTopicSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to deleteTopic.
detachSubscription(DetachSubscriptionRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Detaches a subscription from this topic.
detachSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
detachSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
detachSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
detachSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Detaches a subscription from this topic.
detachSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to detachSubscription.
detachSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to detachSubscription.
detachSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to detachSubscription.
detachSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to detachSubscription.
doStart() - Method in class com.google.cloud.pubsub.v1.Subscriber
 
doStop() - Method in class com.google.cloud.pubsub.v1.Subscriber
 

F

FAILED_PRECONDITION - Enum constant in enum com.google.cloud.pubsub.v1.AckResponse
 

G

getAckId() - Method in class com.google.cloud.pubsub.v1.AckRequestData
 
getApiMaxRequestBytes() - Static method in class com.google.cloud.pubsub.v1.Publisher
The maximum size of one request.
getApiMaxRequestElementCount() - Static method in class com.google.cloud.pubsub.v1.Publisher
The maximum number of messages in one request.
getBatchingSettings() - Method in class com.google.cloud.pubsub.v1.Publisher
The batching settings configured on this Publisher.
getDefaultBatchingSettings() - Static method in class com.google.cloud.pubsub.v1.Publisher.Builder
Returns the default BatchingSettings used by the client if settings are not provided.
getDefaultEndpoint() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the default service endpoint.
getDefaultEndpoint() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the default service endpoint.
getDefaultEndpoint() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the default service endpoint.
getDefaultEndpoint() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the default service endpoint.
getDefaultEndpoint() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the default service endpoint.
getDefaultEndpoint() - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the default service endpoint.
getDefaultFlowControlSettings() - Static method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Returns the default FlowControlSettings used by the client if settings are not provided.
getDefaultMtlsEndpoint() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the default mTLS service endpoint.
getDefaultMtlsEndpoint() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the default mTLS service endpoint.
getDefaultMtlsEndpoint() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the default mTLS service endpoint.
getDefaultServiceScopes() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the default service scopes.
getDefaultServiceScopes() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the default service scopes.
getDefaultServiceScopes() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the default service scopes.
getDefaultServiceScopes() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the default service scopes.
getDefaultServiceScopes() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the default service scopes.
getDefaultServiceScopes() - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the default service scopes.
getDeliveryAttempt(PubsubMessage) - Static method in class com.google.cloud.pubsub.v1.Subscriber
Returns the delivery attempt count for a received PubsubMessage
getEndpoint() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the endpoint set by the user or the the service's default endpoint.
getEndpoint() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the endpoint set by the user or the the service's default endpoint.
getEndpoint() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the endpoint set by the user or the the service's default endpoint.
getEndpoint() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the endpoint set by the user or the the service's default endpoint.
getEndpoint() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the endpoint set by the user or the the service's default endpoint.
getEndpoint() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the endpoint set by the user or the the service's default endpoint.
getFlowControlSettings() - Method in class com.google.cloud.pubsub.v1.Subscriber
The flow control settings the Subscriber is configured with.
getIamPolicy(GetIamPolicyRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Gets the access control policy for a resource.
getIamPolicy(GetIamPolicyRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Gets the access control policy for a resource.
getIamPolicy(GetIamPolicyRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Gets the access control policy for a resource.
getIamPolicy(String) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
getIamPolicy(String) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Gets the access control policy for a resource.
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Gets the access control policy for a resource.
getIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Gets the access control policy for a resource.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to getIamPolicy.
getMessageFutureIfExists() - Method in class com.google.cloud.pubsub.v1.AckRequestData
 
getMethodDescriptors() - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
getMethodDescriptors() - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
getMethodDescriptors() - Static method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
getOperationsStub() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
getOperationsStub() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
getOperationsStub() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
getSchema(GetSchemaRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Gets a schema.
getSchema(SchemaName) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Gets a schema.
getSchema(String) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Gets a schema.
getSchemaCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Gets a schema.
getSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
getSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
getSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
getSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to getSchema.
getSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to getSchema.
getSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to getSchema.
getSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to getSchema.
getServiceName() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the default service name.
getServiceName() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the default service name.
getServiceName() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the default service name.
getSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
 
getSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
 
getSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
 
getSnapshot(GetSnapshotRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Gets the configuration details of a snapshot.
getSnapshot(ProjectSnapshotName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
getSnapshot(SnapshotName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Gets the configuration details of a snapshot.
getSnapshot(String) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Gets the configuration details of a snapshot.
getSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
getSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
getSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
getSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Gets the configuration details of a snapshot.
getSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to getSnapshot.
getSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to getSnapshot.
getSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to getSnapshot.
getSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to getSnapshot.
getStub() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
 
getStub() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
 
getStub() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
 
getStubSettingsBuilder() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
 
getStubSettingsBuilder() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
 
getStubSettingsBuilder() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
 
getSubscription(GetSubscriptionRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Gets the configuration details of a subscription.
getSubscription(ProjectSubscriptionName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
getSubscription(SubscriptionName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Gets the configuration details of a subscription.
getSubscription(String) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Gets the configuration details of a subscription.
getSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
getSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
getSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
getSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Gets the configuration details of a subscription.
getSubscriptionNameString() - Method in class com.google.cloud.pubsub.v1.Subscriber
Subscription which the subscriber is subscribed to.
getSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to getSubscription.
getSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to getSubscription.
getSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to getSubscription.
getSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to getSubscription.
getTopic(GetTopicRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Gets the configuration of a topic.
getTopic(ProjectTopicName) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Deprecated.
getTopic(TopicName) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Gets the configuration of a topic.
getTopic(String) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Gets the configuration of a topic.
getTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
getTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
getTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
getTopicCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Gets the configuration of a topic.
getTopicName() - Method in class com.google.cloud.pubsub.v1.Publisher
Topic which the publisher publishes to.
getTopicNameString() - Method in class com.google.cloud.pubsub.v1.Publisher
Topic which the publisher publishes to.
getTopicSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to getTopic.
getTopicSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to getTopic.
getTopicSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to getTopic.
getTopicSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to getTopic.
GrpcPublisherCallableFactory - Class in com.google.cloud.pubsub.v1.stub
gRPC callable factory implementation for the Publisher service API.
GrpcPublisherCallableFactory() - Constructor for class com.google.cloud.pubsub.v1.stub.GrpcPublisherCallableFactory
 
GrpcPublisherStub - Class in com.google.cloud.pubsub.v1.stub
gRPC stub implementation for the Publisher service API.
GrpcPublisherStub(PublisherStubSettings, ClientContext) - Constructor for class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
Constructs an instance of GrpcPublisherStub, using the given settings.
GrpcPublisherStub(PublisherStubSettings, ClientContext, GrpcStubCallableFactory) - Constructor for class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
Constructs an instance of GrpcPublisherStub, using the given settings.
GrpcSchemaServiceCallableFactory - Class in com.google.cloud.pubsub.v1.stub
gRPC callable factory implementation for the SchemaService service API.
GrpcSchemaServiceCallableFactory() - Constructor for class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceCallableFactory
 
GrpcSchemaServiceStub - Class in com.google.cloud.pubsub.v1.stub
gRPC stub implementation for the SchemaService service API.
GrpcSchemaServiceStub(SchemaServiceStubSettings, ClientContext) - Constructor for class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
Constructs an instance of GrpcSchemaServiceStub, using the given settings.
GrpcSchemaServiceStub(SchemaServiceStubSettings, ClientContext, GrpcStubCallableFactory) - Constructor for class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
Constructs an instance of GrpcSchemaServiceStub, using the given settings.
GrpcSubscriberCallableFactory - Class in com.google.cloud.pubsub.v1.stub
gRPC callable factory implementation for the Subscriber service API.
GrpcSubscriberCallableFactory() - Constructor for class com.google.cloud.pubsub.v1.stub.GrpcSubscriberCallableFactory
 
GrpcSubscriberStub - Class in com.google.cloud.pubsub.v1.stub
gRPC stub implementation for the Subscriber service API.
GrpcSubscriberStub(SubscriberStubSettings, ClientContext) - Constructor for class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
Constructs an instance of GrpcSubscriberStub, using the given settings.
GrpcSubscriberStub(SubscriberStubSettings, ClientContext, GrpcStubCallableFactory) - Constructor for class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
Constructs an instance of GrpcSubscriberStub, using the given settings.

H

hasMessageFuture() - Method in class com.google.cloud.pubsub.v1.AckRequestData
 
HttpJsonPublisherCallableFactory - Class in com.google.cloud.pubsub.v1.stub
REST callable factory implementation for the Publisher service API.
HttpJsonPublisherCallableFactory() - Constructor for class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherCallableFactory
 
HttpJsonPublisherStub - Class in com.google.cloud.pubsub.v1.stub
REST stub implementation for the Publisher service API.
HttpJsonPublisherStub(PublisherStubSettings, ClientContext) - Constructor for class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
Constructs an instance of HttpJsonPublisherStub, using the given settings.
HttpJsonPublisherStub(PublisherStubSettings, ClientContext, HttpJsonStubCallableFactory) - Constructor for class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
Constructs an instance of HttpJsonPublisherStub, using the given settings.
HttpJsonSchemaServiceCallableFactory - Class in com.google.cloud.pubsub.v1.stub
REST callable factory implementation for the SchemaService service API.
HttpJsonSchemaServiceCallableFactory() - Constructor for class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceCallableFactory
 
HttpJsonSchemaServiceStub - Class in com.google.cloud.pubsub.v1.stub
REST stub implementation for the SchemaService service API.
HttpJsonSchemaServiceStub(SchemaServiceStubSettings, ClientContext) - Constructor for class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
Constructs an instance of HttpJsonSchemaServiceStub, using the given settings.
HttpJsonSchemaServiceStub(SchemaServiceStubSettings, ClientContext, HttpJsonStubCallableFactory) - Constructor for class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
Constructs an instance of HttpJsonSchemaServiceStub, using the given settings.
HttpJsonSubscriberCallableFactory - Class in com.google.cloud.pubsub.v1.stub
REST callable factory implementation for the Subscriber service API.
HttpJsonSubscriberCallableFactory() - Constructor for class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberCallableFactory
 
HttpJsonSubscriberStub - Class in com.google.cloud.pubsub.v1.stub
REST stub implementation for the Subscriber service API.
HttpJsonSubscriberStub(SubscriberStubSettings, ClientContext) - Constructor for class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
Constructs an instance of HttpJsonSubscriberStub, using the given settings.
HttpJsonSubscriberStub(SubscriberStubSettings, ClientContext, HttpJsonStubCallableFactory) - Constructor for class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
Constructs an instance of HttpJsonSubscriberStub, using the given settings.

I

INVALID - Enum constant in enum com.google.cloud.pubsub.v1.AckResponse
 
isShutdown() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
 
isShutdown() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
isShutdown() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
isShutdown() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
isShutdown() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
isShutdown() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
isShutdown() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
isShutdown() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
 
isShutdown() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
 
isTerminated() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
 
isTerminated() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
isTerminated() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
isTerminated() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
isTerminated() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
isTerminated() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
isTerminated() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
isTerminated() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
 
isTerminated() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
 

L

listSchemaRevisions(ListSchemaRevisionsRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Lists all schema revisions for the named schema.
listSchemaRevisions(SchemaName) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Lists all schema revisions for the named schema.
listSchemaRevisions(String) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Lists all schema revisions for the named schema.
listSchemaRevisionsCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Lists all schema revisions for the named schema.
listSchemaRevisionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
listSchemaRevisionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
listSchemaRevisionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
listSchemaRevisionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Lists all schema revisions for the named schema.
listSchemaRevisionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
listSchemaRevisionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
listSchemaRevisionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
listSchemaRevisionsSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to listSchemaRevisions.
listSchemaRevisionsSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to listSchemaRevisions.
listSchemaRevisionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to listSchemaRevisions.
listSchemaRevisionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to listSchemaRevisions.
listSchemas(ListSchemasRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Lists schemas in a project.
listSchemas(ProjectName) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Lists schemas in a project.
listSchemas(String) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Lists schemas in a project.
listSchemasCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Lists schemas in a project.
listSchemasCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
listSchemasCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
listSchemasCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
listSchemasPagedCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Lists schemas in a project.
listSchemasPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
listSchemasPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
listSchemasPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
listSchemasSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to listSchemas.
listSchemasSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to listSchemas.
listSchemasSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to listSchemas.
listSchemasSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to listSchemas.
listSnapshots(ListSnapshotsRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Lists the existing snapshots.
listSnapshots(ProjectName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Lists the existing snapshots.
listSnapshots(String) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Lists the existing snapshots.
listSnapshotsCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
listSnapshotsCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
listSnapshotsCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
listSnapshotsCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Lists the existing snapshots.
listSnapshotsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
listSnapshotsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
listSnapshotsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
listSnapshotsPagedCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Lists the existing snapshots.
listSnapshotsSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to listSnapshots.
listSnapshotsSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to listSnapshots.
listSnapshotsSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to listSnapshots.
listSnapshotsSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to listSnapshots.
listSubscriptions(ListSubscriptionsRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Lists matching subscriptions.
listSubscriptions(ProjectName) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Lists matching subscriptions.
listSubscriptions(String) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Lists matching subscriptions.
listSubscriptionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
listSubscriptionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
listSubscriptionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
listSubscriptionsCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Lists matching subscriptions.
listSubscriptionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
listSubscriptionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
listSubscriptionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
listSubscriptionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Lists matching subscriptions.
listSubscriptionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to listSubscriptions.
listSubscriptionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to listSubscriptions.
listSubscriptionsSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to listSubscriptions.
listSubscriptionsSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to listSubscriptions.
listTopics(ListTopicsRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists matching topics.
listTopics(ProjectName) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists matching topics.
listTopics(String) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists matching topics.
listTopicsCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
listTopicsCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
listTopicsCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
listTopicsCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists matching topics.
listTopicSnapshots(ListTopicSnapshotsRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists the names of the snapshots on this topic.
listTopicSnapshots(TopicName) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists the names of the snapshots on this topic.
listTopicSnapshots(String) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists the names of the snapshots on this topic.
listTopicSnapshotsCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
listTopicSnapshotsCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
listTopicSnapshotsCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
listTopicSnapshotsCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists the names of the snapshots on this topic.
listTopicSnapshotsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
listTopicSnapshotsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
listTopicSnapshotsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
listTopicSnapshotsPagedCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists the names of the snapshots on this topic.
listTopicSnapshotsSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to listTopicSnapshots.
listTopicSnapshotsSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to listTopicSnapshots.
listTopicSnapshotsSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to listTopicSnapshots.
listTopicSnapshotsSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to listTopicSnapshots.
listTopicsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
listTopicsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
listTopicsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
listTopicsPagedCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists matching topics.
listTopicsSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to listTopics.
listTopicsSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to listTopics.
listTopicsSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to listTopics.
listTopicsSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to listTopics.
listTopicSubscriptions(ListTopicSubscriptionsRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists the names of the attached subscriptions on this topic.
listTopicSubscriptions(ProjectTopicName) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
listTopicSubscriptions(TopicName) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists the names of the attached subscriptions on this topic.
listTopicSubscriptions(String) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists the names of the attached subscriptions on this topic.
listTopicSubscriptionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
listTopicSubscriptionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
listTopicSubscriptionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
listTopicSubscriptionsCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists the names of the attached subscriptions on this topic.
listTopicSubscriptionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
listTopicSubscriptionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
listTopicSubscriptionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
listTopicSubscriptionsPagedCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Lists the names of the attached subscriptions on this topic.
listTopicSubscriptionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to listTopicSubscriptions.
listTopicSubscriptionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to listTopicSubscriptions.
listTopicSubscriptionsSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to listTopicSubscriptions.
listTopicSubscriptionsSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to listTopicSubscriptions.

M

MessageReceiver - Interface in com.google.cloud.pubsub.v1
This interface can be implemented by users of Subscriber to receive messages.
MessageReceiverWithAckResponse - Interface in com.google.cloud.pubsub.v1
 
modifyAckDeadline(ModifyAckDeadlineRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Modifies the ack deadline for a specific message.
modifyAckDeadline(SubscriptionName, List<String>, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Modifies the ack deadline for a specific message.
modifyAckDeadline(String, List<String>, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Modifies the ack deadline for a specific message.
modifyAckDeadlineCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
modifyAckDeadlineCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
modifyAckDeadlineCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
modifyAckDeadlineCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Modifies the ack deadline for a specific message.
modifyAckDeadlineSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to modifyAckDeadline.
modifyAckDeadlineSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to modifyAckDeadline.
modifyAckDeadlineSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to modifyAckDeadline.
modifyAckDeadlineSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to modifyAckDeadline.
modifyPushConfig(ModifyPushConfigRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Modifies the `PushConfig` for a specified subscription.
modifyPushConfig(ProjectSubscriptionName, PushConfig) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
modifyPushConfig(SubscriptionName, PushConfig) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Modifies the `PushConfig` for a specified subscription.
modifyPushConfig(String, PushConfig) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Modifies the `PushConfig` for a specified subscription.
modifyPushConfigCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
modifyPushConfigCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
modifyPushConfigCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
modifyPushConfigCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Modifies the `PushConfig` for a specified subscription.
modifyPushConfigSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to modifyPushConfig.
modifyPushConfigSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to modifyPushConfig.
modifyPushConfigSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to modifyPushConfig.
modifyPushConfigSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to modifyPushConfig.

N

nack() - Method in interface com.google.cloud.pubsub.v1.AckReplyConsumer
Signals that the message has not been successfully processed.
nack() - Method in class com.google.cloud.pubsub.v1.AckReplyConsumerImpl
 
nack() - Method in interface com.google.cloud.pubsub.v1.AckReplyConsumerWithResponse
Signals that the message has not been successfully processed.
nack() - Method in class com.google.cloud.pubsub.v1.AckReplyConsumerWithResponseImpl
 
newBuilder() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns a new gRPC builder for this class.
newBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns a new gRPC builder for this class.
newBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns a new gRPC builder for this class.
newBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns a new gRPC builder for this class.
newBuilder() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns a new gRPC builder for this class.
newBuilder() - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns a new gRPC builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns a new builder for this class.
newBuilder(ProjectSubscriptionName, MessageReceiver) - Static method in class com.google.cloud.pubsub.v1.Subscriber
Constructs a new Subscriber.Builder.
newBuilder(ProjectSubscriptionName, MessageReceiverWithAckResponse) - Static method in class com.google.cloud.pubsub.v1.Subscriber
 
newBuilder(TopicName) - Static method in class com.google.cloud.pubsub.v1.Publisher
Constructs a new Publisher.Builder using the given topic.
newBuilder(String) - Static method in class com.google.cloud.pubsub.v1.AckRequestData
 
newBuilder(String) - Static method in class com.google.cloud.pubsub.v1.Publisher
Constructs a new Publisher.Builder using the given topic.
newBuilder(String, MessageReceiver) - Static method in class com.google.cloud.pubsub.v1.Subscriber
Constructs a new Subscriber.Builder.
newBuilder(String, MessageReceiverWithAckResponse) - Static method in class com.google.cloud.pubsub.v1.Subscriber
 
newHttpJsonBuilder() - Static method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns a new REST builder for this class.
newHttpJsonBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns a new REST builder for this class.
newHttpJsonBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns a new REST builder for this class.
newHttpJsonBuilder() - Static method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns a new REST builder for this class.
newHttpJsonBuilder() - Static method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns a new REST builder for this class.
newHttpJsonBuilder() - Static method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns a new REST builder for this class.

O

OPEN_CENSUS_MESSAGE_TRANSFORM - Static variable in class com.google.cloud.pubsub.v1.OpenCensusUtil
Propagates active OpenCensus trace and tag contexts from the Publisher by adding them as attributes to the PubsubMessage.
OpenCensusMessageReceiver(MessageReceiver) - Constructor for class com.google.cloud.pubsub.v1.OpenCensusUtil.OpenCensusMessageReceiver
 
OpenCensusUtil - Class in com.google.cloud.pubsub.v1
Utilities for propagating OpenCensus TagContext and SpanContext from publishers to subscribers.
OpenCensusUtil() - Constructor for class com.google.cloud.pubsub.v1.OpenCensusUtil
 
OpenCensusUtil.OpenCensusMessageReceiver - Class in com.google.cloud.pubsub.v1
Wrapper class for MessageReceiver that decodes any received trace and tag contexts and puts them in scope.
OTHER - Enum constant in enum com.google.cloud.pubsub.v1.AckResponse
 

P

PERMISSION_DENIED - Enum constant in enum com.google.cloud.pubsub.v1.AckResponse
 
publish(PublishRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Adds one or more messages to the topic.
publish(PubsubMessage) - Method in class com.google.cloud.pubsub.v1.Publisher
Schedules the publishing of a message.
publish(PubsubMessage) - Method in interface com.google.cloud.pubsub.v1.PublisherInterface
Schedules the publishing of a message.
publish(TopicName, List<PubsubMessage>) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Adds one or more messages to the topic.
publish(String, List<PubsubMessage>) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Adds one or more messages to the topic.
publishAllOutstanding() - Method in class com.google.cloud.pubsub.v1.Publisher
Publish any outstanding batches if non-empty.
publishCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
publishCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
publishCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
publishCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Adds one or more messages to the topic.
Publisher - Class in com.google.cloud.pubsub.v1
A Cloud Pub/Sub publisher, that is associated with a specific topic at creation.
Publisher.Builder - Class in com.google.cloud.pubsub.v1
A builder of Publishers.
PublisherInterface - Interface in com.google.cloud.pubsub.v1
An interface for a Cloud Pub/Sub publisher.
PublisherStub - Class in com.google.cloud.pubsub.v1.stub
Base stub class for the Publisher service API.
PublisherStub() - Constructor for class com.google.cloud.pubsub.v1.stub.PublisherStub
 
PublisherStubSettings - Class in com.google.cloud.pubsub.v1.stub
Settings class to configure an instance of PublisherStub.
PublisherStubSettings(PublisherStubSettings.Builder) - Constructor for class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
 
PublisherStubSettings.Builder - Class in com.google.cloud.pubsub.v1.stub
Builder for PublisherStubSettings.
publishSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to publish.
publishSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to publish.
publishSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to publish.
publishSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to publish.
pull(ProjectSubscriptionName, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
pull(PullRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Pulls messages from the server.
pull(SubscriptionName, boolean, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Pulls messages from the server.
pull(SubscriptionName, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Pulls messages from the server.
pull(String, boolean, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Pulls messages from the server.
pull(String, int) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Pulls messages from the server.
pullCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
pullCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
pullCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
pullCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Pulls messages from the server.
pullSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to pull.
pullSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to pull.
pullSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to pull.
pullSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to pull.

R

receiveMessage(PubsubMessage, AckReplyConsumer) - Method in interface com.google.cloud.pubsub.v1.MessageReceiver
Called when a message is received by the subscriber.
receiveMessage(PubsubMessage, AckReplyConsumer) - Method in class com.google.cloud.pubsub.v1.OpenCensusUtil.OpenCensusMessageReceiver
 
receiveMessage(PubsubMessage, AckReplyConsumerWithResponse) - Method in interface com.google.cloud.pubsub.v1.MessageReceiverWithAckResponse
 
resumePublish(String) - Method in class com.google.cloud.pubsub.v1.Publisher
There may be non-recoverable problems with a request for an ordering key.
rollbackSchema(RollbackSchemaRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Creates a new schema revision that is a copy of the provided revision_id.
rollbackSchema(SchemaName, String) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Creates a new schema revision that is a copy of the provided revision_id.
rollbackSchema(String, String) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Creates a new schema revision that is a copy of the provided revision_id.
rollbackSchemaCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Creates a new schema revision that is a copy of the provided revision_id.
rollbackSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
rollbackSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
rollbackSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
rollbackSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to rollbackSchema.
rollbackSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to rollbackSchema.
rollbackSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to rollbackSchema.
rollbackSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to rollbackSchema.

S

SchemaServiceClient - Class in com.google.cloud.pubsub.v1
Service Description: Service for doing schema-related operations.
SchemaServiceClient(SchemaServiceSettings) - Constructor for class com.google.cloud.pubsub.v1.SchemaServiceClient
Constructs an instance of SchemaServiceClient, using the given settings.
SchemaServiceClient(SchemaServiceStub) - Constructor for class com.google.cloud.pubsub.v1.SchemaServiceClient
 
SchemaServiceClient.ListSchemaRevisionsFixedSizeCollection - Class in com.google.cloud.pubsub.v1
 
SchemaServiceClient.ListSchemaRevisionsPage - Class in com.google.cloud.pubsub.v1
 
SchemaServiceClient.ListSchemaRevisionsPagedResponse - Class in com.google.cloud.pubsub.v1
 
SchemaServiceClient.ListSchemasFixedSizeCollection - Class in com.google.cloud.pubsub.v1
 
SchemaServiceClient.ListSchemasPage - Class in com.google.cloud.pubsub.v1
 
SchemaServiceClient.ListSchemasPagedResponse - Class in com.google.cloud.pubsub.v1
 
SchemaServiceSettings - Class in com.google.cloud.pubsub.v1
Settings class to configure an instance of SchemaServiceClient.
SchemaServiceSettings(SchemaServiceSettings.Builder) - Constructor for class com.google.cloud.pubsub.v1.SchemaServiceSettings
 
SchemaServiceSettings.Builder - Class in com.google.cloud.pubsub.v1
Builder for SchemaServiceSettings.
SchemaServiceStub - Class in com.google.cloud.pubsub.v1.stub
Base stub class for the SchemaService service API.
SchemaServiceStub() - Constructor for class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
SchemaServiceStubSettings - Class in com.google.cloud.pubsub.v1.stub
Settings class to configure an instance of SchemaServiceStub.
SchemaServiceStubSettings(SchemaServiceStubSettings.Builder) - Constructor for class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
 
SchemaServiceStubSettings.Builder - Class in com.google.cloud.pubsub.v1.stub
Builder for SchemaServiceStubSettings.
seek(SeekRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Seeks an existing subscription to a point in time or to a given snapshot, whichever is provided in the request.
seekCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
seekCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
seekCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
seekCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Seeks an existing subscription to a point in time or to a given snapshot, whichever is provided in the request.
seekSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to seek.
seekSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to seek.
seekSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to seek.
seekSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to seek.
setBatchingSettings(BatchingSettings) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
 
setChannelProvider(TransportChannelProvider) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
ChannelProvider to use to create Channels, which must point at Cloud Pub/Sub endpoint.
setChannelProvider(TransportChannelProvider) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
ChannelProvider to use to create Channels, which must point at Cloud Pub/Sub endpoint.
setCompressionBytesThreshold(long) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
Sets the threshold (in bytes) above which messages are compressed for transport.
setCredentialsProvider(CredentialsProvider) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
CredentialsProvider to use to create Credentials to authenticate calls.
setCredentialsProvider(CredentialsProvider) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
CredentialsProvider to use to create Credentials to authenticate calls.
setEnableCompression(boolean) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
Gives the ability to enable transport compression.
setEnableMessageOrdering(boolean) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
Sets the message ordering option.
setEndpoint(String) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
Gives the ability to override the gRPC endpoint.
setEndpoint(String) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Gives the ability to override the gRPC endpoint.
setExecutorProvider(ExecutorProvider) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
Gives the ability to set a custom executor to be used by the library.
setExecutorProvider(ExecutorProvider) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Gives the ability to set a custom executor.
setFlowControlSettings(FlowControlSettings) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Sets the flow control settings.
setHeaderProvider(HeaderProvider) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
Sets the static header provider.
setHeaderProvider(HeaderProvider) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Sets the static header provider.
setIamPolicy(SetIamPolicyRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Sets the access control policy on the specified resource.
setIamPolicy(SetIamPolicyRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Sets the access control policy on the specified resource.
setIamPolicy(SetIamPolicyRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Sets the access control policy on the specified resource.
setIamPolicy(String, Policy) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
setIamPolicy(String, Policy) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Sets the access control policy on the specified resource.
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Sets the access control policy on the specified resource.
setIamPolicyCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Sets the access control policy on the specified resource.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to setIamPolicy.
setMaxAckExtensionPeriod(Duration) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Set the maximum period a message ack deadline will be extended.
setMaxDurationPerAckExtension(Duration) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Set the upper bound for a single mod ack extention period.
setMessageFuture(SettableApiFuture<AckResponse>) - Method in class com.google.cloud.pubsub.v1.AckRequestData.Builder
 
setMinDurationPerAckExtension(Duration) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Set the lower bound for a single mod ack extention period.
setParallelPullCount(int) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Sets the number of StreamingPull streams to pull messages from the subscription.
setResponse(AckResponse, boolean) - Method in class com.google.cloud.pubsub.v1.AckRequestData
 
setRetrySettings(RetrySettings) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
Configures the Publisher's retry parameters.
setSystemExecutorProvider(ExecutorProvider) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Gives the ability to set a custom executor for managing lease extensions.
setTransform(ApiFunction<PubsubMessage, PubsubMessage>) - Method in class com.google.cloud.pubsub.v1.Publisher.Builder
Gives the ability to set an ApiFunction that will transform the PubsubMessage before it is sent
setUseLegacyFlowControl(boolean) - Method in class com.google.cloud.pubsub.v1.Subscriber.Builder
Disables enforcing flow control settings at the Cloud PubSub server and uses the less accurate method of only enforcing flow control at the client side.
shutdown() - Method in class com.google.cloud.pubsub.v1.Publisher
Schedules immediate publishing of any outstanding messages and waits until all are processed.
shutdown() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
 
shutdown() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
shutdown() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
shutdown() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
shutdown() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
shutdown() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
shutdown() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
shutdown() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
 
shutdown() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
 
shutdownNow() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
 
shutdownNow() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
shutdownNow() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
shutdownNow() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
shutdownNow() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
shutdownNow() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
shutdownNow() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
shutdownNow() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
 
shutdownNow() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
 
startAsync() - Method in class com.google.cloud.pubsub.v1.Subscriber
Initiates service startup and returns immediately.
streamingPullCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
streamingPullCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
streamingPullCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
streamingPullCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Establishes a stream with the server, which sends messages down to the client.
streamingPullSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to streamingPull.
streamingPullSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to streamingPull.
streamingPullSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to streamingPull.
streamingPullSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to streamingPull.
Subscriber - Class in com.google.cloud.pubsub.v1
A Cloud Pub/Sub subscriber that is associated with a specific subscription at creation.
Subscriber.Builder - Class in com.google.cloud.pubsub.v1
Builder of Subscribers.
SubscriberInterface - Interface in com.google.cloud.pubsub.v1
The core interface for a Cloud Pub/Sub subscriber, consisting only of ApiService methods.
SubscriberStub - Class in com.google.cloud.pubsub.v1.stub
Base stub class for the Subscriber service API.
SubscriberStub() - Constructor for class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
SubscriberStubSettings - Class in com.google.cloud.pubsub.v1.stub
Settings class to configure an instance of SubscriberStub.
SubscriberStubSettings(SubscriberStubSettings.Builder) - Constructor for class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
 
SubscriberStubSettings.Builder - Class in com.google.cloud.pubsub.v1.stub
Builder for SubscriberStubSettings.
SubscriptionAdminClient - Class in com.google.cloud.pubsub.v1
Service Description: The service that an application uses to manipulate subscriptions and to consume messages from a subscription via the `Pull` method or by establishing a bi-directional stream using the `StreamingPull` method.
SubscriptionAdminClient(SubscriberStub) - Constructor for class com.google.cloud.pubsub.v1.SubscriptionAdminClient
 
SubscriptionAdminClient(SubscriptionAdminSettings) - Constructor for class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Constructs an instance of SubscriptionAdminClient, using the given settings.
SubscriptionAdminClient.ListSnapshotsFixedSizeCollection - Class in com.google.cloud.pubsub.v1
 
SubscriptionAdminClient.ListSnapshotsPage - Class in com.google.cloud.pubsub.v1
 
SubscriptionAdminClient.ListSnapshotsPagedResponse - Class in com.google.cloud.pubsub.v1
 
SubscriptionAdminClient.ListSubscriptionsFixedSizeCollection - Class in com.google.cloud.pubsub.v1
 
SubscriptionAdminClient.ListSubscriptionsPage - Class in com.google.cloud.pubsub.v1
 
SubscriptionAdminClient.ListSubscriptionsPagedResponse - Class in com.google.cloud.pubsub.v1
 
SubscriptionAdminSettings - Class in com.google.cloud.pubsub.v1
Settings class to configure an instance of SubscriptionAdminClient.
SubscriptionAdminSettings(SubscriptionAdminSettings.Builder) - Constructor for class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
 
SubscriptionAdminSettings.Builder - Class in com.google.cloud.pubsub.v1
Builder for SubscriptionAdminSettings.
SUCCESSFUL - Enum constant in enum com.google.cloud.pubsub.v1.AckResponse
 

T

TAG_CONTEXT_KEY - Static variable in class com.google.cloud.pubsub.v1.OpenCensusUtil
 
testIamPermissions(TestIamPermissionsRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Returns permissions that a caller has on the specified resource.
testIamPermissions(TestIamPermissionsRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Returns permissions that a caller has on the specified resource.
testIamPermissions(TestIamPermissionsRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Returns permissions that a caller has on the specified resource.
testIamPermissions(String, List<String>) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
testIamPermissions(String, List<String>) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Returns permissions that a caller has on the specified resource.
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Returns permissions that a caller has on the specified resource.
testIamPermissionsCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Returns permissions that a caller has on the specified resource.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to testIamPermissions.
toBuilder() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns a builder containing all the values of this settings class.
toBuilder() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns a builder containing all the values of this settings class.
toBuilder() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns a builder containing all the values of this settings class.
toBuilder() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns a builder containing all the values of this settings class.
toBuilder() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns a builder containing all the values of this settings class.
toBuilder() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns a builder containing all the values of this settings class.
TopicAdminClient - Class in com.google.cloud.pubsub.v1
Service Description: The service that an application uses to manipulate topics, and to send messages to a topic.
TopicAdminClient(PublisherStub) - Constructor for class com.google.cloud.pubsub.v1.TopicAdminClient
 
TopicAdminClient(TopicAdminSettings) - Constructor for class com.google.cloud.pubsub.v1.TopicAdminClient
Constructs an instance of TopicAdminClient, using the given settings.
TopicAdminClient.ListTopicsFixedSizeCollection - Class in com.google.cloud.pubsub.v1
 
TopicAdminClient.ListTopicSnapshotsFixedSizeCollection - Class in com.google.cloud.pubsub.v1
 
TopicAdminClient.ListTopicSnapshotsPage - Class in com.google.cloud.pubsub.v1
 
TopicAdminClient.ListTopicSnapshotsPagedResponse - Class in com.google.cloud.pubsub.v1
 
TopicAdminClient.ListTopicsPage - Class in com.google.cloud.pubsub.v1
 
TopicAdminClient.ListTopicsPagedResponse - Class in com.google.cloud.pubsub.v1
 
TopicAdminClient.ListTopicSubscriptionsFixedSizeCollection - Class in com.google.cloud.pubsub.v1
 
TopicAdminClient.ListTopicSubscriptionsPage - Class in com.google.cloud.pubsub.v1
 
TopicAdminClient.ListTopicSubscriptionsPagedResponse - Class in com.google.cloud.pubsub.v1
 
TopicAdminSettings - Class in com.google.cloud.pubsub.v1
Settings class to configure an instance of TopicAdminClient.
TopicAdminSettings(TopicAdminSettings.Builder) - Constructor for class com.google.cloud.pubsub.v1.TopicAdminSettings
 
TopicAdminSettings.Builder - Class in com.google.cloud.pubsub.v1
Builder for TopicAdminSettings.
TRACE_CONTEXT_KEY - Static variable in class com.google.cloud.pubsub.v1.OpenCensusUtil
 

U

unaryMethodSettingsBuilders() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
 
unaryMethodSettingsBuilders() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
 
unaryMethodSettingsBuilders() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
 
updateSnapshot(Snapshot, FieldMask) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Updates an existing snapshot by updating the fields specified in the update mask.
updateSnapshot(UpdateSnapshotRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Updates an existing snapshot by updating the fields specified in the update mask.
updateSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
updateSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
updateSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
updateSnapshotCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Updates an existing snapshot by updating the fields specified in the update mask.
updateSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to updateSnapshot.
updateSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to updateSnapshot.
updateSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to updateSnapshot.
updateSnapshotSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to updateSnapshot.
updateSubscription(Subscription, FieldMask) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Updates an existing subscription by updating the fields specified in the update mask.
updateSubscription(UpdateSubscriptionRequest) - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Updates an existing subscription by updating the fields specified in the update mask.
updateSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSubscriberStub
 
updateSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSubscriberStub
 
updateSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStub
 
updateSubscriptionCallable() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminClient
Updates an existing subscription by updating the fields specified in the update mask.
updateSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings.Builder
Returns the builder for the settings used for calls to updateSubscription.
updateSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.stub.SubscriberStubSettings
Returns the object with the settings used for calls to updateSubscription.
updateSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings.Builder
Returns the builder for the settings used for calls to updateSubscription.
updateSubscriptionSettings() - Method in class com.google.cloud.pubsub.v1.SubscriptionAdminSettings
Returns the object with the settings used for calls to updateSubscription.
updateTopic(Topic, FieldMask) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Updates an existing topic by updating the fields specified in the update mask.
updateTopic(UpdateTopicRequest) - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Updates an existing topic by updating the fields specified in the update mask.
updateTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcPublisherStub
 
updateTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonPublisherStub
 
updateTopicCallable() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStub
 
updateTopicCallable() - Method in class com.google.cloud.pubsub.v1.TopicAdminClient
Updates an existing topic by updating the fields specified in the update mask.
updateTopicSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings.Builder
Returns the builder for the settings used for calls to updateTopic.
updateTopicSettings() - Method in class com.google.cloud.pubsub.v1.stub.PublisherStubSettings
Returns the object with the settings used for calls to updateTopic.
updateTopicSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings.Builder
Returns the builder for the settings used for calls to updateTopic.
updateTopicSettings() - Method in class com.google.cloud.pubsub.v1.TopicAdminSettings
Returns the object with the settings used for calls to updateTopic.

V

validateMessage(ValidateMessageRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Validates a message against a schema.
validateMessageCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Validates a message against a schema.
validateMessageCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
validateMessageCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
validateMessageCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
validateMessageSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to validateMessage.
validateMessageSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to validateMessage.
validateMessageSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to validateMessage.
validateMessageSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to validateMessage.
validateSchema(ProjectName, Schema) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Validates a schema.
validateSchema(ValidateSchemaRequest) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Validates a schema.
validateSchema(String, Schema) - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Validates a schema.
validateSchemaCallable() - Method in class com.google.cloud.pubsub.v1.SchemaServiceClient
Validates a schema.
validateSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.GrpcSchemaServiceStub
 
validateSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.HttpJsonSchemaServiceStub
 
validateSchemaCallable() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStub
 
validateSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings.Builder
Returns the builder for the settings used for calls to validateSchema.
validateSchemaSettings() - Method in class com.google.cloud.pubsub.v1.SchemaServiceSettings
Returns the object with the settings used for calls to validateSchema.
validateSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings.Builder
Returns the builder for the settings used for calls to validateSchema.
validateSchemaSettings() - Method in class com.google.cloud.pubsub.v1.stub.SchemaServiceStubSettings
Returns the object with the settings used for calls to validateSchema.
valueOf(String) - Static method in enum com.google.cloud.pubsub.v1.AckResponse
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.google.cloud.pubsub.v1.AckResponse
Returns an array containing the constants of this enum type, in the order they are declared.
A B C D F G H I L M N O P R S T U V 
All Classes and Interfaces|All Packages|Constant Field Values