package pubsublite

import "google.golang.org/genproto/googleapis/cloud/pubsublite/v1"

Package pubsublite aliases all exported identifiers in package "cloud.google.com/go/pubsublite/apiv1/pubsublitepb".

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb. Please read https://github.com/googleapis/google-cloud-go/blob/main/migration.md for more details.

Index

Constants

const (
	ExportConfig_ACTIVE                                          = src.ExportConfig_ACTIVE
	ExportConfig_NOT_FOUND                                       = src.ExportConfig_NOT_FOUND
	ExportConfig_PAUSED                                          = src.ExportConfig_PAUSED
	ExportConfig_PERMISSION_DENIED                               = src.ExportConfig_PERMISSION_DENIED
	ExportConfig_STATE_UNSPECIFIED                               = src.ExportConfig_STATE_UNSPECIFIED
	SeekRequest_COMMITTED_CURSOR                                 = src.SeekRequest_COMMITTED_CURSOR
	SeekRequest_HEAD                                             = src.SeekRequest_HEAD
	SeekRequest_NAMED_TARGET_UNSPECIFIED                         = src.SeekRequest_NAMED_TARGET_UNSPECIFIED
	SeekSubscriptionRequest_HEAD                                 = src.SeekSubscriptionRequest_HEAD
	SeekSubscriptionRequest_NAMED_TARGET_UNSPECIFIED             = src.SeekSubscriptionRequest_NAMED_TARGET_UNSPECIFIED
	SeekSubscriptionRequest_TAIL                                 = src.SeekSubscriptionRequest_TAIL
	Subscription_DeliveryConfig_DELIVERY_REQUIREMENT_UNSPECIFIED = src.Subscription_DeliveryConfig_DELIVERY_REQUIREMENT_UNSPECIFIED
	Subscription_DeliveryConfig_DELIVER_AFTER_STORED             = src.Subscription_DeliveryConfig_DELIVER_AFTER_STORED
	Subscription_DeliveryConfig_DELIVER_IMMEDIATELY              = src.Subscription_DeliveryConfig_DELIVER_IMMEDIATELY
)

Deprecated: Please use consts in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

Variables

var (
	ExportConfig_State_name                               = src.ExportConfig_State_name
	ExportConfig_State_value                              = src.ExportConfig_State_value
	File_google_cloud_pubsublite_v1_admin_proto           = src.File_google_cloud_pubsublite_v1_admin_proto
	File_google_cloud_pubsublite_v1_common_proto          = src.File_google_cloud_pubsublite_v1_common_proto
	File_google_cloud_pubsublite_v1_cursor_proto          = src.File_google_cloud_pubsublite_v1_cursor_proto
	File_google_cloud_pubsublite_v1_publisher_proto       = src.File_google_cloud_pubsublite_v1_publisher_proto
	File_google_cloud_pubsublite_v1_subscriber_proto      = src.File_google_cloud_pubsublite_v1_subscriber_proto
	File_google_cloud_pubsublite_v1_topic_stats_proto     = src.File_google_cloud_pubsublite_v1_topic_stats_proto
	SeekRequest_NamedTarget_name                          = src.SeekRequest_NamedTarget_name
	SeekRequest_NamedTarget_value                         = src.SeekRequest_NamedTarget_value
	SeekSubscriptionRequest_NamedTarget_name              = src.SeekSubscriptionRequest_NamedTarget_name
	SeekSubscriptionRequest_NamedTarget_value             = src.SeekSubscriptionRequest_NamedTarget_value
	Subscription_DeliveryConfig_DeliveryRequirement_name  = src.Subscription_DeliveryConfig_DeliveryRequirement_name
	Subscription_DeliveryConfig_DeliveryRequirement_value = src.Subscription_DeliveryConfig_DeliveryRequirement_value
)

Deprecated: Please use vars in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

Functions

func RegisterAdminServiceServer

