All Classes Interface Summary Class Summary Enum Summary Exception Summary
Class |
Description |
AckSetTrackerImpl |
|
AdminClient |
A client for performing Pub/Sub Lite admin operations.
|
AdminClientImpl |
|
AdminClientSettings |
Settings for construction a Pub/Sub Lite AdminClient.
|
AdminClientSettings.Builder |
|
AdminProto |
|
AdminServiceClient |
Service Description: The service that a client application uses to manage topics and
subscriptions, such creating, listing, and deleting topics and subscriptions.
|
AdminServiceClient.ListReservationsFixedSizeCollection |
|
AdminServiceClient.ListReservationsPage |
|
AdminServiceClient.ListReservationsPagedResponse |
|
AdminServiceClient.ListReservationTopicsFixedSizeCollection |
|
AdminServiceClient.ListReservationTopicsPage |
|
AdminServiceClient.ListReservationTopicsPagedResponse |
|
AdminServiceClient.ListSubscriptionsFixedSizeCollection |
|
AdminServiceClient.ListSubscriptionsPage |
|
AdminServiceClient.ListSubscriptionsPagedResponse |
|
AdminServiceClient.ListTopicsFixedSizeCollection |
|
AdminServiceClient.ListTopicsPage |
|
AdminServiceClient.ListTopicsPagedResponse |
|
AdminServiceClient.ListTopicSubscriptionsFixedSizeCollection |
|
AdminServiceClient.ListTopicSubscriptionsPage |
|
AdminServiceClient.ListTopicSubscriptionsPagedResponse |
|
AdminServiceGrpc |
The service that a client application uses to manage topics and
subscriptions, such creating, listing, and deleting topics and subscriptions.
|
AdminServiceGrpc.AdminServiceBlockingStub |
A stub to allow clients to do synchronous rpc calls to service AdminService.
|
AdminServiceGrpc.AdminServiceFutureStub |
A stub to allow clients to do ListenableFuture-style rpc calls to service AdminService.
|
AdminServiceGrpc.AdminServiceImplBase |
Base class for the server implementation of the service AdminService.
|
AdminServiceGrpc.AdminServiceStub |
A stub to allow clients to do asynchronous rpc calls to service AdminService.
|
AdminServiceGrpc.AsyncService |
The service that a client application uses to manage topics and
subscriptions, such creating, listing, and deleting topics and subscriptions.
|
AdminServiceSettings |
|
AdminServiceSettings.Builder |
Builder for AdminServiceSettings.
|
AdminServiceStub |
Base stub class for the AdminService service API.
|
AdminServiceStubSettings |
|
AdminServiceStubSettings.Builder |
Builder for AdminServiceStubSettings.
|
AlarmFactory |
|
AlarmFactory.Internal |
|
ApiBackgroundResource |
|
ApiExceptionPublisher<T> |
|
ApiResourceAggregation |
|
ApiServiceUtils |
|
Assigner |
An Assigner is responsible for handling partition assignments for a subscribing client.
|
AssignerFactory |
|
AssignerImpl |
|
AssignerSettings |
|
AssignerSettings.Builder |
|
AssigningSubscriber |
|
AttributeValues |
The values associated with a key of an attribute.
|
AttributeValues.Builder |
The values associated with a key of an attribute.
|
AttributeValuesOrBuilder |
|
BacklogLocation |
BacklogLocation refers to a location with respect to the message backlog.
|
BatchingCommitter |
|
BlockingPullSubscriber |
|
BlockingPullSubscriberImpl |
|
BufferingPullSubscriber |
|
CheckedApiException |
A wrapper around an ApiException that is a checked exception to help ensure correctness of
internal classes as well as ease construction of ApiExceptions.
|
CheckedApiPreconditions |
|
CloseableMonitor |
Wraps a Monitor with methods that can be used with try-with-resources.
|
CloudRegion |
A wrapped string representing a Google Cloud region.
|
CloudRegionOrZone |
|
CloudRegionOrZone.Kind |
|
CloudZone |
A representation of a Google Cloud zone.
|
CommitCursorRequest |
Request for CommitCursor.
|
CommitCursorRequest.Builder |
Request for CommitCursor.
|
CommitCursorRequestOrBuilder |
|
CommitCursorResponse |
Response for CommitCursor.
|
CommitCursorResponse.Builder |
Response for CommitCursor.
|
CommitCursorResponseOrBuilder |
|
Committer |
|
CommitterImpl |
|
CommitterSettings |
|
CommitterSettings.Builder |
|
CommonProto |
|
ComputeHeadCursorRequest |
Compute the current head cursor for a partition.
|
ComputeHeadCursorRequest.Builder |
Compute the current head cursor for a partition.
|
ComputeHeadCursorRequestOrBuilder |
|
ComputeHeadCursorResponse |
Response containing the head cursor for the requested topic and partition.
|
ComputeHeadCursorResponse.Builder |
Response containing the head cursor for the requested topic and partition.
|
ComputeHeadCursorResponseOrBuilder |
|
ComputeMessageStatsRequest |
Compute statistics about a range of messages in a given topic and partition.
|
ComputeMessageStatsRequest.Builder |
Compute statistics about a range of messages in a given topic and partition.
|
ComputeMessageStatsRequestOrBuilder |
|
ComputeMessageStatsResponse |
Response containing stats for messages in the requested topic and partition.
|
ComputeMessageStatsResponse.Builder |
Response containing stats for messages in the requested topic and partition.
|
ComputeMessageStatsResponseOrBuilder |
|
ComputeTimeCursorRequest |
Compute the corresponding cursor for a publish or event time in a topic
partition.
|
ComputeTimeCursorRequest.Builder |
Compute the corresponding cursor for a publish or event time in a topic
partition.
|
ComputeTimeCursorRequestOrBuilder |
|
ComputeTimeCursorResponse |
Response containing the cursor corresponding to a publish or event time in a
topic partition.
|
ComputeTimeCursorResponse.Builder |
Response containing the cursor corresponding to a publish or event time in a
topic partition.
|
ComputeTimeCursorResponseOrBuilder |
|
ConnectedAssigner |
|
ConnectedAssignerImpl |
|
ConnectedCommitterImpl |
|
Constants |
Useful general constants for Pub/Sub Lite.
|
CreateReservationRequest |
Request for CreateReservation.
|
CreateReservationRequest.Builder |
Request for CreateReservation.
|
CreateReservationRequestOrBuilder |
|
CreateSubscriptionRequest |
Request for CreateSubscription.
|
CreateSubscriptionRequest.Builder |
Request for CreateSubscription.
|
CreateSubscriptionRequestOrBuilder |
|
CreateTopicRequest |
Request for CreateTopic.
|
CreateTopicRequest.Builder |
Request for CreateTopic.
|
CreateTopicRequestOrBuilder |
|
Cursor |
A cursor that describes the position of a message within a topic partition.
|
Cursor.Builder |
A cursor that describes the position of a message within a topic partition.
|
CursorClient |
|
CursorClientImpl |
|
CursorClientSettings |
|
CursorClientSettings.Builder |
|
CursorOrBuilder |
|
CursorProto |
|
CursorServiceClient |
Service Description: The service that a subscriber client application uses to manage committed
cursors while receiving messsages.
|
CursorServiceClient.ListPartitionCursorsFixedSizeCollection |
|
CursorServiceClient.ListPartitionCursorsPage |
|
CursorServiceClient.ListPartitionCursorsPagedResponse |
|
CursorServiceGrpc |
The service that a subscriber client application uses to manage committed
cursors while receiving messsages.
|
CursorServiceGrpc.AsyncService |
The service that a subscriber client application uses to manage committed
cursors while receiving messsages.
|
CursorServiceGrpc.CursorServiceBlockingStub |
A stub to allow clients to do synchronous rpc calls to service CursorService.
|
CursorServiceGrpc.CursorServiceFutureStub |
A stub to allow clients to do ListenableFuture-style rpc calls to service CursorService.
|
CursorServiceGrpc.CursorServiceImplBase |
Base class for the server implementation of the service CursorService.
|
CursorServiceGrpc.CursorServiceStub |
A stub to allow clients to do asynchronous rpc calls to service CursorService.
|
CursorServiceSettings |
|
CursorServiceSettings.Builder |
Builder for CursorServiceSettings.
|
CursorServiceStub |
Base stub class for the CursorService service API.
|
CursorServiceStubSettings |
|
CursorServiceStubSettings.Builder |
Builder for CursorServiceStubSettings.
|
DefaultRoutingPolicy |
|
DeleteReservationRequest |
Request for DeleteReservation.
|
DeleteReservationRequest.Builder |
Request for DeleteReservation.
|
DeleteReservationRequestOrBuilder |
|
DeleteSubscriptionRequest |
Request for DeleteSubscription.
|
DeleteSubscriptionRequest.Builder |
Request for DeleteSubscription.
|
DeleteSubscriptionRequestOrBuilder |
|
DeleteTopicRequest |
Request for DeleteTopic.
|
DeleteTopicRequest.Builder |
Request for DeleteTopic.
|
DeleteTopicRequestOrBuilder |
|
Endpoints |
Constructs regional endpoints from a CloudRegion.
|
ErrorCodes |
Pub/Sub Lite retryable error codes.
|
ExportConfig |
Configuration for a Pub/Sub Lite subscription that writes messages to a
destination.
|
ExportConfig.Builder |
Configuration for a Pub/Sub Lite subscription that writes messages to a
destination.
|
ExportConfig.DestinationCase |
|
ExportConfig.PubSubConfig |
Configuration for exporting to a Pub/Sub topic.
|
ExportConfig.PubSubConfig.Builder |
Configuration for exporting to a Pub/Sub topic.
|
ExportConfig.PubSubConfigOrBuilder |
|
ExportConfig.State |
The desired export state.
|
ExportConfigOrBuilder |
|
ExtractStatus |
|
ExtractStatus.StatusBiconsumer<K,V> |
|
ExtractStatus.StatusConsumer<I> |
|
ExtractStatus.StatusFunction<I,O> |
|
FakeApiService |
Fake Pub/Sub Lite service for testing.
|
FlowControlRequest |
Request to grant tokens to the server, requesting delivery of messages when
they become available.
|
FlowControlRequest.Builder |
Request to grant tokens to the server, requesting delivery of messages when
they become available.
|
FlowControlRequestOrBuilder |
|
FlowControlSettings |
Describes limits on bytes and messages outstanding for a single partition Pub/Sub Lite
subscriber.
|
FlowControlSettings.Builder |
|
GetReservationRequest |
Request for GetReservation.
|
GetReservationRequest.Builder |
Request for GetReservation.
|
GetReservationRequestOrBuilder |
|
GetSubscriptionRequest |
Request for GetSubscription.
|
GetSubscriptionRequest.Builder |
Request for GetSubscription.
|
GetSubscriptionRequestOrBuilder |
|
GetTopicPartitionsRequest |
Request for GetTopicPartitions.
|
GetTopicPartitionsRequest.Builder |
Request for GetTopicPartitions.
|
GetTopicPartitionsRequestOrBuilder |
|
GetTopicRequest |
Request for GetTopic.
|
GetTopicRequest.Builder |
Request for GetTopic.
|
GetTopicRequestOrBuilder |
|
GrpcAdminServiceCallableFactory |
gRPC callable factory implementation for the AdminService service API.
|
GrpcAdminServiceStub |
gRPC stub implementation for the AdminService service API.
|
GrpcCursorServiceCallableFactory |
gRPC callable factory implementation for the CursorService service API.
|
GrpcCursorServiceStub |
gRPC stub implementation for the CursorService service API.
|
GrpcPartitionAssignmentServiceCallableFactory |
gRPC callable factory implementation for the PartitionAssignmentService service API.
|
GrpcPartitionAssignmentServiceStub |
gRPC stub implementation for the PartitionAssignmentService service API.
|
GrpcPublisherServiceCallableFactory |
gRPC callable factory implementation for the PublisherService service API.
|
GrpcPublisherServiceStub |
gRPC stub implementation for the PublisherService service API.
|
GrpcSubscriberServiceCallableFactory |
gRPC callable factory implementation for the SubscriberService service API.
|
GrpcSubscriberServiceStub |
gRPC stub implementation for the SubscriberService service API.
|
GrpcTopicStatsServiceCallableFactory |
gRPC callable factory implementation for the TopicStatsService service API.
|
GrpcTopicStatsServiceStub |
gRPC stub implementation for the TopicStatsService service API.
|
InitialCommitCursorRequest |
The first streaming request that must be sent on a newly-opened stream.
|
InitialCommitCursorRequest.Builder |
The first streaming request that must be sent on a newly-opened stream.
|
InitialCommitCursorRequestOrBuilder |
|
InitialCommitCursorResponse |
Response to an InitialCommitCursorRequest.
|
InitialCommitCursorResponse.Builder |
Response to an InitialCommitCursorRequest.
|
InitialCommitCursorResponseOrBuilder |
|
InitialPartitionAssignmentRequest |
The first request that must be sent on a newly-opened stream.
|
InitialPartitionAssignmentRequest.Builder |
The first request that must be sent on a newly-opened stream.
|
InitialPartitionAssignmentRequestOrBuilder |
|
InitialPublishRequest |
The first request that must be sent on a newly-opened stream.
|
InitialPublishRequest.Builder |
The first request that must be sent on a newly-opened stream.
|
InitialPublishRequestOrBuilder |
|
InitialPublishResponse |
Response to an InitialPublishRequest.
|
InitialPublishResponse.Builder |
Response to an InitialPublishRequest.
|
InitialPublishResponseOrBuilder |
|
InitialSubscribeRequest |
The first request that must be sent on a newly-opened stream.
|
InitialSubscribeRequest.Builder |
The first request that must be sent on a newly-opened stream.
|
InitialSubscribeRequestOrBuilder |
|
InitialSubscribeResponse |
Response to an InitialSubscribeRequest.
|
InitialSubscribeResponse.Builder |
Response to an InitialSubscribeRequest.
|
InitialSubscribeResponseOrBuilder |
|
KeyExtractor |
A KeyExtractor can extract the Pub/Sub Lite 'key' field used for message routing from a
PubsubMessage.
|
Lazy<T> |
A thread-safe, lazily constructed instance of an object.
|
ListPartitionCursorsRequest |
Request for ListPartitionCursors.
|
ListPartitionCursorsRequest.Builder |
Request for ListPartitionCursors.
|
ListPartitionCursorsRequestOrBuilder |
|
ListPartitionCursorsResponse |
Response for ListPartitionCursors
|
ListPartitionCursorsResponse.Builder |
Response for ListPartitionCursors
|
ListPartitionCursorsResponseOrBuilder |
|
ListReservationsRequest |
Request for ListReservations.
|
ListReservationsRequest.Builder |
Request for ListReservations.
|
ListReservationsRequestOrBuilder |
|
ListReservationsResponse |
Response for ListReservations.
|
ListReservationsResponse.Builder |
Response for ListReservations.
|
ListReservationsResponseOrBuilder |
|
ListReservationTopicsRequest |
Request for ListReservationTopics.
|
ListReservationTopicsRequest.Builder |
Request for ListReservationTopics.
|
ListReservationTopicsRequestOrBuilder |
|
ListReservationTopicsResponse |
Response for ListReservationTopics.
|
ListReservationTopicsResponse.Builder |
Response for ListReservationTopics.
|
ListReservationTopicsResponseOrBuilder |
|
ListSubscriptionsRequest |
Request for ListSubscriptions.
|
ListSubscriptionsRequest.Builder |
Request for ListSubscriptions.
|
ListSubscriptionsRequestOrBuilder |
|
ListSubscriptionsResponse |
Response for ListSubscriptions.
|
ListSubscriptionsResponse.Builder |
Response for ListSubscriptions.
|
ListSubscriptionsResponseOrBuilder |
|
ListTopicsRequest |
Request for ListTopics.
|
ListTopicsRequest.Builder |
Request for ListTopics.
|
ListTopicsRequestOrBuilder |
|
ListTopicsResponse |
Response for ListTopics.
|
ListTopicsResponse.Builder |
Response for ListTopics.
|
ListTopicsResponseOrBuilder |
|
ListTopicSubscriptionsRequest |
Request for ListTopicSubscriptions.
|
ListTopicSubscriptionsRequest.Builder |
Request for ListTopicSubscriptions.
|
ListTopicSubscriptionsRequestOrBuilder |
|
ListTopicSubscriptionsResponse |
Response for ListTopicSubscriptions.
|
ListTopicSubscriptionsResponse.Builder |
Response for ListTopicSubscriptions.
|
ListTopicSubscriptionsResponseOrBuilder |
|
LocationName |
|
LocationName.Builder |
Builder for projects/{project}/locations/{location}.
|
LocationPath |
A string wrapper representing a project and location.
|
LocationPath.Builder |
|
Message |
A user message.
|
Message.Builder |
|
MessageMetadata |
Information about a message in Pub/Sub Lite.
|
MessagePublishRequest |
Request to publish messages to the topic.
|
MessagePublishRequest.Builder |
Request to publish messages to the topic.
|
MessagePublishRequestOrBuilder |
|
MessagePublishResponse |
Response to a MessagePublishRequest.
|
MessagePublishResponse.Builder |
Response to a MessagePublishRequest.
|
MessagePublishResponse.CursorRange |
Cursors for a subrange of published messages.
|
MessagePublishResponse.CursorRange.Builder |
Cursors for a subrange of published messages.
|
MessagePublishResponse.CursorRangeOrBuilder |
|
MessagePublishResponseOrBuilder |
|
MessageResponse |
Response containing a list of messages.
|
MessageResponse.Builder |
Response containing a list of messages.
|
MessageResponseOrBuilder |
|
MessageTransformer<FromT,ToT> |
A MessageTransformer details how to transform a message of one type to another.
|
MessageTransforms |
MessageTransforms details how to transform message representations from Cloud Pub/Sub to Pub/Sub
Lite.
|
MoreApiFutures |
|
MultiPartitionSubscriber |
|
NackHandler |
A NackHandler handles when nack() is called in a user's AckReplyConsumer.
|
NextOffsetTracker |
|
Offset |
An offset in the partition.
|
OperationMetadata |
Metadata for long running operations.
|
OperationMetadata.Builder |
Metadata for long running operations.
|
OperationMetadataOrBuilder |
|
Partition |
A partition of a topic.
|
PartitionAssignment |
PartitionAssignments should not race with acknowledgements.
|
PartitionAssignment.Builder |
PartitionAssignments should not race with acknowledgements.
|
PartitionAssignmentAck |
Acknowledge receipt and handling of the previous assignment.
|
PartitionAssignmentAck.Builder |
Acknowledge receipt and handling of the previous assignment.
|
PartitionAssignmentAckOrBuilder |
|
PartitionAssignmentOrBuilder |
|
PartitionAssignmentReceiver |
A receiver for partition assignments.
|
PartitionAssignmentRequest |
A request on the PartitionAssignment stream.
|
PartitionAssignmentRequest.Builder |
A request on the PartitionAssignment stream.
|
PartitionAssignmentRequest.RequestCase |
|
PartitionAssignmentRequestOrBuilder |
|
PartitionAssignmentServiceClient |
Service Description: The service that a subscriber client application uses to determine which
partitions it should connect to.
|
PartitionAssignmentServiceGrpc |
The service that a subscriber client application uses to determine which
partitions it should connect to.
|
PartitionAssignmentServiceGrpc.AsyncService |
The service that a subscriber client application uses to determine which
partitions it should connect to.
|
PartitionAssignmentServiceGrpc.PartitionAssignmentServiceBlockingStub |
A stub to allow clients to do synchronous rpc calls to service PartitionAssignmentService.
|
PartitionAssignmentServiceGrpc.PartitionAssignmentServiceFutureStub |
A stub to allow clients to do ListenableFuture-style rpc calls to service
PartitionAssignmentService.
|
PartitionAssignmentServiceGrpc.PartitionAssignmentServiceImplBase |
Base class for the server implementation of the service PartitionAssignmentService.
|
PartitionAssignmentServiceGrpc.PartitionAssignmentServiceStub |
A stub to allow clients to do asynchronous rpc calls to service PartitionAssignmentService.
|
PartitionAssignmentServiceSettings |
|
PartitionAssignmentServiceSettings.Builder |
Builder for PartitionAssignmentServiceSettings.
|
PartitionAssignmentServiceStub |
Base stub class for the PartitionAssignmentService service API.
|
PartitionAssignmentServiceStubSettings |
|
PartitionAssignmentServiceStubSettings.Builder |
Builder for PartitionAssignmentServiceStubSettings.
|
PartitionCountWatcher |
|
PartitionCountWatcher.Factory |
|
PartitionCountWatcherImpl |
|
PartitionCountWatcherImpl.Factory |
|
PartitionCountWatchingPublisher |
|
PartitionCountWatchingPublisherSettings |
|
PartitionCountWatchingPublisherSettings.Builder |
|
PartitionCursor |
A pair of a Cursor and the partition it is for.
|
PartitionCursor.Builder |
A pair of a Cursor and the partition it is for.
|
PartitionCursorOrBuilder |
|
PartitionLookupUtils |
Utilities for looking up information on partitions.
|
PartitionPublisherFactory |
|
PartitionSubscriberClientSupplier |
Supplies new SubscriberServiceClient instances.
|
PartitionSubscriberFactory |
PartitionSubscriberFactories are used dynamically in a context where there is no client downcall.
|
Predicates |
|
ProjectId |
|
ProjectIdOrNumber |
|
ProjectNumber |
|
ProjectPath |
A string wrapper representing a project.
|
ProjectPath.Builder |
|
ProxyService |
|
Publisher |
Pub/Sub Lite publishers are streaming based and can experience permanent errors.
|
Publisher<ResponseT> |
A generic PubSub Lite publisher.
|
PublisherBuilder |
A builder for a PubSub Lite Publisher.
|
PublisherBuilder.Builder |
|
PublisherImpl |
|
PublisherProto |
|
PublisherServiceClient |
Service Description: The service that a publisher client application uses to publish messages to
topics.
|
PublisherServiceGrpc |
The service that a publisher client application uses to publish messages to
topics.
|
PublisherServiceGrpc.AsyncService |
The service that a publisher client application uses to publish messages to
topics.
|
PublisherServiceGrpc.PublisherServiceBlockingStub |
A stub to allow clients to do synchronous rpc calls to service PublisherService.
|
PublisherServiceGrpc.PublisherServiceFutureStub |
A stub to allow clients to do ListenableFuture-style rpc calls to service PublisherService.
|
PublisherServiceGrpc.PublisherServiceImplBase |
Base class for the server implementation of the service PublisherService.
|
PublisherServiceGrpc.PublisherServiceStub |
A stub to allow clients to do asynchronous rpc calls to service PublisherService.
|
PublisherServiceSettings |
|
PublisherServiceSettings.Builder |
Builder for PublisherServiceSettings.
|
PublisherServiceStub |
Base stub class for the PublisherService service API.
|
PublisherServiceStubSettings |
|
PublisherServiceStubSettings.Builder |
Builder for PublisherServiceStubSettings.
|
PublisherSettings |
Settings for instantiating a Pub/Sub Lite publisher emulating the Cloud Pub/Sub Publisher API.
|
PublisherSettings.Builder |
|
PublishRequest |
Request sent from the client to the server on a stream.
|
PublishRequest.Builder |
Request sent from the client to the server on a stream.
|
PublishRequest.RequestTypeCase |
|
PublishRequestOrBuilder |
|
PublishResponse |
Response to a PublishRequest.
|
PublishResponse.Builder |
Response to a PublishRequest.
|
PublishResponse.ResponseTypeCase |
|
PublishResponseOrBuilder |
|
PublishSequenceNumber |
A sequence number for a published message, for implementing publish idempotency.
|
PubsubContext |
A context for identifying clients based on basic properties.
|
PubsubContext.Framework |
A unique string representing the unambiguous name of a framework in SCREAMING_SNAKE_CASE.
|
PubSubMessage |
A message that is published by publishers and delivered to subscribers.
|
PubSubMessage.Builder |
A message that is published by publishers and delivered to subscribers.
|
PubSubMessageOrBuilder |
|
PullSubscriber<T> |
|
ReassignmentHandler |
A ReassignmentHandler is called any time a new partition assignment is received from the server.
|
Reservation |
Metadata about a reservation resource.
|
Reservation.Builder |
Metadata about a reservation resource.
|
ReservationName |
|
ReservationName |
A string wrapper for the name of a reservation.
|
ReservationName.Builder |
Builder for projects/{project}/locations/{location}/reservations/{reservation}.
|
ReservationOrBuilder |
|
ReservationPath |
A string wrapper representing a reservation.
|
ReservationPath.Builder |
|
ResetSignal |
|
ResettableSubscriberFactory |
|
RetryingConnectionObserver<ClientResponseT> |
|
RoutingMetadata |
|
RoutingPolicy |
|
RoutingPolicy.Factory |
|
RoutingPublisher |
|
RoutingPublisherBuilder |
|
RoutingPublisherBuilder.Builder |
|
SeekRequest |
Request to update the stream's delivery cursor based on the given target.
|
SeekRequest.Builder |
Request to update the stream's delivery cursor based on the given target.
|
SeekRequest.NamedTarget |
A special target in the partition that takes no other parameters.
|
SeekRequest.TargetCase |
|
SeekRequestOrBuilder |
|
SeekResponse |
Response to a SeekRequest.
|
SeekResponse.Builder |
Response to a SeekRequest.
|
SeekResponseOrBuilder |
|
SeekSubscriptionRequest |
Request for SeekSubscription.
|
SeekSubscriptionRequest.Builder |
Request for SeekSubscription.
|
SeekSubscriptionRequest.NamedTarget |
A named position with respect to the message backlog.
|
SeekSubscriptionRequest.TargetCase |
|
SeekSubscriptionRequestOrBuilder |
|
SeekSubscriptionResponse |
Response for SeekSubscription long running operation.
|
SeekSubscriptionResponse.Builder |
Response for SeekSubscription long running operation.
|
SeekSubscriptionResponseOrBuilder |
|
SeekTarget |
The target location to seek a subscription to.
|
SeekTarget.Kind |
|
SequenceAssigningPublisher |
A publisher that assigns sequence numbers to messages and delegates to an underlying
SequencedPublisher.
|
SequencedCommitCursorRequest |
Streaming request to update the committed cursor.
|
SequencedCommitCursorRequest.Builder |
Streaming request to update the committed cursor.
|
SequencedCommitCursorRequestOrBuilder |
|
SequencedCommitCursorResponse |
Response to a SequencedCommitCursorRequest.
|
SequencedCommitCursorResponse.Builder |
Response to a SequencedCommitCursorRequest.
|
SequencedCommitCursorResponseOrBuilder |
|
SequencedMessage |
A message that has been stored and sequenced by the Pub/Sub Lite system.
|
SequencedMessage |
A message with its sequencing information in the partition.
|
SequencedMessage.Builder |
A message that has been stored and sequenced by the Pub/Sub Lite system.
|
SequencedMessageOrBuilder |
|
SequencedPublisher<ResponseT> |
A PubSub Lite publisher that requires a sequence number assigned to every message, for publish
idempotency.
|
SerialExecutor |
An executor that runs tasks sequentially.
|
ServiceClients |
|
SingleConnection<StreamRequestT,StreamResponseT,ClientResponseT> |
A SingleConnection handles the state for a stream with an initial connection request that may
only be sent once and needs to wait for a response before sending other requests.
|
SingleConnectionFactory<StreamRequestT,StreamResponseT,ClientResponseT,ConnectionT extends AutoCloseable> |
|
SinglePartitionPublisher |
|
SinglePartitionPublisherBuilder |
|
SinglePartitionPublisherBuilder.Builder |
|
SinglePartitionSubscriber |
|
StreamFactories |
|
StreamFactories.CursorStreamFactory |
|
StreamFactories.PublishStreamFactory |
|
StreamFactories.SubscribeStreamFactory |
|
StreamFactory<RequestT,ResponseT> |
|
StreamingCommitCursorRequest |
A request sent from the client to the server on a stream.
|
StreamingCommitCursorRequest.Builder |
A request sent from the client to the server on a stream.
|
StreamingCommitCursorRequest.RequestCase |
|
StreamingCommitCursorRequestOrBuilder |
|
StreamingCommitCursorResponse |
Response to a StreamingCommitCursorRequest.
|
StreamingCommitCursorResponse.Builder |
Response to a StreamingCommitCursorRequest.
|
StreamingCommitCursorResponse.RequestCase |
|
StreamingCommitCursorResponseOrBuilder |
|
Subscriber |
A sub-interface of SubscriberInterface .
|
Subscriber |
A generic PubSub Lite subscriber.
|
SubscriberBuilder |
|
SubscriberBuilder.Builder |
|
SubscribeRequest |
A request sent from the client to the server on a stream.
|
SubscribeRequest.Builder |
A request sent from the client to the server on a stream.
|
SubscribeRequest.RequestCase |
|
SubscribeRequestOrBuilder |
|
SubscribeResponse |
Response to SubscribeRequest.
|
SubscribeResponse.Builder |
Response to SubscribeRequest.
|
SubscribeResponse.ResponseCase |
|
SubscribeResponseOrBuilder |
|
SubscriberFactory |
|
SubscriberImpl |
|
SubscriberProto |
|
SubscriberResetHandler |
|
SubscriberServiceClient |
Service Description: The service that a subscriber client application uses to receive messages
from subscriptions.
|
SubscriberServiceGrpc |
The service that a subscriber client application uses to receive messages
from subscriptions.
|
SubscriberServiceGrpc.AsyncService |
The service that a subscriber client application uses to receive messages
from subscriptions.
|
SubscriberServiceGrpc.SubscriberServiceBlockingStub |
A stub to allow clients to do synchronous rpc calls to service SubscriberService.
|
SubscriberServiceGrpc.SubscriberServiceFutureStub |
A stub to allow clients to do ListenableFuture-style rpc calls to service SubscriberService.
|
SubscriberServiceGrpc.SubscriberServiceImplBase |
Base class for the server implementation of the service SubscriberService.
|
SubscriberServiceGrpc.SubscriberServiceStub |
A stub to allow clients to do asynchronous rpc calls to service SubscriberService.
|
SubscriberServiceSettings |
|
SubscriberServiceSettings.Builder |
Builder for SubscriberServiceSettings.
|
SubscriberServiceStub |
Base stub class for the SubscriberService service API.
|
SubscriberServiceStubSettings |
|
SubscriberServiceStubSettings.Builder |
Builder for SubscriberServiceStubSettings.
|
SubscriberSettings |
Settings for instantiating a Pub/Sub Lite subscriber emulating the Cloud Pub/Sub Subscriber API.
|
SubscriberSettings.Builder |
|
Subscription |
Metadata about a subscription resource.
|
Subscription.Builder |
Metadata about a subscription resource.
|
Subscription.DeliveryConfig |
The settings for a subscription's message delivery.
|
Subscription.DeliveryConfig.Builder |
The settings for a subscription's message delivery.
|
Subscription.DeliveryConfig.DeliveryRequirement |
When this subscription should send messages to subscribers relative to
messages persistence in storage.
|
Subscription.DeliveryConfigOrBuilder |
|
SubscriptionName |
|
SubscriptionName |
A string wrapper for the name of a subscription.
|
SubscriptionName.Builder |
Builder for projects/{project}/locations/{location}/subscriptions/{subscription}.
|
SubscriptionOrBuilder |
|
SubscriptionPath |
A string wrapper representing a subscription.
|
SubscriptionPath.Builder |
|
SystemExecutors |
|
TestResetSignal |
|
TimeTarget |
A target publish or event time.
|
TimeTarget.Builder |
A target publish or event time.
|
TimeTarget.TimeCase |
|
TimeTargetOrBuilder |
|
Topic |
Metadata about a topic resource.
|
Topic.Builder |
Metadata about a topic resource.
|
Topic.PartitionConfig |
The settings for a topic's partitions.
|
Topic.PartitionConfig.Builder |
The settings for a topic's partitions.
|
Topic.PartitionConfig.Capacity |
The throughput capacity configuration for each partition.
|
Topic.PartitionConfig.Capacity.Builder |
The throughput capacity configuration for each partition.
|
Topic.PartitionConfig.CapacityOrBuilder |
|
Topic.PartitionConfig.DimensionCase |
|
Topic.PartitionConfigOrBuilder |
|
Topic.ReservationConfig |
The settings for this topic's Reservation usage.
|
Topic.ReservationConfig.Builder |
The settings for this topic's Reservation usage.
|
Topic.ReservationConfigOrBuilder |
|
Topic.RetentionConfig |
The settings for a topic's message retention.
|
Topic.RetentionConfig.Builder |
The settings for a topic's message retention.
|
Topic.RetentionConfigOrBuilder |
|
TopicName |
|
TopicName |
A string wrapper for the name of a topic.
|
TopicName.Builder |
Builder for projects/{project}/locations/{location}/topics/{topic}.
|
TopicOrBuilder |
|
TopicPartitions |
Response for GetTopicPartitions.
|
TopicPartitions.Builder |
Response for GetTopicPartitions.
|
TopicPartitionsOrBuilder |
|
TopicPath |
A string wrapper representing a topic.
|
TopicPath.Builder |
|
TopicStatsClient |
|
TopicStatsClientImpl |
|
TopicStatsClientSettings |
|
TopicStatsClientSettings.Builder |
|
TopicStatsProto |
|
TopicStatsServiceClient |
Service Description: This service allows users to get stats about messages in their topic.
|
TopicStatsServiceGrpc |
This service allows users to get stats about messages in their topic.
|
TopicStatsServiceGrpc.AsyncService |
This service allows users to get stats about messages in their topic.
|
TopicStatsServiceGrpc.TopicStatsServiceBlockingStub |
A stub to allow clients to do synchronous rpc calls to service TopicStatsService.
|
TopicStatsServiceGrpc.TopicStatsServiceFutureStub |
A stub to allow clients to do ListenableFuture-style rpc calls to service TopicStatsService.
|
TopicStatsServiceGrpc.TopicStatsServiceImplBase |
Base class for the server implementation of the service TopicStatsService.
|
TopicStatsServiceGrpc.TopicStatsServiceStub |
A stub to allow clients to do asynchronous rpc calls to service TopicStatsService.
|
TopicStatsServiceSettings |
|
TopicStatsServiceSettings.Builder |
Builder for TopicStatsServiceSettings.
|
TopicStatsServiceStub |
Base stub class for the TopicStatsService service API.
|
TopicStatsServiceStubSettings |
|
TopicStatsServiceStubSettings.Builder |
Builder for TopicStatsServiceStubSettings.
|
UncheckedApiPreconditions |
|
UnitTestExamples |
|
UpdateReservationRequest |
Request for UpdateReservation.
|
UpdateReservationRequest.Builder |
Request for UpdateReservation.
|
UpdateReservationRequestOrBuilder |
|
UpdateSubscriptionRequest |
Request for UpdateSubscription.
|
UpdateSubscriptionRequest.Builder |
Request for UpdateSubscription.
|
UpdateSubscriptionRequestOrBuilder |
|
UpdateTopicRequest |
Request for UpdateTopic.
|
UpdateTopicRequest.Builder |
Request for UpdateTopic.
|
UpdateTopicRequestOrBuilder |
|
UuidBuilder |
Utilities for generating and converting 128-bit UUIDs.
|
WrappingPublisher |
|