...

Package pubsublite

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

Overview ▾

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
Variables
func RegisterAdminServiceServer(s *grpc.Server, srv AdminServiceServer)
func RegisterCursorServiceServer(s *grpc.Server, srv CursorServiceServer)
func RegisterPartitionAssignmentServiceServer(s *grpc.Server, srv PartitionAssignmentServiceServer)
func RegisterPublisherServiceServer(s *grpc.Server, srv PublisherServiceServer)
func RegisterSubscriberServiceServer(s *grpc.Server, srv SubscriberServiceServer)
func RegisterTopicStatsServiceServer(s *grpc.Server, srv TopicStatsServiceServer)
type AdminServiceClient
    func NewAdminServiceClient(cc grpc.ClientConnInterface) AdminServiceClient
type AdminServiceServer
type AttributeValues
type CommitCursorRequest
type CommitCursorResponse
type ComputeHeadCursorRequest
type ComputeHeadCursorResponse
type ComputeMessageStatsRequest
type ComputeMessageStatsResponse
type ComputeTimeCursorRequest
type ComputeTimeCursorResponse
type CreateReservationRequest
type CreateSubscriptionRequest
type CreateTopicRequest
type Cursor
type CursorServiceClient
    func NewCursorServiceClient(cc grpc.ClientConnInterface) CursorServiceClient
type CursorServiceServer
type CursorService_StreamingCommitCursorClient
type CursorService_StreamingCommitCursorServer
type DeleteReservationRequest
type DeleteSubscriptionRequest
type DeleteTopicRequest
type ExportConfig
type ExportConfig_PubSubConfig
type ExportConfig_PubsubConfig
type ExportConfig_State
type FlowControlRequest
type GetReservationRequest
type GetSubscriptionRequest
type GetTopicPartitionsRequest
type GetTopicRequest
type InitialCommitCursorRequest
type InitialCommitCursorResponse
type InitialPartitionAssignmentRequest
type InitialPublishRequest
type InitialPublishResponse
type InitialSubscribeRequest
type InitialSubscribeResponse
type ListPartitionCursorsRequest
type ListPartitionCursorsResponse
type ListReservationTopicsRequest
type ListReservationTopicsResponse
type ListReservationsRequest
type ListReservationsResponse
type ListSubscriptionsRequest
type ListSubscriptionsResponse
type ListTopicSubscriptionsRequest
type ListTopicSubscriptionsResponse
type ListTopicsRequest
type ListTopicsResponse
type MessagePublishRequest
type MessagePublishResponse
type MessageResponse
type OperationMetadata
type PartitionAssignment
type PartitionAssignmentAck
type PartitionAssignmentRequest
type PartitionAssignmentRequest_Ack
type PartitionAssignmentRequest_Initial
type PartitionAssignmentServiceClient
    func NewPartitionAssignmentServiceClient(cc grpc.ClientConnInterface) PartitionAssignmentServiceClient
type PartitionAssignmentServiceServer
type PartitionAssignmentService_AssignPartitionsClient
type PartitionAssignmentService_AssignPartitionsServer
type PartitionCursor
type PubSubMessage
type PublishRequest
type PublishRequest_InitialRequest
type PublishRequest_MessagePublishRequest
type PublishResponse
type PublishResponse_InitialResponse
type PublishResponse_MessageResponse
type PublisherServiceClient
    func NewPublisherServiceClient(cc grpc.ClientConnInterface) PublisherServiceClient
type PublisherServiceServer
type PublisherService_PublishClient
type PublisherService_PublishServer
type Reservation
type SeekRequest
type SeekRequest_Cursor
type SeekRequest_NamedTarget
type SeekRequest_NamedTarget_
type SeekResponse
type SeekSubscriptionRequest
type SeekSubscriptionRequest_NamedTarget
type SeekSubscriptionRequest_NamedTarget_
type SeekSubscriptionRequest_TimeTarget
type SeekSubscriptionResponse
type SequencedCommitCursorRequest
type SequencedCommitCursorResponse
type SequencedMessage
type StreamingCommitCursorRequest
type StreamingCommitCursorRequest_Commit
type StreamingCommitCursorRequest_Initial
type StreamingCommitCursorResponse
type StreamingCommitCursorResponse_Commit
type StreamingCommitCursorResponse_Initial
type SubscribeRequest
type SubscribeRequest_FlowControl
type SubscribeRequest_Initial
type SubscribeRequest_Seek
type SubscribeResponse
type SubscribeResponse_Initial
type SubscribeResponse_Messages
type SubscribeResponse_Seek
type SubscriberServiceClient
    func NewSubscriberServiceClient(cc grpc.ClientConnInterface) SubscriberServiceClient