func RegisterAdminServiceServer(s *grpc.Server, srv AdminServiceServer)

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func RegisterCursorServiceServer

func RegisterCursorServiceServer(s *grpc.Server, srv CursorServiceServer)

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func RegisterPartitionAssignmentServiceServer

func RegisterPartitionAssignmentServiceServer(s *grpc.Server, srv PartitionAssignmentServiceServer)

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func RegisterPublisherServiceServer

func RegisterPublisherServiceServer(s *grpc.Server, srv PublisherServiceServer)

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func RegisterSubscriberServiceServer

func RegisterSubscriberServiceServer(s *grpc.Server, srv SubscriberServiceServer)

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func RegisterTopicStatsServiceServer

func RegisterTopicStatsServiceServer(s *grpc.Server, srv TopicStatsServiceServer)

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

Types

type AdminServiceClient

type AdminServiceClient = src.AdminServiceClient

AdminServiceClient is the client API for AdminService service. For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func NewAdminServiceClient

func NewAdminServiceClient(cc grpc.ClientConnInterface) AdminServiceClient

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type AdminServiceServer

type AdminServiceServer = src.AdminServiceServer

AdminServiceServer is the server API for AdminService service.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type AttributeValues

type AttributeValues = src.AttributeValues

The values associated with a key of an attribute.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type CommitCursorRequest

type CommitCursorRequest = src.CommitCursorRequest

Request for CommitCursor.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type CommitCursorResponse

type CommitCursorResponse = src.CommitCursorResponse

Response for CommitCursor.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ComputeHeadCursorRequest

type ComputeHeadCursorRequest = src.ComputeHeadCursorRequest

Compute the current head cursor for a partition.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ComputeHeadCursorResponse

type ComputeHeadCursorResponse = src.ComputeHeadCursorResponse

Response containing the head cursor for the requested topic and partition.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ComputeMessageStatsRequest

type ComputeMessageStatsRequest = src.ComputeMessageStatsRequest

Compute statistics about a range of messages in a given topic and partition.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ComputeMessageStatsResponse

type ComputeMessageStatsResponse = src.ComputeMessageStatsResponse

Response containing stats for messages in the requested topic and partition.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ComputeTimeCursorRequest

type ComputeTimeCursorRequest = src.ComputeTimeCursorRequest

Compute the corresponding cursor for a publish or event time in a topic partition.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ComputeTimeCursorResponse

type ComputeTimeCursorResponse = src.ComputeTimeCursorResponse

Response containing the cursor corresponding to a publish or event time in a topic partition.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type CreateReservationRequest

type CreateReservationRequest = src.CreateReservationRequest

Request for CreateReservation.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type CreateSubscriptionRequest

type CreateSubscriptionRequest = src.CreateSubscriptionRequest

Request for CreateSubscription.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type CreateTopicRequest

type CreateTopicRequest = src.CreateTopicRequest

Request for CreateTopic.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type Cursor

type Cursor = src.Cursor

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

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type CursorServiceClient

type CursorServiceClient = src.CursorServiceClient

CursorServiceClient is the client API for CursorService service. For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func NewCursorServiceClient

func NewCursorServiceClient(cc grpc.ClientConnInterface) CursorServiceClient

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type CursorServiceServer

type CursorServiceServer = src.CursorServiceServer

CursorServiceServer is the server API for CursorService service.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type CursorService_StreamingCommitCursorClient

type CursorService_StreamingCommitCursorClient = src.CursorService_StreamingCommitCursorClient

type CursorService_StreamingCommitCursorServer

type CursorService_StreamingCommitCursorServer = src.CursorService_StreamingCommitCursorServer

type DeleteReservationRequest

type DeleteReservationRequest = src.DeleteReservationRequest

Request for DeleteReservation.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type DeleteSubscriptionRequest

type DeleteSubscriptionRequest = src.DeleteSubscriptionRequest

Request for DeleteSubscription.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type DeleteTopicRequest

type DeleteTopicRequest = src.DeleteTopicRequest

