package google.cloud.pubsublite.v1

Mouse Melon logoGet desktop application:
View/edit binary Protocol Buffers messages

service AdminService

admin.proto:39

The service that a client application uses to manage topics and subscriptions, such creating, listing, and deleting topics and subscriptions.

service CursorService

cursor.proto:37

The service that a subscriber client application uses to manage committed cursors while receiving messsages. A cursor represents a subscriber's progress within a topic partition for a given subscription.

service PartitionAssignmentService

subscriber.proto:46

The service that a subscriber client application uses to determine which partitions it should connect to.

service PublisherService

publisher.proto:36

The service that a publisher client application uses to publish messages to topics. Published messages are retained by the service for the duration of the retention period configured for the respective topic, and are delivered to subscriber clients upon request (via the `SubscriberService`).

service SubscriberService

subscriber.proto:35

The service that a subscriber client application uses to receive messages from subscriptions.

service TopicStatsService

topic_stats.proto:35

This service allows users to get stats about messages in their topic.

message AttributeValues

common.proto:34

The values associated with a key of an attribute.

Used in: PubSubMessage

message Cursor

common.proto:57

A cursor that describes the position of a message within a topic partition.

Used in: CommitCursorRequest, ComputeHeadCursorResponse, ComputeMessageStatsRequest, ComputeTimeCursorResponse, InitialSubscribeResponse, MessagePublishResponse, MessagePublishResponse.CursorRange, PartitionCursor, SeekRequest, SeekResponse, SequencedCommitCursorRequest, SequencedMessage

message ExportConfig

common.proto:237

Configuration for a Pub/Sub Lite subscription that writes messages to a destination. User subscriber clients must not connect to this subscription.

Used in: Subscription

message ExportConfig.PubSubConfig

common.proto:257

Configuration for exporting to a Pub/Sub topic.

Used in: ExportConfig

enum ExportConfig.State

common.proto:239

The desired export state.

Used in: ExportConfig

message FlowControlRequest

subscriber.proto:125

Request to grant tokens to the server, requesting delivery of messages when they become available.

Used in: SubscribeRequest

message InitialCommitCursorRequest

cursor.proto:67

The first streaming request that must be sent on a newly-opened stream. The client must wait for the response before sending subsequent requests on the stream.

Used in: StreamingCommitCursorRequest

message InitialCommitCursorResponse

cursor.proto:77

Response to an InitialCommitCursorRequest.

Used in: StreamingCommitCursorResponse

(message has no fields)

message InitialPartitionAssignmentRequest

subscriber.proto:176

The first request that must be sent on a newly-opened stream. The client must wait for the response before sending subsequent requests on the stream.

Used in: PartitionAssignmentRequest

message InitialPublishRequest

publisher.proto:52

The first request that must be sent on a newly-opened stream.

Used in: PublishRequest

message InitialPublishResponse

publisher.proto:72

Response to an InitialPublishRequest.

Used in: PublishResponse

(message has no fields)

message InitialSubscribeRequest

subscriber.proto:64

The first request that must be sent on a newly-opened stream. The client must wait for the response before sending subsequent requests on the stream.

Used in: SubscribeRequest

message InitialSubscribeResponse

subscriber.proto:79

Response to an InitialSubscribeRequest.

Used in: SubscribeResponse

message MessagePublishRequest

publisher.proto:75

Request to publish messages to the topic.

Used in: PublishRequest

message MessagePublishResponse

publisher.proto:94

Response to a MessagePublishRequest.

Used in: PublishResponse

message MessagePublishResponse.CursorRange

publisher.proto:96

Cursors for a subrange of published messages.

Used in: MessagePublishResponse

message MessageResponse

subscriber.proto:154

Response containing a list of messages. Upon delivering a MessageResponse to the client, the server: * Updates the stream's delivery cursor to one greater than the cursor of the last message in the list. * Subtracts the total number of bytes and messages from the tokens available to the server.

Used in: SubscribeResponse