type SubscriberServiceServer
type SubscriberService_SubscribeClient
type SubscriberService_SubscribeServer
type Subscription
type Subscription_DeliveryConfig
type Subscription_DeliveryConfig_DeliveryRequirement
type TimeTarget
type TimeTarget_EventTime
type TimeTarget_PublishTime
type Topic
type TopicPartitions
type TopicStatsServiceClient
    func NewTopicStatsServiceClient(cc grpc.ClientConnInterface) TopicStatsServiceClient
type TopicStatsServiceServer
type Topic_PartitionConfig
type Topic_PartitionConfig_Capacity
type Topic_PartitionConfig_Capacity_
type Topic_PartitionConfig_Scale
type Topic_ReservationConfig
type Topic_RetentionConfig
type UnimplementedAdminServiceServer
type UnimplementedCursorServiceServer
type UnimplementedPartitionAssignmentServiceServer
type UnimplementedPublisherServiceServer
type UnimplementedSubscriberServiceServer
type UnimplementedTopicStatsServiceServer
type UpdateReservationRequest
type UpdateSubscriptionRequest
type UpdateTopicRequest

Package files

alias.go

Constants

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

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
)

Variables

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

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
)

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

type 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

type AdminServiceClient = src.AdminServiceClient

func NewAdminServiceClient

func NewAdminServiceClient(cc grpc.ClientConnInterface) AdminServiceClient

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

type AdminServiceServer

AdminServiceServer is the server API for AdminService service.

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

type AdminServiceServer = src.AdminServiceServer

type AttributeValues

The values associated with a key of an attribute.

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

type AttributeValues = src.AttributeValues

type CommitCursorRequest

Request for CommitCursor.

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

type CommitCursorRequest = src.CommitCursorRequest

type CommitCursorResponse

Response for CommitCursor.

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

type CommitCursorResponse = src.CommitCursorResponse

type ComputeHeadCursorRequest

Compute the current head cursor for a partition.

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

type ComputeHeadCursorRequest = src.ComputeHeadCursorRequest

type 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 ComputeHeadCursorResponse = src.ComputeHeadCursorResponse

type 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 ComputeMessageStatsRequest = src.ComputeMessageStatsRequest

type 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 ComputeMessageStatsResponse = src.ComputeMessageStatsResponse

type 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 ComputeTimeCursorRequest = src.ComputeTimeCursorRequest

type 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 ComputeTimeCursorResponse = src.ComputeTimeCursorResponse

type CreateReservationRequest

Request for CreateReservation.

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

type CreateReservationRequest = src.CreateReservationRequest

type CreateSubscriptionRequest

Request for CreateSubscription.

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

type CreateSubscriptionRequest = src.CreateSubscriptionRequest

type CreateTopicRequest

Request for CreateTopic.

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

type CreateTopicRequest = src.CreateTopicRequest

type 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 Cursor = src.Cursor

type 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

type CursorServiceClient = src.CursorServiceClient

func NewCursorServiceClient

func NewCursorServiceClient(cc grpc.ClientConnInterface) CursorServiceClient

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

type CursorServiceServer

CursorServiceServer is the server API for CursorService service.

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

type CursorServiceServer = src.CursorServiceServer

type CursorService_StreamingCommitCursorClient

type CursorService_StreamingCommitCursorClient = src.CursorService_StreamingCommitCursorClient

type CursorService_StreamingCommitCursorServer

type CursorService_StreamingCommitCursorServer = src.CursorService_StreamingCommitCursorServer

type DeleteReservationRequest

Request for DeleteReservation.

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

type DeleteReservationRequest = src.DeleteReservationRequest

type DeleteSubscriptionRequest

Request for DeleteSubscription.

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

type DeleteSubscriptionRequest = src.DeleteSubscriptionRequest

type DeleteTopicRequest

Request for DeleteTopic.

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

type DeleteTopicRequest = src.DeleteTopicRequest