Request for DeleteTopic.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ExportConfig

type ExportConfig = src.ExportConfig

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

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ExportConfig_PubSubConfig

type ExportConfig_PubSubConfig = src.ExportConfig_PubSubConfig

Configuration for exporting to a Pub/Sub topic.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ExportConfig_PubsubConfig

type ExportConfig_PubsubConfig = src.ExportConfig_PubsubConfig

type ExportConfig_State

type ExportConfig_State = src.ExportConfig_State

The desired export state.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type FlowControlRequest

type FlowControlRequest = src.FlowControlRequest

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

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type GetReservationRequest

type GetReservationRequest = src.GetReservationRequest

Request for GetReservation.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type GetSubscriptionRequest

type GetSubscriptionRequest = src.GetSubscriptionRequest

Request for GetSubscription.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type GetTopicPartitionsRequest

type GetTopicPartitionsRequest = src.GetTopicPartitionsRequest

Request for GetTopicPartitions.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type GetTopicRequest

type GetTopicRequest = src.GetTopicRequest

Request for GetTopic.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type InitialCommitCursorRequest

type InitialCommitCursorRequest = src.InitialCommitCursorRequest

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.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type InitialCommitCursorResponse

type InitialCommitCursorResponse = src.InitialCommitCursorResponse

Response to an InitialCommitCursorRequest.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type InitialPartitionAssignmentRequest

type InitialPartitionAssignmentRequest = src.InitialPartitionAssignmentRequest

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.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type InitialPublishRequest

type InitialPublishRequest = src.InitialPublishRequest

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

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type InitialPublishResponse

type InitialPublishResponse = src.InitialPublishResponse

Response to an InitialPublishRequest.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type InitialSubscribeRequest

type InitialSubscribeRequest = src.InitialSubscribeRequest

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.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type InitialSubscribeResponse

type InitialSubscribeResponse = src.InitialSubscribeResponse

Response to an InitialSubscribeRequest.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListPartitionCursorsRequest

type ListPartitionCursorsRequest = src.ListPartitionCursorsRequest

Request for ListPartitionCursors.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListPartitionCursorsResponse

type ListPartitionCursorsResponse = src.ListPartitionCursorsResponse

Response for ListPartitionCursors

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListReservationTopicsRequest

type ListReservationTopicsRequest = src.ListReservationTopicsRequest

Request for ListReservationTopics.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListReservationTopicsResponse

type ListReservationTopicsResponse = src.ListReservationTopicsResponse

Response for ListReservationTopics.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListReservationsRequest

type ListReservationsRequest = src.ListReservationsRequest

Request for ListReservations.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListReservationsResponse

type ListReservationsResponse = src.ListReservationsResponse

Response for ListReservations.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListSubscriptionsRequest

type ListSubscriptionsRequest = src.ListSubscriptionsRequest

Request for ListSubscriptions.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListSubscriptionsResponse

type ListSubscriptionsResponse = src.ListSubscriptionsResponse

Response for ListSubscriptions.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListTopicSubscriptionsRequest

type ListTopicSubscriptionsRequest = src.ListTopicSubscriptionsRequest

Request for ListTopicSubscriptions.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListTopicSubscriptionsResponse

type ListTopicSubscriptionsResponse = src.ListTopicSubscriptionsResponse

Response for ListTopicSubscriptions.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListTopicsRequest

type ListTopicsRequest = src.ListTopicsRequest

Request for ListTopics.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type ListTopicsResponse

type ListTopicsResponse = src.ListTopicsResponse

Response for ListTopics.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type MessagePublishRequest

type MessagePublishRequest = src.MessagePublishRequest

Request to publish messages to the topic.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type MessagePublishResponse

type MessagePublishResponse = src.MessagePublishResponse

Response to a MessagePublishRequest.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type MessageResponse

type MessageResponse = src.MessageResponse

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.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type OperationMetadata