message OperationMetadata

admin.proto:509

Metadata for long running operations.

message PartitionAssignmentAck

subscriber.proto:206

Acknowledge receipt and handling of the previous assignment. If not sent within a short period after receiving the assignment, partitions may remain unassigned for a period of time until the client is known to be inactive, after which time the server will break the stream.

Used in: PartitionAssignmentRequest

(message has no fields)

message PartitionCursor

cursor.proto:160

A pair of a Cursor and the partition it is for.

Used in: ListPartitionCursorsResponse

message PubSubMessage

common.proto:40

A message that is published by publishers and delivered to subscribers.

Used in: MessagePublishRequest, SequencedMessage

message Reservation

common.proto:80

Metadata about a reservation resource.

Used as response type in: AdminService.CreateReservation, AdminService.GetReservation, AdminService.UpdateReservation

Used as field type in: CreateReservationRequest, ListReservationsResponse, UpdateReservationRequest

message SeekRequest

subscriber.proto:91

Request to update the stream's delivery cursor based on the given target. Resets the server available tokens to 0. SeekRequests past head result in stream breakage. SeekRequests may not be sent while another SeekRequest is outstanding (i.e., has not received a SeekResponse) on the same stream.

Used in: InitialSubscribeRequest, SubscribeRequest

enum SeekRequest.NamedTarget

subscriber.proto:93

A special target in the partition that takes no other parameters.

Used in: SeekRequest

message SeekResponse

subscriber.proto:118

Response to a SeekRequest.

Used in: SubscribeResponse

enum SeekSubscriptionRequest.NamedTarget

admin.proto:473

A named position with respect to the message backlog.

Used in: SeekSubscriptionRequest

message SeekSubscriptionResponse

admin.proto:506

Response for SeekSubscription long running operation.

(message has no fields)

message SequencedCommitCursorRequest

cursor.proto:81

Streaming request to update the committed cursor. Subsequent SequencedCommitCursorRequests override outstanding ones.

Used in: StreamingCommitCursorRequest

message SequencedCommitCursorResponse

cursor.proto:87

Response to a SequencedCommitCursorRequest.

Used in: StreamingCommitCursorResponse

message SequencedMessage

common.proto:64

A message that has been stored and sequenced by the Pub/Sub Lite system.

Used in: MessageResponse

message Subscription

common.proto:186

Metadata about a subscription resource.

Used as response type in: AdminService.CreateSubscription, AdminService.GetSubscription, AdminService.UpdateSubscription

Used as field type in: CreateSubscriptionRequest, ListSubscriptionsResponse, UpdateSubscriptionRequest

message Subscription.DeliveryConfig

common.proto:193

The settings for a subscription's message delivery.

Used in: Subscription

enum Subscription.DeliveryConfig.DeliveryRequirement

common.proto:197

When this subscription should send messages to subscribers relative to messages persistence in storage. For details, see [Creating Lite subscriptions](https://cloud.google.com/pubsub/lite/docs/subscriptions#creating_lite_subscriptions).

Used in: DeliveryConfig

message TimeTarget

common.proto:298

A target publish or event time. Can be used for seeking to or retrieving the corresponding cursor.

Used in: ComputeTimeCursorRequest, SeekSubscriptionRequest

message Topic

common.proto:102

Metadata about a topic resource.

Used as response type in: AdminService.CreateTopic, AdminService.GetTopic, AdminService.UpdateTopic

Used as field type in: CreateTopicRequest, ListTopicsResponse, UpdateTopicRequest

message Topic.PartitionConfig

common.proto:109

The settings for a topic's partitions.

Used in: Topic

message Topic.PartitionConfig.Capacity

common.proto:111

The throughput capacity configuration for each partition.

Used in: PartitionConfig

message Topic.ReservationConfig

common.proto:161

The settings for this topic's Reservation usage.

Used in: Topic

message Topic.RetentionConfig

common.proto:147

The settings for a topic's message retention.

Used in: Topic