type 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 = src.ExportConfig

type 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 = src.ExportConfig_PubSubConfig

type ExportConfig_PubsubConfig

type ExportConfig_PubsubConfig = src.ExportConfig_PubsubConfig

type ExportConfig_State

The desired export state.

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

type ExportConfig_State = src.ExportConfig_State

type 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 FlowControlRequest = src.FlowControlRequest

type GetReservationRequest

Request for GetReservation.

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

type GetReservationRequest = src.GetReservationRequest

type GetSubscriptionRequest

Request for GetSubscription.

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

type GetSubscriptionRequest = src.GetSubscriptionRequest

type GetTopicPartitionsRequest

Request for GetTopicPartitions.

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

type GetTopicPartitionsRequest = src.GetTopicPartitionsRequest

type GetTopicRequest

Request for GetTopic.

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

type GetTopicRequest = src.GetTopicRequest

type 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 InitialCommitCursorRequest = src.InitialCommitCursorRequest

type InitialCommitCursorResponse

Response to an InitialCommitCursorRequest.

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

type InitialCommitCursorResponse = src.InitialCommitCursorResponse

type 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 InitialPartitionAssignmentRequest = src.InitialPartitionAssignmentRequest

type 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 InitialPublishRequest = src.InitialPublishRequest

type InitialPublishResponse

Response to an InitialPublishRequest.

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

type InitialPublishResponse = src.InitialPublishResponse

type 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 InitialSubscribeRequest = src.InitialSubscribeRequest

type InitialSubscribeResponse

Response to an InitialSubscribeRequest.

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

type InitialSubscribeResponse = src.InitialSubscribeResponse

type ListPartitionCursorsRequest

Request for ListPartitionCursors.

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

type ListPartitionCursorsRequest = src.ListPartitionCursorsRequest

type ListPartitionCursorsResponse

Response for ListPartitionCursors

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

type ListPartitionCursorsResponse = src.ListPartitionCursorsResponse

type ListReservationTopicsRequest

Request for ListReservationTopics.

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

type ListReservationTopicsRequest = src.ListReservationTopicsRequest

type ListReservationTopicsResponse

Response for ListReservationTopics.

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

type ListReservationTopicsResponse = src.ListReservationTopicsResponse

type ListReservationsRequest

Request for ListReservations.

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

type ListReservationsRequest = src.ListReservationsRequest

type ListReservationsResponse

Response for ListReservations.

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

type ListReservationsResponse = src.ListReservationsResponse

type ListSubscriptionsRequest

Request for ListSubscriptions.

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

type ListSubscriptionsRequest = src.ListSubscriptionsRequest

type ListSubscriptionsResponse

Response for ListSubscriptions.

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

type ListSubscriptionsResponse = src.ListSubscriptionsResponse

type ListTopicSubscriptionsRequest

Request for ListTopicSubscriptions.

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

type ListTopicSubscriptionsRequest = src.ListTopicSubscriptionsRequest

type ListTopicSubscriptionsResponse

Response for ListTopicSubscriptions.

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

type ListTopicSubscriptionsResponse = src.ListTopicSubscriptionsResponse

type ListTopicsRequest

Request for ListTopics.

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

type ListTopicsRequest = src.ListTopicsRequest

type ListTopicsResponse

Response for ListTopics.

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

type ListTopicsResponse = src.ListTopicsResponse

type MessagePublishRequest

Request to publish messages to the topic.

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

type MessagePublishRequest = src.MessagePublishRequest

type MessagePublishResponse

Response to a MessagePublishRequest.

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

type MessagePublishResponse = src.MessagePublishResponse

type 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 MessageResponse = src.MessageResponse

type OperationMetadata

Metadata for long running operations.

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

type OperationMetadata = src.OperationMetadata

type 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 PartitionAssignment = src.PartitionAssignment

type 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 PartitionAssignmentAck = src.PartitionAssignmentAck

type PartitionAssignmentRequest

A request on the PartitionAssignment stream.

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

type PartitionAssignmentRequest = src.PartitionAssignmentRequest

type PartitionAssignmentRequest_Ack

type PartitionAssignmentRequest_Ack = src.PartitionAssignmentRequest_Ack

type PartitionAssignmentRequest_Initial