type OperationMetadata = src.OperationMetadata

Metadata for long running operations.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PartitionAssignment

type PartitionAssignment = src.PartitionAssignment

PartitionAssignments should not race with acknowledgements. There should be exactly one unacknowledged PartitionAssignment at a time. If not, the client must break the stream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PartitionAssignmentAck

type PartitionAssignmentAck = src.PartitionAssignmentAck

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.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PartitionAssignmentRequest

type PartitionAssignmentRequest = src.PartitionAssignmentRequest

A request on the PartitionAssignment stream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PartitionAssignmentRequest_Ack

type PartitionAssignmentRequest_Ack = src.PartitionAssignmentRequest_Ack

type PartitionAssignmentRequest_Initial

type PartitionAssignmentRequest_Initial = src.PartitionAssignmentRequest_Initial

type PartitionAssignmentServiceClient

type PartitionAssignmentServiceClient = src.PartitionAssignmentServiceClient

PartitionAssignmentServiceClient is the client API for PartitionAssignmentService service. For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func NewPartitionAssignmentServiceClient

func NewPartitionAssignmentServiceClient(cc grpc.ClientConnInterface) PartitionAssignmentServiceClient

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PartitionAssignmentServiceServer

type PartitionAssignmentServiceServer = src.PartitionAssignmentServiceServer

PartitionAssignmentServiceServer is the server API for PartitionAssignmentService service.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PartitionAssignmentService_AssignPartitionsClient

type PartitionAssignmentService_AssignPartitionsClient = src.PartitionAssignmentService_AssignPartitionsClient

type PartitionAssignmentService_AssignPartitionsServer

type PartitionAssignmentService_AssignPartitionsServer = src.PartitionAssignmentService_AssignPartitionsServer

type PartitionCursor

type PartitionCursor = src.PartitionCursor

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

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PubSubMessage

type PubSubMessage = src.PubSubMessage

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

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PublishRequest

type PublishRequest = src.PublishRequest

Request sent from the client to the server on a stream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PublishRequest_InitialRequest

type PublishRequest_InitialRequest = src.PublishRequest_InitialRequest

type PublishRequest_MessagePublishRequest

type PublishRequest_MessagePublishRequest = src.PublishRequest_MessagePublishRequest

type PublishResponse

type PublishResponse = src.PublishResponse

Response to a PublishRequest.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PublishResponse_InitialResponse

type PublishResponse_InitialResponse = src.PublishResponse_InitialResponse

type PublishResponse_MessageResponse

type PublishResponse_MessageResponse = src.PublishResponse_MessageResponse

type PublisherServiceClient

type PublisherServiceClient = src.PublisherServiceClient

PublisherServiceClient is the client API for PublisherService service. For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func NewPublisherServiceClient

func NewPublisherServiceClient(cc grpc.ClientConnInterface) PublisherServiceClient

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PublisherServiceServer

type PublisherServiceServer = src.PublisherServiceServer

PublisherServiceServer is the server API for PublisherService service.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type PublisherService_PublishClient

type PublisherService_PublishClient = src.PublisherService_PublishClient

type PublisherService_PublishServer

type PublisherService_PublishServer = src.PublisherService_PublishServer

type Reservation

type Reservation = src.Reservation

Metadata about a reservation resource.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SeekRequest

type SeekRequest = src.SeekRequest

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.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SeekRequest_Cursor

type SeekRequest_Cursor = src.SeekRequest_Cursor

type SeekRequest_NamedTarget

type SeekRequest_NamedTarget = src.SeekRequest_NamedTarget

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

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SeekRequest_NamedTarget_

type SeekRequest_NamedTarget_ = src.SeekRequest_NamedTarget_

type SeekResponse

type SeekResponse = src.SeekResponse

Response to a SeekRequest.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SeekSubscriptionRequest

type SeekSubscriptionRequest = src.SeekSubscriptionRequest

Request for SeekSubscription.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SeekSubscriptionRequest_NamedTarget

type SeekSubscriptionRequest_NamedTarget = src.SeekSubscriptionRequest_NamedTarget

A named position with respect to the message backlog.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SeekSubscriptionRequest_NamedTarget_

type SeekSubscriptionRequest_NamedTarget_ = src.SeekSubscriptionRequest_NamedTarget_

type SeekSubscriptionRequest_TimeTarget

type SeekSubscriptionRequest_TimeTarget = src.SeekSubscriptionRequest_TimeTarget

type SeekSubscriptionResponse

type SeekSubscriptionResponse = src.SeekSubscriptionResponse

Response for SeekSubscription long running operation.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SequencedCommitCursorRequest

type SequencedCommitCursorRequest = src.SequencedCommitCursorRequest

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

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SequencedCommitCursorResponse

type SequencedCommitCursorResponse = src.SequencedCommitCursorResponse

Response to a SequencedCommitCursorRequest.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SequencedMessage

type SequencedMessage = src.SequencedMessage

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

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type StreamingCommitCursorRequest

type StreamingCommitCursorRequest = src.StreamingCommitCursorRequest

A request sent from the client to the server on a stream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type StreamingCommitCursorRequest_Commit

type StreamingCommitCursorRequest_Commit = src.StreamingCommitCursorRequest_Commit

type StreamingCommitCursorRequest_Initial

type StreamingCommitCursorRequest_Initial = src.StreamingCommitCursorRequest_Initial

type StreamingCommitCursorResponse

type StreamingCommitCursorResponse = src.StreamingCommitCursorResponse

Response to a StreamingCommitCursorRequest.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type StreamingCommitCursorResponse_Commit

type StreamingCommitCursorResponse_Commit = src.StreamingCommitCursorResponse_Commit

type StreamingCommitCursorResponse_Initial

type StreamingCommitCursorResponse_Initial = src.StreamingCommitCursorResponse_Initial

type SubscribeRequest

type SubscribeRequest = src.SubscribeRequest

A request sent from the client to the server on a stream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SubscribeRequest_FlowControl

type SubscribeRequest_FlowControl = src.SubscribeRequest_FlowControl

type SubscribeRequest_Initial

type SubscribeRequest_Initial = src.SubscribeRequest_Initial

type SubscribeRequest_Seek

type SubscribeRequest_Seek = src.SubscribeRequest_Seek

type SubscribeResponse

type SubscribeResponse = src.SubscribeResponse

Response to SubscribeRequest.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SubscribeResponse_Initial

type SubscribeResponse_Initial = src.SubscribeResponse_Initial

type SubscribeResponse_Messages

type SubscribeResponse_Messages = src.SubscribeResponse_Messages

type SubscribeResponse_Seek

type SubscribeResponse_Seek = src.SubscribeResponse_Seek

type SubscriberServiceClient

type SubscriberServiceClient = src.SubscriberServiceClient

SubscriberServiceClient is the client API for SubscriberService service. For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func NewSubscriberServiceClient

func NewSubscriberServiceClient(cc grpc.ClientConnInterface) SubscriberServiceClient

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SubscriberServiceServer

type SubscriberServiceServer = src.SubscriberServiceServer

SubscriberServiceServer is the server API for SubscriberService service.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type SubscriberService_SubscribeClient

type SubscriberService_SubscribeClient = src.SubscriberService_SubscribeClient

type SubscriberService_SubscribeServer

type SubscriberService_SubscribeServer = src.SubscriberService_SubscribeServer

type Subscription

type Subscription = src.Subscription

Metadata about a subscription resource.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type Subscription_DeliveryConfig

type Subscription_DeliveryConfig = src.Subscription_DeliveryConfig

The settings for a subscription's message delivery.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type Subscription_DeliveryConfig_DeliveryRequirement

type Subscription_DeliveryConfig_DeliveryRequirement = src.Subscription_DeliveryConfig_DeliveryRequirement

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).

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type TimeTarget