type PartitionAssignmentRequest_Initial = src.PartitionAssignmentRequest_Initial

type 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

type PartitionAssignmentServiceClient = src.PartitionAssignmentServiceClient

func NewPartitionAssignmentServiceClient

func NewPartitionAssignmentServiceClient(cc grpc.ClientConnInterface) PartitionAssignmentServiceClient

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

type PartitionAssignmentServiceServer

PartitionAssignmentServiceServer is the server API for PartitionAssignmentService service.

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

type PartitionAssignmentServiceServer = src.PartitionAssignmentServiceServer

type PartitionAssignmentService_AssignPartitionsClient

type PartitionAssignmentService_AssignPartitionsClient = src.PartitionAssignmentService_AssignPartitionsClient

type PartitionAssignmentService_AssignPartitionsServer

type PartitionAssignmentService_AssignPartitionsServer = src.PartitionAssignmentService_AssignPartitionsServer

type 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 PartitionCursor = src.PartitionCursor

type 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 PubSubMessage = src.PubSubMessage

type 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 = src.PublishRequest

type PublishRequest_InitialRequest

type PublishRequest_InitialRequest = src.PublishRequest_InitialRequest

type PublishRequest_MessagePublishRequest

type PublishRequest_MessagePublishRequest = src.PublishRequest_MessagePublishRequest

type PublishResponse

Response to a PublishRequest.

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

type PublishResponse = src.PublishResponse

type PublishResponse_InitialResponse

type PublishResponse_InitialResponse = src.PublishResponse_InitialResponse

type PublishResponse_MessageResponse

type PublishResponse_MessageResponse = src.PublishResponse_MessageResponse

type 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

type PublisherServiceClient = src.PublisherServiceClient

func NewPublisherServiceClient

func NewPublisherServiceClient(cc grpc.ClientConnInterface) PublisherServiceClient

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

type PublisherServiceServer

PublisherServiceServer is the server API for PublisherService service.

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

type PublisherServiceServer = src.PublisherServiceServer

type PublisherService_PublishClient

type PublisherService_PublishClient = src.PublisherService_PublishClient

type PublisherService_PublishServer

type PublisherService_PublishServer = src.PublisherService_PublishServer

type Reservation

Metadata about a reservation resource.

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

type Reservation = src.Reservation

type 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 = src.SeekRequest

type SeekRequest_Cursor

type SeekRequest_Cursor = src.SeekRequest_Cursor

type 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 = src.SeekRequest_NamedTarget

type SeekRequest_NamedTarget_

type SeekRequest_NamedTarget_ = src.SeekRequest_NamedTarget_

type SeekResponse

Response to a SeekRequest.

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

type SeekResponse = src.SeekResponse

type SeekSubscriptionRequest

Request for SeekSubscription.

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

type SeekSubscriptionRequest = src.SeekSubscriptionRequest

type 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 = src.SeekSubscriptionRequest_NamedTarget

type SeekSubscriptionRequest_NamedTarget_

type SeekSubscriptionRequest_NamedTarget_ = src.SeekSubscriptionRequest_NamedTarget_

type SeekSubscriptionRequest_TimeTarget

type SeekSubscriptionRequest_TimeTarget = src.SeekSubscriptionRequest_TimeTarget

type SeekSubscriptionResponse

Response for SeekSubscription long running operation.

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

type SeekSubscriptionResponse = src.SeekSubscriptionResponse

type 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 SequencedCommitCursorRequest = src.SequencedCommitCursorRequest

type SequencedCommitCursorResponse

Response to a SequencedCommitCursorRequest.

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

type SequencedCommitCursorResponse = src.SequencedCommitCursorResponse

type 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 SequencedMessage = src.SequencedMessage

type 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 = src.StreamingCommitCursorRequest

type StreamingCommitCursorRequest_Commit

type StreamingCommitCursorRequest_Commit = src.StreamingCommitCursorRequest_Commit

type StreamingCommitCursorRequest_Initial

type StreamingCommitCursorRequest_Initial = src.StreamingCommitCursorRequest_Initial

type StreamingCommitCursorResponse

Response to a StreamingCommitCursorRequest.

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

type StreamingCommitCursorResponse = src.StreamingCommitCursorResponse

type StreamingCommitCursorResponse_Commit