type TimeTarget = src.TimeTarget

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

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type TimeTarget_EventTime

type TimeTarget_EventTime = src.TimeTarget_EventTime

type TimeTarget_PublishTime

type TimeTarget_PublishTime = src.TimeTarget_PublishTime

type Topic

type Topic = src.Topic

Metadata about a topic resource.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type TopicPartitions

type TopicPartitions = src.TopicPartitions

Response for GetTopicPartitions.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type TopicStatsServiceClient

type TopicStatsServiceClient = src.TopicStatsServiceClient

TopicStatsServiceClient is the client API for TopicStatsService service. For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

func NewTopicStatsServiceClient

func NewTopicStatsServiceClient(cc grpc.ClientConnInterface) TopicStatsServiceClient

Deprecated: Please use funcs in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type TopicStatsServiceServer

type TopicStatsServiceServer = src.TopicStatsServiceServer

TopicStatsServiceServer is the server API for TopicStatsService service.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type Topic_PartitionConfig

type Topic_PartitionConfig = src.Topic_PartitionConfig

The settings for a topic's partitions.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type Topic_PartitionConfig_Capacity

type Topic_PartitionConfig_Capacity = src.Topic_PartitionConfig_Capacity

The throughput capacity configuration for each partition.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type Topic_PartitionConfig_Capacity_

type Topic_PartitionConfig_Capacity_ = src.Topic_PartitionConfig_Capacity_

type Topic_PartitionConfig_Scale

type Topic_PartitionConfig_Scale = src.Topic_PartitionConfig_Scale

type Topic_ReservationConfig

type Topic_ReservationConfig = src.Topic_ReservationConfig

The settings for this topic's Reservation usage.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type Topic_RetentionConfig

type Topic_RetentionConfig = src.Topic_RetentionConfig

The settings for a topic's message retention.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type UnimplementedAdminServiceServer

type UnimplementedAdminServiceServer = src.UnimplementedAdminServiceServer

UnimplementedAdminServiceServer can be embedded to have forward compatible implementations.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type UnimplementedCursorServiceServer

type UnimplementedCursorServiceServer = src.UnimplementedCursorServiceServer

UnimplementedCursorServiceServer can be embedded to have forward compatible implementations.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type UnimplementedPartitionAssignmentServiceServer

type UnimplementedPartitionAssignmentServiceServer = src.UnimplementedPartitionAssignmentServiceServer

UnimplementedPartitionAssignmentServiceServer can be embedded to have forward compatible implementations.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type UnimplementedPublisherServiceServer

type UnimplementedPublisherServiceServer = src.UnimplementedPublisherServiceServer

UnimplementedPublisherServiceServer can be embedded to have forward compatible implementations.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type UnimplementedSubscriberServiceServer

type UnimplementedSubscriberServiceServer = src.UnimplementedSubscriberServiceServer

UnimplementedSubscriberServiceServer can be embedded to have forward compatible implementations.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type UnimplementedTopicStatsServiceServer

type UnimplementedTopicStatsServiceServer = src.UnimplementedTopicStatsServiceServer

UnimplementedTopicStatsServiceServer can be embedded to have forward compatible implementations.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type UpdateReservationRequest

type UpdateReservationRequest = src.UpdateReservationRequest

Request for UpdateReservation.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type UpdateSubscriptionRequest

type UpdateSubscriptionRequest = src.UpdateSubscriptionRequest

Request for UpdateSubscription.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

type UpdateTopicRequest

type UpdateTopicRequest = src.UpdateTopicRequest

Request for UpdateTopic.

Deprecated: Please use types in: cloud.google.com/go/pubsublite/apiv1/pubsublitepb

Source Files

alias.go

Version
v0.0.0-20250219182151-9fdb1cabc7b2 (latest)
Published
Feb 19, 2025
Platform
linux/amd64
Imports
2 packages
Last checked
1 hour ago

Tools for package owners.