type StreamingCommitCursorResponse_Commit = src.StreamingCommitCursorResponse_Commit

type StreamingCommitCursorResponse_Initial

type StreamingCommitCursorResponse_Initial = src.StreamingCommitCursorResponse_Initial

type 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 = src.SubscribeRequest

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

Response to SubscribeRequest.

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

type SubscribeResponse = src.SubscribeResponse

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

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

type SubscriberServiceClient = src.SubscriberServiceClient

func NewSubscriberServiceClient

func NewSubscriberServiceClient(cc grpc.ClientConnInterface) SubscriberServiceClient

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

type SubscriberServiceServer

SubscriberServiceServer is the server API for SubscriberService service.

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

type SubscriberServiceServer = src.SubscriberServiceServer

type SubscriberService_SubscribeClient

type SubscriberService_SubscribeClient = src.SubscriberService_SubscribeClient

type SubscriberService_SubscribeServer

type SubscriberService_SubscribeServer = src.SubscriberService_SubscribeServer

type Subscription

Metadata about a subscription resource.

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

type Subscription = src.Subscription

type 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 = src.Subscription_DeliveryConfig

type 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 Subscription_DeliveryConfig_DeliveryRequirement = src.Subscription_DeliveryConfig_DeliveryRequirement

type 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 = src.TimeTarget

type TimeTarget_EventTime

type TimeTarget_EventTime = src.TimeTarget_EventTime

type TimeTarget_PublishTime

type TimeTarget_PublishTime = src.TimeTarget_PublishTime

type Topic

Metadata about a topic resource.

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

type Topic = src.Topic

type TopicPartitions

Response for GetTopicPartitions.

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

type TopicPartitions = src.TopicPartitions

type 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

type TopicStatsServiceClient = src.TopicStatsServiceClient

func NewTopicStatsServiceClient

func NewTopicStatsServiceClient(cc grpc.ClientConnInterface) TopicStatsServiceClient

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

type TopicStatsServiceServer

TopicStatsServiceServer is the server API for TopicStatsService service.

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

type TopicStatsServiceServer = src.TopicStatsServiceServer

type Topic_PartitionConfig

The settings for a topic's partitions.

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

type Topic_PartitionConfig = src.Topic_PartitionConfig

type 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 = src.Topic_PartitionConfig_Capacity

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

The settings for this topic's Reservation usage.

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

type Topic_ReservationConfig = src.Topic_ReservationConfig

type Topic_RetentionConfig

The settings for a topic's message retention.

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

type Topic_RetentionConfig = src.Topic_RetentionConfig

type UnimplementedAdminServiceServer

UnimplementedAdminServiceServer can be embedded to have forward compatible implementations.

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

type UnimplementedAdminServiceServer = src.UnimplementedAdminServiceServer

type UnimplementedCursorServiceServer

UnimplementedCursorServiceServer can be embedded to have forward compatible implementations.

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

type UnimplementedCursorServiceServer = src.UnimplementedCursorServiceServer

type UnimplementedPartitionAssignmentServiceServer

UnimplementedPartitionAssignmentServiceServer can be embedded to have forward compatible implementations.

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

type UnimplementedPartitionAssignmentServiceServer = src.UnimplementedPartitionAssignmentServiceServer

type UnimplementedPublisherServiceServer

UnimplementedPublisherServiceServer can be embedded to have forward compatible implementations.

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

type UnimplementedPublisherServiceServer = src.UnimplementedPublisherServiceServer

type UnimplementedSubscriberServiceServer

UnimplementedSubscriberServiceServer can be embedded to have forward compatible implementations.

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

type UnimplementedSubscriberServiceServer = src.UnimplementedSubscriberServiceServer

type UnimplementedTopicStatsServiceServer

UnimplementedTopicStatsServiceServer can be embedded to have forward compatible implementations.

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

type UnimplementedTopicStatsServiceServer = src.UnimplementedTopicStatsServiceServer

type UpdateReservationRequest

Request for UpdateReservation.

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

type UpdateReservationRequest = src.UpdateReservationRequest

type UpdateSubscriptionRequest

Request for UpdateSubscription.

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

type UpdateSubscriptionRequest = src.UpdateSubscriptionRequest

type UpdateTopicRequest

Request for UpdateTopic.

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

type UpdateTopicRequest = src.UpdateTopicRequest