package pubsublitepb
import "cloud.google.com/go/pubsublite/apiv1/pubsublitepb"
Index ¶
- 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
- type AdminServiceServer
- type AttributeValues
- func (*AttributeValues) Descriptor() ([]byte, []int)
- func (x *AttributeValues) GetValues() [][]byte
- func (*AttributeValues) ProtoMessage()
- func (x *AttributeValues) ProtoReflect() protoreflect.Message
- func (x *AttributeValues) Reset()
- func (x *AttributeValues) String() string
- type CommitCursorRequest
- func (*CommitCursorRequest) Descriptor() ([]byte, []int)
- func (x *CommitCursorRequest) GetCursor() *Cursor
- func (x *CommitCursorRequest) GetPartition() int64
- func (x *CommitCursorRequest) GetSubscription() string
- func (*CommitCursorRequest) ProtoMessage()
- func (x *CommitCursorRequest) ProtoReflect() protoreflect.Message
- func (x *CommitCursorRequest) Reset()
- func (x *CommitCursorRequest) String() string
- type CommitCursorResponse
- func (*CommitCursorResponse) Descriptor() ([]byte, []int)
- func (*CommitCursorResponse) ProtoMessage()
- func (x *CommitCursorResponse) ProtoReflect() protoreflect.Message
- func (x *CommitCursorResponse) Reset()
- func (x *CommitCursorResponse) String() string
- type ComputeHeadCursorRequest
- func (*ComputeHeadCursorRequest) Descriptor() ([]byte, []int)
- func (x *ComputeHeadCursorRequest) GetPartition() int64
- func (x *ComputeHeadCursorRequest) GetTopic() string
- func (*ComputeHeadCursorRequest) ProtoMessage()
- func (x *ComputeHeadCursorRequest) ProtoReflect() protoreflect.Message
- func (x *ComputeHeadCursorRequest) Reset()
- func (x *ComputeHeadCursorRequest) String() string
- type ComputeHeadCursorResponse
- func (*ComputeHeadCursorResponse) Descriptor() ([]byte, []int)
- func (x *ComputeHeadCursorResponse) GetHeadCursor() *Cursor
- func (*ComputeHeadCursorResponse) ProtoMessage()
- func (x *ComputeHeadCursorResponse) ProtoReflect() protoreflect.Message
- func (x *ComputeHeadCursorResponse) Reset()
- func (x *ComputeHeadCursorResponse) String() string
- type ComputeMessageStatsRequest
- func (*ComputeMessageStatsRequest) Descriptor() ([]byte, []int)
- func (x *ComputeMessageStatsRequest) GetEndCursor() *Cursor
- func (x *ComputeMessageStatsRequest) GetPartition() int64
- func (x *ComputeMessageStatsRequest) GetStartCursor() *Cursor
- func (x *ComputeMessageStatsRequest) GetTopic() string
- func (*ComputeMessageStatsRequest) ProtoMessage()
- func (x *ComputeMessageStatsRequest) ProtoReflect() protoreflect.Message
- func (x *ComputeMessageStatsRequest) Reset()
- func (x *ComputeMessageStatsRequest) String() string
- type ComputeMessageStatsResponse
- func (*ComputeMessageStatsResponse) Descriptor() ([]byte, []int)
- func (x *ComputeMessageStatsResponse) GetMessageBytes() int64
- func (x *ComputeMessageStatsResponse) GetMessageCount() int64
- func (x *ComputeMessageStatsResponse) GetMinimumEventTime() *timestamppb.Timestamp
- func (x *ComputeMessageStatsResponse) GetMinimumPublishTime() *timestamppb.Timestamp
- func (*ComputeMessageStatsResponse) ProtoMessage()
- func (x *ComputeMessageStatsResponse) ProtoReflect() protoreflect.Message
- func (x *ComputeMessageStatsResponse) Reset()
- func (x *ComputeMessageStatsResponse) String() string
- type ComputeTimeCursorRequest
- func (*ComputeTimeCursorRequest) Descriptor() ([]byte, []int)
- func (x *ComputeTimeCursorRequest) GetPartition() int64
- func (x *ComputeTimeCursorRequest) GetTarget() *TimeTarget
- func (x *ComputeTimeCursorRequest) GetTopic() string
- func (*ComputeTimeCursorRequest) ProtoMessage()
- func (x *ComputeTimeCursorRequest) ProtoReflect() protoreflect.Message
- func (x *ComputeTimeCursorRequest) Reset()
- func (x *ComputeTimeCursorRequest) String() string
- type ComputeTimeCursorResponse
- func (*ComputeTimeCursorResponse) Descriptor() ([]byte, []int)
- func (x *ComputeTimeCursorResponse) GetCursor() *Cursor
- func (*ComputeTimeCursorResponse) ProtoMessage()
- func (x *ComputeTimeCursorResponse) ProtoReflect() protoreflect.Message
- func (x *ComputeTimeCursorResponse) Reset()
- func (x *ComputeTimeCursorResponse) String() string
- type CreateReservationRequest
- func (*CreateReservationRequest) Descriptor() ([]byte, []int)
- func (x *CreateReservationRequest) GetParent() string
- func (x *CreateReservationRequest) GetReservation() *Reservation
- func (x *CreateReservationRequest) GetReservationId() string
- func (*CreateReservationRequest) ProtoMessage()
- func (x *CreateReservationRequest) ProtoReflect() protoreflect.Message
- func (x *CreateReservationRequest) Reset()
- func (x *CreateReservationRequest) String() string
- type CreateSubscriptionRequest
- func (*CreateSubscriptionRequest) Descriptor() ([]byte, []int)
- func (x *CreateSubscriptionRequest) GetParent() string
- func (x *CreateSubscriptionRequest) GetSkipBacklog() bool
- func (x *CreateSubscriptionRequest) GetSubscription() *Subscription
- func (x *CreateSubscriptionRequest) GetSubscriptionId() string
- func (*CreateSubscriptionRequest) ProtoMessage()
- func (x *CreateSubscriptionRequest) ProtoReflect() protoreflect.Message
- func (x *CreateSubscriptionRequest) Reset()
- func (x *CreateSubscriptionRequest) String() string
- type CreateTopicRequest
- func (*CreateTopicRequest) Descriptor() ([]byte, []int)
- func (x *CreateTopicRequest) GetParent() string
- func (x *CreateTopicRequest) GetTopic() *Topic
- func (x *CreateTopicRequest) GetTopicId() string
- func (*CreateTopicRequest) ProtoMessage()
- func (x *CreateTopicRequest) ProtoReflect() protoreflect.Message
- func (x *CreateTopicRequest) Reset()
- func (x *CreateTopicRequest) String() string
- type Cursor
- func (*Cursor) Descriptor() ([]byte, []int)
- func (x *Cursor) GetOffset() int64
- func (*Cursor) ProtoMessage()
- func (x *Cursor) ProtoReflect() protoreflect.Message
- func (x *Cursor) Reset()
- func (x *Cursor) String() string
- type CursorServiceClient
- type CursorServiceServer
- type CursorService_StreamingCommitCursorClient
- type CursorService_StreamingCommitCursorServer
- type DeleteReservationRequest
- func (*DeleteReservationRequest) Descriptor() ([]byte, []int)
- func (x *DeleteReservationRequest) GetName() string
- func (*DeleteReservationRequest) ProtoMessage()
- func (x *DeleteReservationRequest) ProtoReflect() protoreflect.Message
- func (x *DeleteReservationRequest) Reset()
- func (x *DeleteReservationRequest) String() string
- type DeleteSubscriptionRequest
- func (*DeleteSubscriptionRequest) Descriptor() ([]byte, []int)
- func (x *DeleteSubscriptionRequest) GetName() string
- func (*DeleteSubscriptionRequest) ProtoMessage()
- func (x *DeleteSubscriptionRequest) ProtoReflect() protoreflect.Message
- func (x *DeleteSubscriptionRequest) Reset()
- func (x *DeleteSubscriptionRequest) String() string
- type DeleteTopicRequest
- func (*DeleteTopicRequest) Descriptor() ([]byte, []int)
- func (x *DeleteTopicRequest) GetName() string
- func (*DeleteTopicRequest) ProtoMessage()
- func (x *DeleteTopicRequest) ProtoReflect() protoreflect.Message
- func (x *DeleteTopicRequest) Reset()
- func (x *DeleteTopicRequest) String() string
- type ExportConfig
- func (*ExportConfig) Descriptor() ([]byte, []int)
- func (x *ExportConfig) GetCurrentState() ExportConfig_State
- func (x *ExportConfig) GetDeadLetterTopic() string
- func (x *ExportConfig) GetDesiredState() ExportConfig_State
- func (m *ExportConfig) GetDestination() isExportConfig_Destination
- func (x *ExportConfig) GetPubsubConfig() *ExportConfig_PubSubConfig
- func (*ExportConfig) ProtoMessage()
- func (x *ExportConfig) ProtoReflect() protoreflect.Message
- func (x *ExportConfig) Reset()
- func (x *ExportConfig) String() string
- type ExportConfig_PubSubConfig
- func (*ExportConfig_PubSubConfig) Descriptor() ([]byte, []int)
- func (x *ExportConfig_PubSubConfig) GetTopic() string
- func (*ExportConfig_PubSubConfig) ProtoMessage()
- func (x *ExportConfig_PubSubConfig) ProtoReflect() protoreflect.Message
- func (x *ExportConfig_PubSubConfig) Reset()
- func (x *ExportConfig_PubSubConfig) String() string
- type ExportConfig_PubsubConfig
- type ExportConfig_State
- func (ExportConfig_State) Descriptor() protoreflect.EnumDescriptor
- func (x ExportConfig_State) Enum() *ExportConfig_State
- func (ExportConfig_State) EnumDescriptor() ([]byte, []int)
- func (x ExportConfig_State) Number() protoreflect.EnumNumber
- func (x ExportConfig_State) String() string
- func (ExportConfig_State) Type() protoreflect.EnumType
- type FlowControlRequest
- func (*FlowControlRequest) Descriptor() ([]byte, []int)
- func (x *FlowControlRequest) GetAllowedBytes() int64
- func (x *FlowControlRequest) GetAllowedMessages() int64
- func (*FlowControlRequest) ProtoMessage()
- func (x *FlowControlRequest) ProtoReflect() protoreflect.Message
- func (x *FlowControlRequest) Reset()
- func (x *FlowControlRequest) String() string
- type GetReservationRequest
- func (*GetReservationRequest) Descriptor() ([]byte, []int)
- func (x *GetReservationRequest) GetName() string
- func (*GetReservationRequest) ProtoMessage()
- func (x *GetReservationRequest) ProtoReflect() protoreflect.Message
- func (x *GetReservationRequest) Reset()
- func (x *GetReservationRequest) String() string
- type GetSubscriptionRequest
- func (*GetSubscriptionRequest) Descriptor() ([]byte, []int)
- func (x *GetSubscriptionRequest) GetName() string
- func (*GetSubscriptionRequest) ProtoMessage()
- func (x *GetSubscriptionRequest) ProtoReflect() protoreflect.Message
- func (x *GetSubscriptionRequest) Reset()
- func (x *GetSubscriptionRequest) String() string
- type GetTopicPartitionsRequest
- func (*GetTopicPartitionsRequest) Descriptor() ([]byte, []int)
- func (x *GetTopicPartitionsRequest) GetName() string
- func (*GetTopicPartitionsRequest) ProtoMessage()
- func (x *GetTopicPartitionsRequest) ProtoReflect() protoreflect.Message
- func (x *GetTopicPartitionsRequest) Reset()
- func (x *GetTopicPartitionsRequest) String() string
- type GetTopicRequest
- func (*GetTopicRequest) Descriptor() ([]byte, []int)
- func (x *GetTopicRequest) GetName() string
- func (*GetTopicRequest) ProtoMessage()
- func (x *GetTopicRequest) ProtoReflect() protoreflect.Message
- func (x *GetTopicRequest) Reset()
- func (x *GetTopicRequest) String() string
- type InitialCommitCursorRequest
- func (*InitialCommitCursorRequest) Descriptor() ([]byte, []int)
- func (x *InitialCommitCursorRequest) GetPartition() int64
- func (x *InitialCommitCursorRequest) GetSubscription() string
- func (*InitialCommitCursorRequest) ProtoMessage()
- func (x *InitialCommitCursorRequest) ProtoReflect() protoreflect.Message
- func (x *InitialCommitCursorRequest) Reset()
- func (x *InitialCommitCursorRequest) String() string
- type InitialCommitCursorResponse
- func (*InitialCommitCursorResponse) Descriptor() ([]byte, []int)
- func (*InitialCommitCursorResponse) ProtoMessage()
- func (x *InitialCommitCursorResponse) ProtoReflect() protoreflect.Message
- func (x *InitialCommitCursorResponse) Reset()
- func (x *InitialCommitCursorResponse) String() string
- type InitialPartitionAssignmentRequest
- func (*InitialPartitionAssignmentRequest) Descriptor() ([]byte, []int)
- func (x *InitialPartitionAssignmentRequest) GetClientId() []byte
- func (x *InitialPartitionAssignmentRequest) GetSubscription() string
- func (*InitialPartitionAssignmentRequest) ProtoMessage()
- func (x *InitialPartitionAssignmentRequest) ProtoReflect() protoreflect.Message
- func (x *InitialPartitionAssignmentRequest) Reset()
- func (x *InitialPartitionAssignmentRequest) String() string
- type InitialPublishRequest
- func (*InitialPublishRequest) Descriptor() ([]byte, []int)
- func (x *InitialPublishRequest) GetClientId() []byte
- func (x *InitialPublishRequest) GetPartition() int64
- func (x *InitialPublishRequest) GetTopic() string
- func (*InitialPublishRequest) ProtoMessage()
- func (x *InitialPublishRequest) ProtoReflect() protoreflect.Message
- func (x *InitialPublishRequest) Reset()
- func (x *InitialPublishRequest) String() string
- type InitialPublishResponse
- func (*InitialPublishResponse) Descriptor() ([]byte, []int)
- func (*InitialPublishResponse) ProtoMessage()
- func (x *InitialPublishResponse) ProtoReflect() protoreflect.Message
- func (x *InitialPublishResponse) Reset()
- func (x *InitialPublishResponse) String() string
- type InitialSubscribeRequest
- func (*InitialSubscribeRequest) Descriptor() ([]byte, []int)
- func (x *InitialSubscribeRequest) GetInitialLocation() *SeekRequest
- func (x *InitialSubscribeRequest) GetPartition() int64
- func (x *InitialSubscribeRequest) GetSubscription() string
- func (*InitialSubscribeRequest) ProtoMessage()
- func (x *InitialSubscribeRequest) ProtoReflect() protoreflect.Message
- func (x *InitialSubscribeRequest) Reset()
- func (x *InitialSubscribeRequest) String() string
- type InitialSubscribeResponse
- func (*InitialSubscribeResponse) Descriptor() ([]byte, []int)
- func (x *InitialSubscribeResponse) GetCursor() *Cursor
- func (*InitialSubscribeResponse) ProtoMessage()
- func (x *InitialSubscribeResponse) ProtoReflect() protoreflect.Message
- func (x *InitialSubscribeResponse) Reset()
- func (x *InitialSubscribeResponse) String() string
- type ListPartitionCursorsRequest
- func (*ListPartitionCursorsRequest) Descriptor() ([]byte, []int)
- func (x *ListPartitionCursorsRequest) GetPageSize() int32
- func (x *ListPartitionCursorsRequest) GetPageToken() string
- func (x *ListPartitionCursorsRequest) GetParent() string
- func (*ListPartitionCursorsRequest) ProtoMessage()
- func (x *ListPartitionCursorsRequest) ProtoReflect() protoreflect.Message
- func (x *ListPartitionCursorsRequest) Reset()
- func (x *ListPartitionCursorsRequest) String() string
- type ListPartitionCursorsResponse
- func (*ListPartitionCursorsResponse) Descriptor() ([]byte, []int)
- func (x *ListPartitionCursorsResponse) GetNextPageToken() string
- func (x *ListPartitionCursorsResponse) GetPartitionCursors() []*PartitionCursor
- func (*ListPartitionCursorsResponse) ProtoMessage()
- func (x *ListPartitionCursorsResponse) ProtoReflect() protoreflect.Message
- func (x *ListPartitionCursorsResponse) Reset()
- func (x *ListPartitionCursorsResponse) String() string
- type ListReservationTopicsRequest
- func (*ListReservationTopicsRequest) Descriptor() ([]byte, []int)
- func (x *ListReservationTopicsRequest) GetName() string
- func (x *ListReservationTopicsRequest) GetPageSize() int32
- func (x *ListReservationTopicsRequest) GetPageToken() string
- func (*ListReservationTopicsRequest) ProtoMessage()
- func (x *ListReservationTopicsRequest) ProtoReflect() protoreflect.Message
- func (x *ListReservationTopicsRequest) Reset()
- func (x *ListReservationTopicsRequest) String() string
- type ListReservationTopicsResponse
- func (*ListReservationTopicsResponse) Descriptor() ([]byte, []int)
- func (x *ListReservationTopicsResponse) GetNextPageToken() string
- func (x *ListReservationTopicsResponse) GetTopics() []string
- func (*ListReservationTopicsResponse) ProtoMessage()
- func (x *ListReservationTopicsResponse) ProtoReflect() protoreflect.Message
- func (x *ListReservationTopicsResponse) Reset()
- func (x *ListReservationTopicsResponse) String() string
- type ListReservationsRequest
- func (*ListReservationsRequest) Descriptor() ([]byte, []int)
- func (x *ListReservationsRequest) GetPageSize() int32
- func (x *ListReservationsRequest) GetPageToken() string
- func (x *ListReservationsRequest) GetParent() string
- func (*ListReservationsRequest) ProtoMessage()
- func (x *ListReservationsRequest) ProtoReflect() protoreflect.Message
- func (x *ListReservationsRequest) Reset()
- func (x *ListReservationsRequest) String() string
- type ListReservationsResponse
- func (*ListReservationsResponse) Descriptor() ([]byte, []int)
- func (x *ListReservationsResponse) GetNextPageToken() string
- func (x *ListReservationsResponse) GetReservations() []*Reservation
- func (*ListReservationsResponse) ProtoMessage()
- func (x *ListReservationsResponse) ProtoReflect() protoreflect.Message
- func (x *ListReservationsResponse) Reset()
- func (x *ListReservationsResponse) String() string
- type ListSubscriptionsRequest
- func (*ListSubscriptionsRequest) Descriptor() ([]byte, []int)
- func (x *ListSubscriptionsRequest) GetPageSize() int32
- func (x *ListSubscriptionsRequest) GetPageToken() string
- func (x *ListSubscriptionsRequest) GetParent() string
- func (*ListSubscriptionsRequest) ProtoMessage()
- func (x *ListSubscriptionsRequest) ProtoReflect() protoreflect.Message
- func (x *ListSubscriptionsRequest) Reset()
- func (x *ListSubscriptionsRequest) String() string
- type ListSubscriptionsResponse
- func (*ListSubscriptionsResponse) Descriptor() ([]byte, []int)
- func (x *ListSubscriptionsResponse) GetNextPageToken() string
- func (x *ListSubscriptionsResponse) GetSubscriptions() []*Subscription
- func (*ListSubscriptionsResponse) ProtoMessage()
- func (x *ListSubscriptionsResponse) ProtoReflect() protoreflect.Message
- func (x *ListSubscriptionsResponse) Reset()
- func (x *ListSubscriptionsResponse) String() string
- type ListTopicSubscriptionsRequest
- func (*ListTopicSubscriptionsRequest) Descriptor() ([]byte, []int)
- func (x *ListTopicSubscriptionsRequest) GetName() string
- func (x *ListTopicSubscriptionsRequest) GetPageSize() int32
- func (x *ListTopicSubscriptionsRequest) GetPageToken() string
- func (*ListTopicSubscriptionsRequest) ProtoMessage()
- func (x *ListTopicSubscriptionsRequest) ProtoReflect() protoreflect.Message
- func (x *ListTopicSubscriptionsRequest) Reset()
- func (x *ListTopicSubscriptionsRequest) String() string
- type ListTopicSubscriptionsResponse
- func (*ListTopicSubscriptionsResponse) Descriptor() ([]byte, []int)
- func (x *ListTopicSubscriptionsResponse) GetNextPageToken() string
- func (x *ListTopicSubscriptionsResponse) GetSubscriptions() []string
- func (*ListTopicSubscriptionsResponse) ProtoMessage()
- func (x *ListTopicSubscriptionsResponse) ProtoReflect() protoreflect.Message
- func (x *ListTopicSubscriptionsResponse) Reset()
- func (x *ListTopicSubscriptionsResponse) String() string
- type ListTopicsRequest
- func (*ListTopicsRequest) Descriptor() ([]byte, []int)
- func (x *ListTopicsRequest) GetPageSize() int32
- func (x *ListTopicsRequest) GetPageToken() string
- func (x *ListTopicsRequest) GetParent() string
- func (*ListTopicsRequest) ProtoMessage()
- func (x *ListTopicsRequest) ProtoReflect() protoreflect.Message
- func (x *ListTopicsRequest) Reset()
- func (x *ListTopicsRequest) String() string
- type ListTopicsResponse
- func (*ListTopicsResponse) Descriptor() ([]byte, []int)
- func (x *ListTopicsResponse) GetNextPageToken() string
- func (x *ListTopicsResponse) GetTopics() []*Topic
- func (*ListTopicsResponse) ProtoMessage()
- func (x *ListTopicsResponse) ProtoReflect() protoreflect.Message
- func (x *ListTopicsResponse) Reset()
- func (x *ListTopicsResponse) String() string
- type MessagePublishRequest
- func (*MessagePublishRequest) Descriptor() ([]byte, []int)
- func (x *MessagePublishRequest) GetFirstSequenceNumber() int64
- func (x *MessagePublishRequest) GetMessages() []*PubSubMessage
- func (*MessagePublishRequest) ProtoMessage()
- func (x *MessagePublishRequest) ProtoReflect() protoreflect.Message
- func (x *MessagePublishRequest) Reset()
- func (x *MessagePublishRequest) String() string
- type MessagePublishResponse
- func (*MessagePublishResponse) Descriptor() ([]byte, []int)
- func (x *MessagePublishResponse) GetCursorRanges() []*MessagePublishResponse_CursorRange
- func (x *MessagePublishResponse) GetStartCursor() *Cursor
- func (*MessagePublishResponse) ProtoMessage()
- func (x *MessagePublishResponse) ProtoReflect() protoreflect.Message
- func (x *MessagePublishResponse) Reset()
- func (x *MessagePublishResponse) String() string
- type MessagePublishResponse_CursorRange
- func (*MessagePublishResponse_CursorRange) Descriptor() ([]byte, []int)
- func (x *MessagePublishResponse_CursorRange) GetEndIndex() int32
- func (x *MessagePublishResponse_CursorRange) GetStartCursor() *Cursor
- func (x *MessagePublishResponse_CursorRange) GetStartIndex() int32
- func (*MessagePublishResponse_CursorRange) ProtoMessage()
- func (x *MessagePublishResponse_CursorRange) ProtoReflect() protoreflect.Message
- func (x *MessagePublishResponse_CursorRange) Reset()
- func (x *MessagePublishResponse_CursorRange) String() string
- type MessageResponse
- func (*MessageResponse) Descriptor() ([]byte, []int)
- func (x *MessageResponse) GetMessages() []*SequencedMessage
- func (*MessageResponse) ProtoMessage()
- func (x *MessageResponse) ProtoReflect() protoreflect.Message
- func (x *MessageResponse) Reset()
- func (x *MessageResponse) String() string
- type OperationMetadata
- func (*OperationMetadata) Descriptor() ([]byte, []int)
- func (x *OperationMetadata) GetCreateTime() *timestamppb.Timestamp
- func (x *OperationMetadata) GetEndTime() *timestamppb.Timestamp
- func (x *OperationMetadata) GetTarget() string
- func (x *OperationMetadata) GetVerb() string
- func (*OperationMetadata) ProtoMessage()
- func (x *OperationMetadata) ProtoReflect() protoreflect.Message
- func (x *OperationMetadata) Reset()
- func (x *OperationMetadata) String() string
- type PartitionAssignment
- func (*PartitionAssignment) Descriptor() ([]byte, []int)
- func (x *PartitionAssignment) GetPartitions() []int64
- func (*PartitionAssignment) ProtoMessage()
- func (x *PartitionAssignment) ProtoReflect() protoreflect.Message
- func (x *PartitionAssignment) Reset()
- func (x *PartitionAssignment) String() string
- type PartitionAssignmentAck
- func (*PartitionAssignmentAck) Descriptor() ([]byte, []int)
- func (*PartitionAssignmentAck) ProtoMessage()
- func (x *PartitionAssignmentAck) ProtoReflect() protoreflect.Message
- func (x *PartitionAssignmentAck) Reset()
- func (x *PartitionAssignmentAck) String() string
- type PartitionAssignmentRequest
- func (*PartitionAssignmentRequest) Descriptor() ([]byte, []int)
- func (x *PartitionAssignmentRequest) GetAck() *PartitionAssignmentAck
- func (x *PartitionAssignmentRequest) GetInitial() *InitialPartitionAssignmentRequest
- func (m *PartitionAssignmentRequest) GetRequest() isPartitionAssignmentRequest_Request
- func (*PartitionAssignmentRequest) ProtoMessage()
- func (x *PartitionAssignmentRequest) ProtoReflect() protoreflect.Message
- func (x *PartitionAssignmentRequest) Reset()
- func (x *PartitionAssignmentRequest) String() string
- type PartitionAssignmentRequest_Ack
- type PartitionAssignmentRequest_Initial
- type PartitionAssignmentServiceClient
- type PartitionAssignmentServiceServer
- type PartitionAssignmentService_AssignPartitionsClient
- type PartitionAssignmentService_AssignPartitionsServer
- type PartitionCursor
- func (*PartitionCursor) Descriptor() ([]byte, []int)
- func (x *PartitionCursor) GetCursor() *Cursor
- func (x *PartitionCursor) GetPartition() int64
- func (*PartitionCursor) ProtoMessage()
- func (x *PartitionCursor) ProtoReflect() protoreflect.Message
- func (x *PartitionCursor) Reset()
- func (x *PartitionCursor) String() string
- type PubSubMessage
- func (*PubSubMessage) Descriptor() ([]byte, []int)
- func (x *PubSubMessage) GetAttributes() map[string]*AttributeValues
- func (x *PubSubMessage) GetData() []byte
- func (x *PubSubMessage) GetEventTime() *timestamppb.Timestamp
- func (x *PubSubMessage) GetKey() []byte
- func (*PubSubMessage) ProtoMessage()
- func (x *PubSubMessage) ProtoReflect() protoreflect.Message
- func (x *PubSubMessage) Reset()
- func (x *PubSubMessage) String() string
- type PublishRequest
- func (*PublishRequest) Descriptor() ([]byte, []int)
- func (x *PublishRequest) GetInitialRequest() *InitialPublishRequest
- func (x *PublishRequest) GetMessagePublishRequest() *MessagePublishRequest
- func (m *PublishRequest) GetRequestType() isPublishRequest_RequestType
- func (*PublishRequest) ProtoMessage()
- func (x *PublishRequest) ProtoReflect() protoreflect.Message
- func (x *PublishRequest) Reset()
- func (x *PublishRequest) String() string
- type PublishRequest_InitialRequest
- type PublishRequest_MessagePublishRequest
- type PublishResponse
- func (*PublishResponse) Descriptor() ([]byte, []int)
- func (x *PublishResponse) GetInitialResponse() *InitialPublishResponse
- func (x *PublishResponse) GetMessageResponse() *MessagePublishResponse
- func (m *PublishResponse) GetResponseType() isPublishResponse_ResponseType
- func (*PublishResponse) ProtoMessage()
- func (x *PublishResponse) ProtoReflect() protoreflect.Message
- func (x *PublishResponse) Reset()
- func (x *PublishResponse) String() string
- type PublishResponse_InitialResponse
- type PublishResponse_MessageResponse
- type PublisherServiceClient
- type PublisherServiceServer
- type PublisherService_PublishClient
- type PublisherService_PublishServer
- type Reservation
- func (*Reservation) Descriptor() ([]byte, []int)
- func (x *Reservation) GetName() string
- func (x *Reservation) GetThroughputCapacity() int64
- func (*Reservation) ProtoMessage()
- func (x *Reservation) ProtoReflect() protoreflect.Message
- func (x *Reservation) Reset()
- func (x *Reservation) String() string
- type SeekRequest
- func (*SeekRequest) Descriptor() ([]byte, []int)
- func (x *SeekRequest) GetCursor() *Cursor
- func (x *SeekRequest) GetNamedTarget() SeekRequest_NamedTarget
- func (m *SeekRequest) GetTarget() isSeekRequest_Target
- func (*SeekRequest) ProtoMessage()
- func (x *SeekRequest) ProtoReflect() protoreflect.Message
- func (x *SeekRequest) Reset()
- func (x *SeekRequest) String() string
- type SeekRequest_Cursor
- type SeekRequest_NamedTarget
- func (SeekRequest_NamedTarget) Descriptor() protoreflect.EnumDescriptor
- func (x SeekRequest_NamedTarget) Enum() *SeekRequest_NamedTarget
- func (SeekRequest_NamedTarget) EnumDescriptor() ([]byte, []int)
- func (x SeekRequest_NamedTarget) Number() protoreflect.EnumNumber
- func (x SeekRequest_NamedTarget) String() string
- func (SeekRequest_NamedTarget) Type() protoreflect.EnumType
- type SeekRequest_NamedTarget_
- type SeekResponse
- func (*SeekResponse) Descriptor() ([]byte, []int)
- func (x *SeekResponse) GetCursor() *Cursor
- func (*SeekResponse) ProtoMessage()
- func (x *SeekResponse) ProtoReflect() protoreflect.Message
- func (x *SeekResponse) Reset()
- func (x *SeekResponse) String() string
- type SeekSubscriptionRequest
- func (*SeekSubscriptionRequest) Descriptor() ([]byte, []int)
- func (x *SeekSubscriptionRequest) GetName() string
- func (x *SeekSubscriptionRequest) GetNamedTarget() SeekSubscriptionRequest_NamedTarget
- func (m *SeekSubscriptionRequest) GetTarget() isSeekSubscriptionRequest_Target
- func (x *SeekSubscriptionRequest) GetTimeTarget() *TimeTarget
- func (*SeekSubscriptionRequest) ProtoMessage()
- func (x *SeekSubscriptionRequest) ProtoReflect() protoreflect.Message
- func (x *SeekSubscriptionRequest) Reset()
- func (x *SeekSubscriptionRequest) String() string
- type SeekSubscriptionRequest_NamedTarget
- func (SeekSubscriptionRequest_NamedTarget) Descriptor() protoreflect.EnumDescriptor
- func (x SeekSubscriptionRequest_NamedTarget) Enum() *SeekSubscriptionRequest_NamedTarget
- func (SeekSubscriptionRequest_NamedTarget) EnumDescriptor() ([]byte, []int)
- func (x SeekSubscriptionRequest_NamedTarget) Number() protoreflect.EnumNumber
- func (x SeekSubscriptionRequest_NamedTarget) String() string
- func (SeekSubscriptionRequest_NamedTarget) Type() protoreflect.EnumType
- type SeekSubscriptionRequest_NamedTarget_
- type SeekSubscriptionRequest_TimeTarget
- type SeekSubscriptionResponse
- func (*SeekSubscriptionResponse) Descriptor() ([]byte, []int)
- func (*SeekSubscriptionResponse) ProtoMessage()
- func (x *SeekSubscriptionResponse) ProtoReflect() protoreflect.Message
- func (x *SeekSubscriptionResponse) Reset()
- func (x *SeekSubscriptionResponse) String() string
- type SequencedCommitCursorRequest
- func (*SequencedCommitCursorRequest) Descriptor() ([]byte, []int)
- func (x *SequencedCommitCursorRequest) GetCursor() *Cursor
- func (*SequencedCommitCursorRequest) ProtoMessage()
- func (x *SequencedCommitCursorRequest) ProtoReflect() protoreflect.Message
- func (x *SequencedCommitCursorRequest) Reset()
- func (x *SequencedCommitCursorRequest) String() string
- type SequencedCommitCursorResponse
- func (*SequencedCommitCursorResponse) Descriptor() ([]byte, []int)
- func (x *SequencedCommitCursorResponse) GetAcknowledgedCommits() int64
- func (*SequencedCommitCursorResponse) ProtoMessage()
- func (x *SequencedCommitCursorResponse) ProtoReflect() protoreflect.Message
- func (x *SequencedCommitCursorResponse) Reset()
- func (x *SequencedCommitCursorResponse) String() string
- type SequencedMessage
- func (*SequencedMessage) Descriptor() ([]byte, []int)
- func (x *SequencedMessage) GetCursor() *Cursor
- func (x *SequencedMessage) GetMessage() *PubSubMessage
- func (x *SequencedMessage) GetPublishTime() *timestamppb.Timestamp
- func (x *SequencedMessage) GetSizeBytes() int64
- func (*SequencedMessage) ProtoMessage()
- func (x *SequencedMessage) ProtoReflect() protoreflect.Message
- func (x *SequencedMessage) Reset()
- func (x *SequencedMessage) String() string
- type StreamingCommitCursorRequest
- func (*StreamingCommitCursorRequest) Descriptor() ([]byte, []int)
- func (x *StreamingCommitCursorRequest) GetCommit() *SequencedCommitCursorRequest
- func (x *StreamingCommitCursorRequest) GetInitial() *InitialCommitCursorRequest
- func (m *StreamingCommitCursorRequest) GetRequest() isStreamingCommitCursorRequest_Request
- func (*StreamingCommitCursorRequest) ProtoMessage()
- func (x *StreamingCommitCursorRequest) ProtoReflect() protoreflect.Message
- func (x *StreamingCommitCursorRequest) Reset()
- func (x *StreamingCommitCursorRequest) String() string
- type StreamingCommitCursorRequest_Commit
- type StreamingCommitCursorRequest_Initial
- type StreamingCommitCursorResponse
- func (*StreamingCommitCursorResponse) Descriptor() ([]byte, []int)
- func (x *StreamingCommitCursorResponse) GetCommit() *SequencedCommitCursorResponse
- func (x *StreamingCommitCursorResponse) GetInitial() *InitialCommitCursorResponse
- func (m *StreamingCommitCursorResponse) GetRequest() isStreamingCommitCursorResponse_Request
- func (*StreamingCommitCursorResponse) ProtoMessage()
- func (x *StreamingCommitCursorResponse) ProtoReflect() protoreflect.Message
- func (x *StreamingCommitCursorResponse) Reset()
- func (x *StreamingCommitCursorResponse) String() string
- type StreamingCommitCursorResponse_Commit
- type StreamingCommitCursorResponse_Initial
- type SubscribeRequest
- func (*SubscribeRequest) Descriptor() ([]byte, []int)
- func (x *SubscribeRequest) GetFlowControl() *FlowControlRequest
- func (x *SubscribeRequest) GetInitial() *InitialSubscribeRequest
- func (m *SubscribeRequest) GetRequest() isSubscribeRequest_Request
- func (x *SubscribeRequest) GetSeek() *SeekRequest
- func (*SubscribeRequest) ProtoMessage()
- func (x *SubscribeRequest) ProtoReflect() protoreflect.Message
- func (x *SubscribeRequest) Reset()
- func (x *SubscribeRequest) String() string
- type SubscribeRequest_FlowControl
- type SubscribeRequest_Initial
- type SubscribeRequest_Seek
- type SubscribeResponse
- func (*SubscribeResponse) Descriptor() ([]byte, []int)
- func (x *SubscribeResponse) GetInitial() *InitialSubscribeResponse
- func (x *SubscribeResponse) GetMessages() *MessageResponse
- func (m *SubscribeResponse) GetResponse() isSubscribeResponse_Response
- func (x *SubscribeResponse) GetSeek() *SeekResponse
- func (*SubscribeResponse) ProtoMessage()
- func (x *SubscribeResponse) ProtoReflect() protoreflect.Message
- func (x *SubscribeResponse) Reset()
- func (x *SubscribeResponse) String() string
- type SubscribeResponse_Initial
- type SubscribeResponse_Messages
- type SubscribeResponse_Seek
- type SubscriberServiceClient
- type SubscriberServiceServer
- type SubscriberService_SubscribeClient
- type SubscriberService_SubscribeServer
- type Subscription
- func (*Subscription) Descriptor() ([]byte, []int)
- func (x *Subscription) GetDeliveryConfig() *Subscription_DeliveryConfig
- func (x *Subscription) GetExportConfig() *ExportConfig
- func (x *Subscription) GetName() string
- func (x *Subscription) GetTopic() string
- func (*Subscription) ProtoMessage()
- func (x *Subscription) ProtoReflect() protoreflect.Message
- func (x *Subscription) Reset()
- func (x *Subscription) String() string
- type Subscription_DeliveryConfig
- func (*Subscription_DeliveryConfig) Descriptor() ([]byte, []int)
- func (x *Subscription_DeliveryConfig) GetDeliveryRequirement() Subscription_DeliveryConfig_DeliveryRequirement
- func (*Subscription_DeliveryConfig) ProtoMessage()
- func (x *Subscription_DeliveryConfig) ProtoReflect() protoreflect.Message
- func (x *Subscription_DeliveryConfig) Reset()
- func (x *Subscription_DeliveryConfig) String() string
- type Subscription_DeliveryConfig_DeliveryRequirement
- func (Subscription_DeliveryConfig_DeliveryRequirement) Descriptor() protoreflect.EnumDescriptor
- func (x Subscription_DeliveryConfig_DeliveryRequirement) Enum() *Subscription_DeliveryConfig_DeliveryRequirement
- func (Subscription_DeliveryConfig_DeliveryRequirement) EnumDescriptor() ([]byte, []int)
- func (x Subscription_DeliveryConfig_DeliveryRequirement) Number() protoreflect.EnumNumber
- func (x Subscription_DeliveryConfig_DeliveryRequirement) String() string
- func (Subscription_DeliveryConfig_DeliveryRequirement) Type() protoreflect.EnumType
- type TimeTarget
- func (*TimeTarget) Descriptor() ([]byte, []int)
- func (x *TimeTarget) GetEventTime() *timestamppb.Timestamp
- func (x *TimeTarget) GetPublishTime() *timestamppb.Timestamp
- func (m *TimeTarget) GetTime() isTimeTarget_Time
- func (*TimeTarget) ProtoMessage()
- func (x *TimeTarget) ProtoReflect() protoreflect.Message
- func (x *TimeTarget) Reset()
- func (x *TimeTarget) String() string
- type TimeTarget_EventTime
- type TimeTarget_PublishTime
- type Topic
- func (*Topic) Descriptor() ([]byte, []int)
- func (x *Topic) GetName() string
- func (x *Topic) GetPartitionConfig() *Topic_PartitionConfig
- func (x *Topic) GetReservationConfig() *Topic_ReservationConfig
- func (x *Topic) GetRetentionConfig() *Topic_RetentionConfig
- func (*Topic) ProtoMessage()
- func (x *Topic) ProtoReflect() protoreflect.Message
- func (x *Topic) Reset()
- func (x *Topic) String() string
- type TopicPartitions
- func (*TopicPartitions) Descriptor() ([]byte, []int)
- func (x *TopicPartitions) GetPartitionCount() int64
- func (*TopicPartitions) ProtoMessage()
- func (x *TopicPartitions) ProtoReflect() protoreflect.Message
- func (x *TopicPartitions) Reset()
- func (x *TopicPartitions) String() string
- type TopicStatsServiceClient
- type TopicStatsServiceServer
- type Topic_PartitionConfig
- func (*Topic_PartitionConfig) Descriptor() ([]byte, []int)
- func (x *Topic_PartitionConfig) GetCapacity() *Topic_PartitionConfig_Capacity
- func (x *Topic_PartitionConfig) GetCount() int64
- func (m *Topic_PartitionConfig) GetDimension() isTopic_PartitionConfig_Dimension
- func (x *Topic_PartitionConfig) GetScale() int32
- func (*Topic_PartitionConfig) ProtoMessage()
- func (x *Topic_PartitionConfig) ProtoReflect() protoreflect.Message
- func (x *Topic_PartitionConfig) Reset()
- func (x *Topic_PartitionConfig) String() string
- type Topic_PartitionConfig_Capacity
- func (*Topic_PartitionConfig_Capacity) Descriptor() ([]byte, []int)
- func (x *Topic_PartitionConfig_Capacity) GetPublishMibPerSec() int32
- func (x *Topic_PartitionConfig_Capacity) GetSubscribeMibPerSec() int32
- func (*Topic_PartitionConfig_Capacity) ProtoMessage()
- func (x *Topic_PartitionConfig_Capacity) ProtoReflect() protoreflect.Message
- func (x *Topic_PartitionConfig_Capacity) Reset()
- func (x *Topic_PartitionConfig_Capacity) String() string
- type Topic_PartitionConfig_Capacity_
- type Topic_PartitionConfig_Scale
- type Topic_ReservationConfig
- func (*Topic_ReservationConfig) Descriptor() ([]byte, []int)
- func (x *Topic_ReservationConfig) GetThroughputReservation() string
- func (*Topic_ReservationConfig) ProtoMessage()
- func (x *Topic_ReservationConfig) ProtoReflect() protoreflect.Message
- func (x *Topic_ReservationConfig) Reset()
- func (x *Topic_ReservationConfig) String() string
- type Topic_RetentionConfig
- func (*Topic_RetentionConfig) Descriptor() ([]byte, []int)
- func (x *Topic_RetentionConfig) GetPerPartitionBytes() int64
- func (x *Topic_RetentionConfig) GetPeriod() *durationpb.Duration
- func (*Topic_RetentionConfig) ProtoMessage()
- func (x *Topic_RetentionConfig) ProtoReflect() protoreflect.Message
- func (x *Topic_RetentionConfig) Reset()
- func (x *Topic_RetentionConfig) String() string
- type UnimplementedAdminServiceServer
- func (*UnimplementedAdminServiceServer) CreateReservation(context.Context, *CreateReservationRequest) (*Reservation, error)
- func (*UnimplementedAdminServiceServer) CreateSubscription(context.Context, *CreateSubscriptionRequest) (*Subscription, error)
- func (*UnimplementedAdminServiceServer) CreateTopic(context.Context, *CreateTopicRequest) (*Topic, error)
- func (*UnimplementedAdminServiceServer) DeleteReservation(context.Context, *DeleteReservationRequest) (*emptypb.Empty, error)
- func (*UnimplementedAdminServiceServer) DeleteSubscription(context.Context, *DeleteSubscriptionRequest) (*emptypb.Empty, error)
- func (*UnimplementedAdminServiceServer) DeleteTopic(context.Context, *DeleteTopicRequest) (*emptypb.Empty, error)
- func (*UnimplementedAdminServiceServer) GetReservation(context.Context, *GetReservationRequest) (*Reservation, error)
- func (*UnimplementedAdminServiceServer) GetSubscription(context.Context, *GetSubscriptionRequest) (*Subscription, error)
- func (*UnimplementedAdminServiceServer) GetTopic(context.Context, *GetTopicRequest) (*Topic, error)
- func (*UnimplementedAdminServiceServer) GetTopicPartitions(context.Context, *GetTopicPartitionsRequest) (*TopicPartitions, error)
- func (*UnimplementedAdminServiceServer) ListReservationTopics(context.Context, *ListReservationTopicsRequest) (*ListReservationTopicsResponse, error)
- func (*UnimplementedAdminServiceServer) ListReservations(context.Context, *ListReservationsRequest) (*ListReservationsResponse, error)
- func (*UnimplementedAdminServiceServer) ListSubscriptions(context.Context, *ListSubscriptionsRequest) (*ListSubscriptionsResponse, error)
- func (*UnimplementedAdminServiceServer) ListTopicSubscriptions(context.Context, *ListTopicSubscriptionsRequest) (*ListTopicSubscriptionsResponse, error)
- func (*UnimplementedAdminServiceServer) ListTopics(context.Context, *ListTopicsRequest) (*ListTopicsResponse, error)
- func (*UnimplementedAdminServiceServer) SeekSubscription(context.Context, *SeekSubscriptionRequest) (*longrunningpb.Operation, error)
- func (*UnimplementedAdminServiceServer) UpdateReservation(context.Context, *UpdateReservationRequest) (*Reservation, error)
- func (*UnimplementedAdminServiceServer) UpdateSubscription(context.Context, *UpdateSubscriptionRequest) (*Subscription, error)
- func (*UnimplementedAdminServiceServer) UpdateTopic(context.Context, *UpdateTopicRequest) (*Topic, error)
- type UnimplementedCursorServiceServer
- func (*UnimplementedCursorServiceServer) CommitCursor(context.Context, *CommitCursorRequest) (*CommitCursorResponse, error)
- func (*UnimplementedCursorServiceServer) ListPartitionCursors(context.Context, *ListPartitionCursorsRequest) (*ListPartitionCursorsResponse, error)
- func (*UnimplementedCursorServiceServer) StreamingCommitCursor(CursorService_StreamingCommitCursorServer) error
- type UnimplementedPartitionAssignmentServiceServer
- type UnimplementedPublisherServiceServer
- type UnimplementedSubscriberServiceServer
- type UnimplementedTopicStatsServiceServer
- func (*UnimplementedTopicStatsServiceServer) ComputeHeadCursor(context.Context, *ComputeHeadCursorRequest) (*ComputeHeadCursorResponse, error)
- func (*UnimplementedTopicStatsServiceServer) ComputeMessageStats(context.Context, *ComputeMessageStatsRequest) (*ComputeMessageStatsResponse, error)
- func (*UnimplementedTopicStatsServiceServer) ComputeTimeCursor(context.Context, *ComputeTimeCursorRequest) (*ComputeTimeCursorResponse, error)
- type UpdateReservationRequest
- func (*UpdateReservationRequest) Descriptor() ([]byte, []int)
- func (x *UpdateReservationRequest) GetReservation() *Reservation
- func (x *UpdateReservationRequest) GetUpdateMask() *fieldmaskpb.FieldMask
- func (*UpdateReservationRequest) ProtoMessage()
- func (x *UpdateReservationRequest) ProtoReflect() protoreflect.Message
- func (x *UpdateReservationRequest) Reset()
- func (x *UpdateReservationRequest) String() string
- type UpdateSubscriptionRequest
- func (*UpdateSubscriptionRequest) Descriptor() ([]byte, []int)
- func (x *UpdateSubscriptionRequest) GetSubscription() *Subscription
- func (x *UpdateSubscriptionRequest) GetUpdateMask() *fieldmaskpb.FieldMask
- func (*UpdateSubscriptionRequest) ProtoMessage()
- func (x *UpdateSubscriptionRequest) ProtoReflect() protoreflect.Message
- func (x *UpdateSubscriptionRequest) Reset()
- func (x *UpdateSubscriptionRequest) String() string
- type UpdateTopicRequest
- func (*UpdateTopicRequest) Descriptor() ([]byte, []int)
- func (x *UpdateTopicRequest) GetTopic() *Topic
- func (x *UpdateTopicRequest) GetUpdateMask() *fieldmaskpb.FieldMask
- func (*UpdateTopicRequest) ProtoMessage()
- func (x *UpdateTopicRequest) ProtoReflect() protoreflect.Message
- func (x *UpdateTopicRequest) Reset()
- func (x *UpdateTopicRequest) String() string
Variables ¶
var ( SeekSubscriptionRequest_NamedTarget_name = map[int32]string{ 0: "NAMED_TARGET_UNSPECIFIED", 1: "TAIL", 2: "HEAD", } SeekSubscriptionRequest_NamedTarget_value = map[string]int32{ "NAMED_TARGET_UNSPECIFIED": 0, "TAIL": 1, "HEAD": 2, } )
Enum value maps for SeekSubscriptionRequest_NamedTarget.
var ( Subscription_DeliveryConfig_DeliveryRequirement_name = map[int32]string{ 0: "DELIVERY_REQUIREMENT_UNSPECIFIED", 1: "DELIVER_IMMEDIATELY", 2: "DELIVER_AFTER_STORED", } Subscription_DeliveryConfig_DeliveryRequirement_value = map[string]int32{ "DELIVERY_REQUIREMENT_UNSPECIFIED": 0, "DELIVER_IMMEDIATELY": 1, "DELIVER_AFTER_STORED": 2, } )
Enum value maps for Subscription_DeliveryConfig_DeliveryRequirement.
var ( ExportConfig_State_name = map[int32]string{ 0: "STATE_UNSPECIFIED", 1: "ACTIVE", 2: "PAUSED", 3: "PERMISSION_DENIED", 4: "NOT_FOUND", } ExportConfig_State_value = map[string]int32{ "STATE_UNSPECIFIED": 0, "ACTIVE": 1, "PAUSED": 2, "PERMISSION_DENIED": 3, "NOT_FOUND": 4, } )
Enum value maps for ExportConfig_State.
var ( SeekRequest_NamedTarget_name = map[int32]string{ 0: "NAMED_TARGET_UNSPECIFIED", 1: "HEAD", 2: "COMMITTED_CURSOR", } SeekRequest_NamedTarget_value = map[string]int32{ "NAMED_TARGET_UNSPECIFIED": 0, "HEAD": 1, "COMMITTED_CURSOR": 2, } )
Enum value maps for SeekRequest_NamedTarget.
var File_google_cloud_pubsublite_v1_admin_proto protoreflect.FileDescriptor
var File_google_cloud_pubsublite_v1_common_proto protoreflect.FileDescriptor
var File_google_cloud_pubsublite_v1_cursor_proto protoreflect.FileDescriptor
var File_google_cloud_pubsublite_v1_publisher_proto protoreflect.FileDescriptor
var File_google_cloud_pubsublite_v1_subscriber_proto protoreflect.FileDescriptor
var File_google_cloud_pubsublite_v1_topic_stats_proto protoreflect.FileDescriptor
Functions ¶
func RegisterAdminServiceServer ¶
func RegisterAdminServiceServer(s *grpc.Server, srv AdminServiceServer)
func RegisterCursorServiceServer ¶
func RegisterCursorServiceServer(s *grpc.Server, srv CursorServiceServer)
func RegisterPartitionAssignmentServiceServer ¶
func RegisterPartitionAssignmentServiceServer(s *grpc.Server, srv PartitionAssignmentServiceServer)
func RegisterPublisherServiceServer ¶
func RegisterPublisherServiceServer(s *grpc.Server, srv PublisherServiceServer)
func RegisterSubscriberServiceServer ¶
func RegisterSubscriberServiceServer(s *grpc.Server, srv SubscriberServiceServer)
func RegisterTopicStatsServiceServer ¶
func RegisterTopicStatsServiceServer(s *grpc.Server, srv TopicStatsServiceServer)
Types ¶
type AdminServiceClient ¶
type AdminServiceClient interface { // Creates a new topic. CreateTopic(ctx context.Context, in *CreateTopicRequest, opts ...grpc.CallOption) (*Topic, error) // Returns the topic configuration. GetTopic(ctx context.Context, in *GetTopicRequest, opts ...grpc.CallOption) (*Topic, error) // Returns the partition information for the requested topic. GetTopicPartitions(ctx context.Context, in *GetTopicPartitionsRequest, opts ...grpc.CallOption) (*TopicPartitions, error) // Returns the list of topics for the given project. ListTopics(ctx context.Context, in *ListTopicsRequest, opts ...grpc.CallOption) (*ListTopicsResponse, error) // Updates properties of the specified topic. UpdateTopic(ctx context.Context, in *UpdateTopicRequest, opts ...grpc.CallOption) (*Topic, error) // Deletes the specified topic. DeleteTopic(ctx context.Context, in *DeleteTopicRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) // Lists the subscriptions attached to the specified topic. ListTopicSubscriptions(ctx context.Context, in *ListTopicSubscriptionsRequest, opts ...grpc.CallOption) (*ListTopicSubscriptionsResponse, error) // Creates a new subscription. CreateSubscription(ctx context.Context, in *CreateSubscriptionRequest, opts ...grpc.CallOption) (*Subscription, error) // Returns the subscription configuration. GetSubscription(ctx context.Context, in *GetSubscriptionRequest, opts ...grpc.CallOption) (*Subscription, error) // Returns the list of subscriptions for the given project. ListSubscriptions(ctx context.Context, in *ListSubscriptionsRequest, opts ...grpc.CallOption) (*ListSubscriptionsResponse, error) // Updates properties of the specified subscription. UpdateSubscription(ctx context.Context, in *UpdateSubscriptionRequest, opts ...grpc.CallOption) (*Subscription, error) // Deletes the specified subscription. DeleteSubscription(ctx context.Context, in *DeleteSubscriptionRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) // Performs an out-of-band seek for a subscription to a specified target, // which may be timestamps or named positions within the message backlog. // Seek translates these targets to cursors for each partition and // orchestrates subscribers to start consuming messages from these seek // cursors. // // If an operation is returned, the seek has been registered and subscribers // will eventually receive messages from the seek cursors (i.e. eventual // consistency), as long as they are using a minimum supported client library // version and not a system that tracks cursors independently of Pub/Sub Lite // (e.g. Apache Beam, Dataflow, Spark). The seek operation will fail for // unsupported clients. // // If clients would like to know when subscribers react to the seek (or not), // they can poll the operation. The seek operation will succeed and complete // once subscribers are ready to receive messages from the seek cursors for // all partitions of the topic. This means that the seek operation will not // complete until all subscribers come online. // // If the previous seek operation has not yet completed, it will be aborted // and the new invocation of seek will supersede it. SeekSubscription(ctx context.Context, in *SeekSubscriptionRequest, opts ...grpc.CallOption) (*longrunningpb.Operation, error) // Creates a new reservation. CreateReservation(ctx context.Context, in *CreateReservationRequest, opts ...grpc.CallOption) (*Reservation, error) // Returns the reservation configuration. GetReservation(ctx context.Context, in *GetReservationRequest, opts ...grpc.CallOption) (*Reservation, error) // Returns the list of reservations for the given project. ListReservations(ctx context.Context, in *ListReservationsRequest, opts ...grpc.CallOption) (*ListReservationsResponse, error) // Updates properties of the specified reservation. UpdateReservation(ctx context.Context, in *UpdateReservationRequest, opts ...grpc.CallOption) (*Reservation, error) // Deletes the specified reservation. DeleteReservation(ctx context.Context, in *DeleteReservationRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) // Lists the topics attached to the specified reservation. ListReservationTopics(ctx context.Context, in *ListReservationTopicsRequest, opts ...grpc.CallOption) (*ListReservationTopicsResponse, error) }
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.
func NewAdminServiceClient ¶
func NewAdminServiceClient(cc grpc.ClientConnInterface) AdminServiceClient
type AdminServiceServer ¶
type AdminServiceServer interface { // Creates a new topic. CreateTopic(context.Context, *CreateTopicRequest) (*Topic, error) // Returns the topic configuration. GetTopic(context.Context, *GetTopicRequest) (*Topic, error) // Returns the partition information for the requested topic. GetTopicPartitions(context.Context, *GetTopicPartitionsRequest) (*TopicPartitions, error) // Returns the list of topics for the given project. ListTopics(context.Context, *ListTopicsRequest) (*ListTopicsResponse, error) // Updates properties of the specified topic. UpdateTopic(context.Context, *UpdateTopicRequest) (*Topic, error) // Deletes the specified topic. DeleteTopic(context.Context, *DeleteTopicRequest) (*emptypb.Empty, error) // Lists the subscriptions attached to the specified topic. ListTopicSubscriptions(context.Context, *ListTopicSubscriptionsRequest) (*ListTopicSubscriptionsResponse, error) // Creates a new subscription. CreateSubscription(context.Context, *CreateSubscriptionRequest) (*Subscription, error) // Returns the subscription configuration. GetSubscription(context.Context, *GetSubscriptionRequest) (*Subscription, error) // Returns the list of subscriptions for the given project. ListSubscriptions(context.Context, *ListSubscriptionsRequest) (*ListSubscriptionsResponse, error) // Updates properties of the specified subscription. UpdateSubscription(context.Context, *UpdateSubscriptionRequest) (*Subscription, error) // Deletes the specified subscription. DeleteSubscription(context.Context, *DeleteSubscriptionRequest) (*emptypb.Empty, error) // Performs an out-of-band seek for a subscription to a specified target, // which may be timestamps or named positions within the message backlog. // Seek translates these targets to cursors for each partition and // orchestrates subscribers to start consuming messages from these seek // cursors. // // If an operation is returned, the seek has been registered and subscribers // will eventually receive messages from the seek cursors (i.e. eventual // consistency), as long as they are using a minimum supported client library // version and not a system that tracks cursors independently of Pub/Sub Lite // (e.g. Apache Beam, Dataflow, Spark). The seek operation will fail for // unsupported clients. // // If clients would like to know when subscribers react to the seek (or not), // they can poll the operation. The seek operation will succeed and complete // once subscribers are ready to receive messages from the seek cursors for // all partitions of the topic. This means that the seek operation will not // complete until all subscribers come online. // // If the previous seek operation has not yet completed, it will be aborted // and the new invocation of seek will supersede it. SeekSubscription(context.Context, *SeekSubscriptionRequest) (*longrunningpb.Operation, error) // Creates a new reservation. CreateReservation(context.Context, *CreateReservationRequest) (*Reservation, error) // Returns the reservation configuration. GetReservation(context.Context, *GetReservationRequest) (*Reservation, error) // Returns the list of reservations for the given project. ListReservations(context.Context, *ListReservationsRequest) (*ListReservationsResponse, error) // Updates properties of the specified reservation. UpdateReservation(context.Context, *UpdateReservationRequest) (*Reservation, error) // Deletes the specified reservation. DeleteReservation(context.Context, *DeleteReservationRequest) (*emptypb.Empty, error) // Lists the topics attached to the specified reservation. ListReservationTopics(context.Context, *ListReservationTopicsRequest) (*ListReservationTopicsResponse, error) }
AdminServiceServer is the server API for AdminService service.
type AttributeValues ¶
type AttributeValues struct { // The list of values associated with a key. Values [][]byte `protobuf:"bytes,1,rep,name=values,proto3" json:"values,omitempty"` // contains filtered or unexported fields }
The values associated with a key of an attribute.
func (*AttributeValues) Descriptor ¶
func (*AttributeValues) Descriptor() ([]byte, []int)
Deprecated: Use AttributeValues.ProtoReflect.Descriptor instead.
func (*AttributeValues) GetValues ¶
func (x *AttributeValues) GetValues() [][]byte
func (*AttributeValues) ProtoMessage ¶
func (*AttributeValues) ProtoMessage()
func (*AttributeValues) ProtoReflect ¶
func (x *AttributeValues) ProtoReflect() protoreflect.Message
func (*AttributeValues) Reset ¶
func (x *AttributeValues) Reset()
func (*AttributeValues) String ¶
func (x *AttributeValues) String() string
type CommitCursorRequest ¶
type CommitCursorRequest struct { // The subscription for which to update the cursor. Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"` // The partition for which to update the cursor. Partitions are zero indexed, // so `partition` must be in the range [0, topic.num_partitions). Partition int64 `protobuf:"varint,2,opt,name=partition,proto3" json:"partition,omitempty"` // The new value for the committed cursor. Cursor *Cursor `protobuf:"bytes,3,opt,name=cursor,proto3" json:"cursor,omitempty"` // contains filtered or unexported fields }
Request for CommitCursor.
func (*CommitCursorRequest) Descriptor ¶
func (*CommitCursorRequest) Descriptor() ([]byte, []int)
Deprecated: Use CommitCursorRequest.ProtoReflect.Descriptor instead.
func (*CommitCursorRequest) GetCursor ¶
func (x *CommitCursorRequest) GetCursor() *Cursor
func (*CommitCursorRequest) GetPartition ¶
func (x *CommitCursorRequest) GetPartition() int64
func (*CommitCursorRequest) GetSubscription ¶
func (x *CommitCursorRequest) GetSubscription() string
func (*CommitCursorRequest) ProtoMessage ¶
func (*CommitCursorRequest) ProtoMessage()
func (*CommitCursorRequest) ProtoReflect ¶
func (x *CommitCursorRequest) ProtoReflect() protoreflect.Message
func (*CommitCursorRequest) Reset ¶
func (x *CommitCursorRequest) Reset()
func (*CommitCursorRequest) String ¶
func (x *CommitCursorRequest) String() string
type CommitCursorResponse ¶
type CommitCursorResponse struct {
// contains filtered or unexported fields
}
Response for CommitCursor.
func (*CommitCursorResponse) Descriptor ¶
func (*CommitCursorResponse) Descriptor() ([]byte, []int)
Deprecated: Use CommitCursorResponse.ProtoReflect.Descriptor instead.
func (*CommitCursorResponse) ProtoMessage ¶
func (*CommitCursorResponse) ProtoMessage()
func (*CommitCursorResponse) ProtoReflect ¶
func (x *CommitCursorResponse) ProtoReflect() protoreflect.Message
func (*CommitCursorResponse) Reset ¶
func (x *CommitCursorResponse) Reset()
func (*CommitCursorResponse) String ¶
func (x *CommitCursorResponse) String() string
type ComputeHeadCursorRequest ¶
type ComputeHeadCursorRequest struct { // Required. The topic for which we should compute the head cursor. Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"` // Required. The partition for which we should compute the head cursor. Partition int64 `protobuf:"varint,2,opt,name=partition,proto3" json:"partition,omitempty"` // contains filtered or unexported fields }
Compute the current head cursor for a partition.
func (*ComputeHeadCursorRequest) Descriptor ¶
func (*ComputeHeadCursorRequest) Descriptor() ([]byte, []int)
Deprecated: Use ComputeHeadCursorRequest.ProtoReflect.Descriptor instead.
func (*ComputeHeadCursorRequest) GetPartition ¶
func (x *ComputeHeadCursorRequest) GetPartition() int64
func (*ComputeHeadCursorRequest) GetTopic ¶
func (x *ComputeHeadCursorRequest) GetTopic() string
func (*ComputeHeadCursorRequest) ProtoMessage ¶
func (*ComputeHeadCursorRequest) ProtoMessage()
func (*ComputeHeadCursorRequest) ProtoReflect ¶
func (x *ComputeHeadCursorRequest) ProtoReflect() protoreflect.Message
func (*ComputeHeadCursorRequest) Reset ¶
func (x *ComputeHeadCursorRequest) Reset()
func (*ComputeHeadCursorRequest) String ¶
func (x *ComputeHeadCursorRequest) String() string
type ComputeHeadCursorResponse ¶
type ComputeHeadCursorResponse struct { // The head cursor. HeadCursor *Cursor `protobuf:"bytes,1,opt,name=head_cursor,json=headCursor,proto3" json:"head_cursor,omitempty"` // contains filtered or unexported fields }
Response containing the head cursor for the requested topic and partition.
func (*ComputeHeadCursorResponse) Descriptor ¶
func (*ComputeHeadCursorResponse) Descriptor() ([]byte, []int)
Deprecated: Use ComputeHeadCursorResponse.ProtoReflect.Descriptor instead.
func (*ComputeHeadCursorResponse) GetHeadCursor ¶
func (x *ComputeHeadCursorResponse) GetHeadCursor() *Cursor
func (*ComputeHeadCursorResponse) ProtoMessage ¶
func (*ComputeHeadCursorResponse) ProtoMessage()
func (*ComputeHeadCursorResponse) ProtoReflect ¶
func (x *ComputeHeadCursorResponse) ProtoReflect() protoreflect.Message
func (*ComputeHeadCursorResponse) Reset ¶
func (x *ComputeHeadCursorResponse) Reset()
func (*ComputeHeadCursorResponse) String ¶
func (x *ComputeHeadCursorResponse) String() string
type ComputeMessageStatsRequest ¶
type ComputeMessageStatsRequest struct { // Required. The topic for which we should compute message stats. Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"` // Required. The partition for which we should compute message stats. Partition int64 `protobuf:"varint,2,opt,name=partition,proto3" json:"partition,omitempty"` // The inclusive start of the range. StartCursor *Cursor `protobuf:"bytes,3,opt,name=start_cursor,json=startCursor,proto3" json:"start_cursor,omitempty"` // The exclusive end of the range. The range is empty if end_cursor <= // start_cursor. Specifying a start_cursor before the first message and an // end_cursor after the last message will retrieve all messages. EndCursor *Cursor `protobuf:"bytes,4,opt,name=end_cursor,json=endCursor,proto3" json:"end_cursor,omitempty"` // contains filtered or unexported fields }
Compute statistics about a range of messages in a given topic and partition.
func (*ComputeMessageStatsRequest) Descriptor ¶
func (*ComputeMessageStatsRequest) Descriptor() ([]byte, []int)
Deprecated: Use ComputeMessageStatsRequest.ProtoReflect.Descriptor instead.
func (*ComputeMessageStatsRequest) GetEndCursor ¶
func (x *ComputeMessageStatsRequest) GetEndCursor() *Cursor
func (*ComputeMessageStatsRequest) GetPartition ¶
func (x *ComputeMessageStatsRequest) GetPartition() int64
func (*ComputeMessageStatsRequest) GetStartCursor ¶
func (x *ComputeMessageStatsRequest) GetStartCursor() *Cursor
func (*ComputeMessageStatsRequest) GetTopic ¶
func (x *ComputeMessageStatsRequest) GetTopic() string
func (*ComputeMessageStatsRequest) ProtoMessage ¶
func (*ComputeMessageStatsRequest) ProtoMessage()
func (*ComputeMessageStatsRequest) ProtoReflect ¶
func (x *ComputeMessageStatsRequest) ProtoReflect() protoreflect.Message
func (*ComputeMessageStatsRequest) Reset ¶
func (x *ComputeMessageStatsRequest) Reset()
func (*ComputeMessageStatsRequest) String ¶
func (x *ComputeMessageStatsRequest) String() string
type ComputeMessageStatsResponse ¶
type ComputeMessageStatsResponse struct { // The count of messages. MessageCount int64 `protobuf:"varint,1,opt,name=message_count,json=messageCount,proto3" json:"message_count,omitempty"` // The number of quota bytes accounted to these messages. MessageBytes int64 `protobuf:"varint,2,opt,name=message_bytes,json=messageBytes,proto3" json:"message_bytes,omitempty"` // The minimum publish timestamp across these messages. Note that publish // timestamps within a partition are not guaranteed to be non-decreasing. The // timestamp will be unset if there are no messages. MinimumPublishTime *timestamppb.Timestamp `protobuf:"bytes,3,opt,name=minimum_publish_time,json=minimumPublishTime,proto3" json:"minimum_publish_time,omitempty"` // The minimum event timestamp across these messages. For the purposes of this // computation, if a message does not have an event time, we use the publish // time. The timestamp will be unset if there are no messages. MinimumEventTime *timestamppb.Timestamp `protobuf:"bytes,4,opt,name=minimum_event_time,json=minimumEventTime,proto3" json:"minimum_event_time,omitempty"` // contains filtered or unexported fields }
Response containing stats for messages in the requested topic and partition.
func (*ComputeMessageStatsResponse) Descriptor ¶
func (*ComputeMessageStatsResponse) Descriptor() ([]byte, []int)
Deprecated: Use ComputeMessageStatsResponse.ProtoReflect.Descriptor instead.
func (*ComputeMessageStatsResponse) GetMessageBytes ¶
func (x *ComputeMessageStatsResponse) GetMessageBytes() int64
func (*ComputeMessageStatsResponse) GetMessageCount ¶
func (x *ComputeMessageStatsResponse) GetMessageCount() int64
func (*ComputeMessageStatsResponse) GetMinimumEventTime ¶
func (x *ComputeMessageStatsResponse) GetMinimumEventTime() *timestamppb.Timestamp
func (*ComputeMessageStatsResponse) GetMinimumPublishTime ¶
func (x *ComputeMessageStatsResponse) GetMinimumPublishTime() *timestamppb.Timestamp
func (*ComputeMessageStatsResponse) ProtoMessage ¶
func (*ComputeMessageStatsResponse) ProtoMessage()
func (*ComputeMessageStatsResponse) ProtoReflect ¶
func (x *ComputeMessageStatsResponse) ProtoReflect() protoreflect.Message
func (*ComputeMessageStatsResponse) Reset ¶
func (x *ComputeMessageStatsResponse) Reset()
func (*ComputeMessageStatsResponse) String ¶
func (x *ComputeMessageStatsResponse) String() string
type ComputeTimeCursorRequest ¶
type ComputeTimeCursorRequest struct { // Required. The topic for which we should compute the cursor. Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"` // Required. The partition for which we should compute the cursor. Partition int64 `protobuf:"varint,2,opt,name=partition,proto3" json:"partition,omitempty"` // Required. The target publish or event time. Specifying a future time will // return an unset cursor. Target *TimeTarget `protobuf:"bytes,3,opt,name=target,proto3" json:"target,omitempty"` // contains filtered or unexported fields }
Compute the corresponding cursor for a publish or event time in a topic partition.
func (*ComputeTimeCursorRequest) Descriptor ¶
func (*ComputeTimeCursorRequest) Descriptor() ([]byte, []int)
Deprecated: Use ComputeTimeCursorRequest.ProtoReflect.Descriptor instead.
func (*ComputeTimeCursorRequest) GetPartition ¶
func (x *ComputeTimeCursorRequest) GetPartition() int64
func (*ComputeTimeCursorRequest) GetTarget ¶
func (x *ComputeTimeCursorRequest) GetTarget() *TimeTarget
func (*ComputeTimeCursorRequest) GetTopic ¶
func (x *ComputeTimeCursorRequest) GetTopic() string
func (*ComputeTimeCursorRequest) ProtoMessage ¶
func (*ComputeTimeCursorRequest) ProtoMessage()
func (*ComputeTimeCursorRequest) ProtoReflect ¶
func (x *ComputeTimeCursorRequest) ProtoReflect() protoreflect.Message
func (*ComputeTimeCursorRequest) Reset ¶
func (x *ComputeTimeCursorRequest) Reset()
func (*ComputeTimeCursorRequest) String ¶
func (x *ComputeTimeCursorRequest) String() string
type ComputeTimeCursorResponse ¶
type ComputeTimeCursorResponse struct { // If present, the cursor references the first message with time greater than // or equal to the specified target time. If such a message cannot be found, // the cursor will be unset (i.e. `cursor` is not present). Cursor *Cursor `protobuf:"bytes,1,opt,name=cursor,proto3" json:"cursor,omitempty"` // contains filtered or unexported fields }
Response containing the cursor corresponding to a publish or event time in a topic partition.
func (*ComputeTimeCursorResponse) Descriptor ¶
func (*ComputeTimeCursorResponse) Descriptor() ([]byte, []int)
Deprecated: Use ComputeTimeCursorResponse.ProtoReflect.Descriptor instead.
func (*ComputeTimeCursorResponse) GetCursor ¶
func (x *ComputeTimeCursorResponse) GetCursor() *Cursor
func (*ComputeTimeCursorResponse) ProtoMessage ¶
func (*ComputeTimeCursorResponse) ProtoMessage()
func (*ComputeTimeCursorResponse) ProtoReflect ¶
func (x *ComputeTimeCursorResponse) ProtoReflect() protoreflect.Message
func (*ComputeTimeCursorResponse) Reset ¶
func (x *ComputeTimeCursorResponse) Reset()
func (*ComputeTimeCursorResponse) String ¶
func (x *ComputeTimeCursorResponse) String() string
type CreateReservationRequest ¶
type CreateReservationRequest struct { // Required. The parent location in which to create the reservation. // Structured like `projects/{project_number}/locations/{location}`. Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"` // Required. Configuration of the reservation to create. Its `name` field is // ignored. Reservation *Reservation `protobuf:"bytes,2,opt,name=reservation,proto3" json:"reservation,omitempty"` // Required. The ID to use for the reservation, which will become the final // component of the reservation's name. // // This value is structured like: `my-reservation-name`. ReservationId string `protobuf:"bytes,3,opt,name=reservation_id,json=reservationId,proto3" json:"reservation_id,omitempty"` // contains filtered or unexported fields }
Request for CreateReservation.
func (*CreateReservationRequest) Descriptor ¶
func (*CreateReservationRequest) Descriptor() ([]byte, []int)
Deprecated: Use CreateReservationRequest.ProtoReflect.Descriptor instead.
func (*CreateReservationRequest) GetParent ¶
func (x *CreateReservationRequest) GetParent() string
func (*CreateReservationRequest) GetReservation ¶
func (x *CreateReservationRequest) GetReservation() *Reservation
func (*CreateReservationRequest) GetReservationId ¶
func (x *CreateReservationRequest) GetReservationId() string
func (*CreateReservationRequest) ProtoMessage ¶
func (*CreateReservationRequest) ProtoMessage()
func (*CreateReservationRequest) ProtoReflect ¶
func (x *CreateReservationRequest) ProtoReflect() protoreflect.Message
func (*CreateReservationRequest) Reset ¶
func (x *CreateReservationRequest) Reset()
func (*CreateReservationRequest) String ¶
func (x *CreateReservationRequest) String() string
type CreateSubscriptionRequest ¶
type CreateSubscriptionRequest struct { // Required. The parent location in which to create the subscription. // Structured like `projects/{project_number}/locations/{location}`. Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"` // Required. Configuration of the subscription to create. Its `name` field is // ignored. Subscription *Subscription `protobuf:"bytes,2,opt,name=subscription,proto3" json:"subscription,omitempty"` // Required. The ID to use for the subscription, which will become the final // component of the subscription's name. // // This value is structured like: `my-sub-name`. SubscriptionId string `protobuf:"bytes,3,opt,name=subscription_id,json=subscriptionId,proto3" json:"subscription_id,omitempty"` // If true, the newly created subscription will only receive messages // published after the subscription was created. Otherwise, the entire // message backlog will be received on the subscription. Defaults to false. SkipBacklog bool `protobuf:"varint,4,opt,name=skip_backlog,json=skipBacklog,proto3" json:"skip_backlog,omitempty"` // contains filtered or unexported fields }
Request for CreateSubscription.
func (*CreateSubscriptionRequest) Descriptor ¶
func (*CreateSubscriptionRequest) Descriptor() ([]byte, []int)
Deprecated: Use CreateSubscriptionRequest.ProtoReflect.Descriptor instead.
func (*CreateSubscriptionRequest) GetParent ¶
func (x *CreateSubscriptionRequest) GetParent() string
func (*CreateSubscriptionRequest) GetSkipBacklog ¶
func (x *CreateSubscriptionRequest) GetSkipBacklog() bool
func (*CreateSubscriptionRequest) GetSubscription ¶
func (x *CreateSubscriptionRequest) GetSubscription() *Subscription
func (*CreateSubscriptionRequest) GetSubscriptionId ¶
func (x *CreateSubscriptionRequest) GetSubscriptionId() string
func (*CreateSubscriptionRequest) ProtoMessage ¶
func (*CreateSubscriptionRequest) ProtoMessage()
func (*CreateSubscriptionRequest) ProtoReflect ¶
func (x *CreateSubscriptionRequest) ProtoReflect() protoreflect.Message
func (*CreateSubscriptionRequest) Reset ¶
func (x *CreateSubscriptionRequest) Reset()
func (*CreateSubscriptionRequest) String ¶
func (x *CreateSubscriptionRequest) String() string
type CreateTopicRequest ¶
type CreateTopicRequest struct { // Required. The parent location in which to create the topic. // Structured like `projects/{project_number}/locations/{location}`. Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"` // Required. Configuration of the topic to create. Its `name` field is // ignored. Topic *Topic `protobuf:"bytes,2,opt,name=topic,proto3" json:"topic,omitempty"` // Required. The ID to use for the topic, which will become the final // component of the topic's name. // // This value is structured like: `my-topic-name`. TopicId string `protobuf:"bytes,3,opt,name=topic_id,json=topicId,proto3" json:"topic_id,omitempty"` // contains filtered or unexported fields }
Request for CreateTopic.
func (*CreateTopicRequest) Descriptor ¶
func (*CreateTopicRequest) Descriptor() ([]byte, []int)
Deprecated: Use CreateTopicRequest.ProtoReflect.Descriptor instead.
func (*CreateTopicRequest) GetParent ¶
func (x *CreateTopicRequest) GetParent() string
func (*CreateTopicRequest) GetTopic ¶
func (x *CreateTopicRequest) GetTopic() *Topic
func (*CreateTopicRequest) GetTopicId ¶
func (x *CreateTopicRequest) GetTopicId() string
func (*CreateTopicRequest) ProtoMessage ¶
func (*CreateTopicRequest) ProtoMessage()
func (*CreateTopicRequest) ProtoReflect ¶
func (x *CreateTopicRequest) ProtoReflect() protoreflect.Message
func (*CreateTopicRequest) Reset ¶
func (x *CreateTopicRequest) Reset()
func (*CreateTopicRequest) String ¶
func (x *CreateTopicRequest) String() string
type Cursor ¶
type Cursor struct { // The offset of a message within a topic partition. Must be greater than or // equal 0. Offset int64 `protobuf:"varint,1,opt,name=offset,proto3" json:"offset,omitempty"` // contains filtered or unexported fields }
A cursor that describes the position of a message within a topic partition.
func (*Cursor) Descriptor ¶
Deprecated: Use Cursor.ProtoReflect.Descriptor instead.
func (*Cursor) GetOffset ¶
func (*Cursor) ProtoMessage ¶
func (*Cursor) ProtoMessage()
func (*Cursor) ProtoReflect ¶
func (x *Cursor) ProtoReflect() protoreflect.Message
func (*Cursor) Reset ¶
func (x *Cursor) Reset()
func (*Cursor) String ¶
type CursorServiceClient ¶
type CursorServiceClient interface { // Establishes a stream with the server for managing committed cursors. StreamingCommitCursor(ctx context.Context, opts ...grpc.CallOption) (CursorService_StreamingCommitCursorClient, error) // Updates the committed cursor. CommitCursor(ctx context.Context, in *CommitCursorRequest, opts ...grpc.CallOption) (*CommitCursorResponse, error) // Returns all committed cursor information for a subscription. ListPartitionCursors(ctx context.Context, in *ListPartitionCursorsRequest, opts ...grpc.CallOption) (*ListPartitionCursorsResponse, error) }
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.
func NewCursorServiceClient ¶
func NewCursorServiceClient(cc grpc.ClientConnInterface) CursorServiceClient
type CursorServiceServer ¶
type CursorServiceServer interface { // Establishes a stream with the server for managing committed cursors. StreamingCommitCursor(CursorService_StreamingCommitCursorServer) error // Updates the committed cursor. CommitCursor(context.Context, *CommitCursorRequest) (*CommitCursorResponse, error) // Returns all committed cursor information for a subscription. ListPartitionCursors(context.Context, *ListPartitionCursorsRequest) (*ListPartitionCursorsResponse, error) }
CursorServiceServer is the server API for CursorService service.
type CursorService_StreamingCommitCursorClient ¶
type CursorService_StreamingCommitCursorClient interface { Send(*StreamingCommitCursorRequest) error Recv() (*StreamingCommitCursorResponse, error) grpc.ClientStream }
type CursorService_StreamingCommitCursorServer ¶
type CursorService_StreamingCommitCursorServer interface { Send(*StreamingCommitCursorResponse) error Recv() (*StreamingCommitCursorRequest, error) grpc.ServerStream }
type DeleteReservationRequest ¶
type DeleteReservationRequest struct { // Required. The name of the reservation to delete. // Structured like: // projects/{project_number}/locations/{location}/reservations/{reservation_id} Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // contains filtered or unexported fields }
Request for DeleteReservation.
func (*DeleteReservationRequest) Descriptor ¶
func (*DeleteReservationRequest) Descriptor() ([]byte, []int)
Deprecated: Use DeleteReservationRequest.ProtoReflect.Descriptor instead.
func (*DeleteReservationRequest) GetName ¶
func (x *DeleteReservationRequest) GetName() string
func (*DeleteReservationRequest) ProtoMessage ¶
func (*DeleteReservationRequest) ProtoMessage()
func (*DeleteReservationRequest) ProtoReflect ¶
func (x *DeleteReservationRequest) ProtoReflect() protoreflect.Message
func (*DeleteReservationRequest) Reset ¶
func (x *DeleteReservationRequest) Reset()
func (*DeleteReservationRequest) String ¶
func (x *DeleteReservationRequest) String() string
type DeleteSubscriptionRequest ¶
type DeleteSubscriptionRequest struct { // Required. The name of the subscription to delete. Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // contains filtered or unexported fields }
Request for DeleteSubscription.
func (*DeleteSubscriptionRequest) Descriptor ¶
func (*DeleteSubscriptionRequest) Descriptor() ([]byte, []int)
Deprecated: Use DeleteSubscriptionRequest.ProtoReflect.Descriptor instead.
func (*DeleteSubscriptionRequest) GetName ¶
func (x *DeleteSubscriptionRequest) GetName() string
func (*DeleteSubscriptionRequest) ProtoMessage ¶
func (*DeleteSubscriptionRequest) ProtoMessage()
func (*DeleteSubscriptionRequest) ProtoReflect ¶
func (x *DeleteSubscriptionRequest) ProtoReflect() protoreflect.Message
func (*DeleteSubscriptionRequest) Reset ¶
func (x *DeleteSubscriptionRequest) Reset()
func (*DeleteSubscriptionRequest) String ¶
func (x *DeleteSubscriptionRequest) String() string
type DeleteTopicRequest ¶
type DeleteTopicRequest struct { // Required. The name of the topic to delete. Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // contains filtered or unexported fields }
Request for DeleteTopic.
func (*DeleteTopicRequest) Descriptor ¶
func (*DeleteTopicRequest) Descriptor() ([]byte, []int)
Deprecated: Use DeleteTopicRequest.ProtoReflect.Descriptor instead.
func (*DeleteTopicRequest) GetName ¶
func (x *DeleteTopicRequest) GetName() string
func (*DeleteTopicRequest) ProtoMessage ¶
func (*DeleteTopicRequest) ProtoMessage()
func (*DeleteTopicRequest) ProtoReflect ¶
func (x *DeleteTopicRequest) ProtoReflect() protoreflect.Message
func (*DeleteTopicRequest) Reset ¶
func (x *DeleteTopicRequest) Reset()
func (*DeleteTopicRequest) String ¶
func (x *DeleteTopicRequest) String() string
type ExportConfig ¶
type ExportConfig struct { // The desired state of this export. Setting this to values other than // `ACTIVE` and `PAUSED` will result in an error. DesiredState ExportConfig_State `protobuf:"varint,1,opt,name=desired_state,json=desiredState,proto3,enum=google.cloud.pubsublite.v1.ExportConfig_State" json:"desired_state,omitempty"` // Output only. The current state of the export, which may be different to the // desired state due to errors. This field is output only. CurrentState ExportConfig_State `protobuf:"varint,6,opt,name=current_state,json=currentState,proto3,enum=google.cloud.pubsublite.v1.ExportConfig_State" json:"current_state,omitempty"` // Optional. The name of an optional Pub/Sub Lite topic to publish messages // that can not be exported to the destination. For example, the message can // not be published to the Pub/Sub service because it does not satisfy the // constraints documented at https://cloud.google.com/pubsub/docs/publisher. // // Structured like: // projects/{project_number}/locations/{location}/topics/{topic_id}. // Must be within the same project and location as the subscription. The topic // may be changed or removed. DeadLetterTopic string `protobuf:"bytes,5,opt,name=dead_letter_topic,json=deadLetterTopic,proto3" json:"dead_letter_topic,omitempty"` // The destination to export to. Required. // // Types that are assignable to Destination: // // *ExportConfig_PubsubConfig Destination isExportConfig_Destination `protobuf_oneof:"destination"` // contains filtered or unexported fields }
Configuration for a Pub/Sub Lite subscription that writes messages to a destination. User subscriber clients must not connect to this subscription.
func (*ExportConfig) Descriptor ¶
func (*ExportConfig) Descriptor() ([]byte, []int)
Deprecated: Use ExportConfig.ProtoReflect.Descriptor instead.
func (*ExportConfig) GetCurrentState ¶
func (x *ExportConfig) GetCurrentState() ExportConfig_State
func (*ExportConfig) GetDeadLetterTopic ¶
func (x *ExportConfig) GetDeadLetterTopic() string
func (*ExportConfig) GetDesiredState ¶
func (x *ExportConfig) GetDesiredState() ExportConfig_State
func (*ExportConfig) GetDestination ¶
func (m *ExportConfig) GetDestination() isExportConfig_Destination
func (*ExportConfig) GetPubsubConfig ¶
func (x *ExportConfig) GetPubsubConfig() *ExportConfig_PubSubConfig
func (*ExportConfig) ProtoMessage ¶
func (*ExportConfig) ProtoMessage()
func (*ExportConfig) ProtoReflect ¶
func (x *ExportConfig) ProtoReflect() protoreflect.Message
func (*ExportConfig) Reset ¶
func (x *ExportConfig) Reset()
func (*ExportConfig) String ¶
func (x *ExportConfig) String() string
type ExportConfig_PubSubConfig ¶
type ExportConfig_PubSubConfig struct { // The name of the Pub/Sub topic. // Structured like: projects/{project_number}/topics/{topic_id}. // The topic may be changed. Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"` // contains filtered or unexported fields }
Configuration for exporting to a Pub/Sub topic.
func (*ExportConfig_PubSubConfig) Descriptor ¶
func (*ExportConfig_PubSubConfig) Descriptor() ([]byte, []int)
Deprecated: Use ExportConfig_PubSubConfig.ProtoReflect.Descriptor instead.
func (*ExportConfig_PubSubConfig) GetTopic ¶
func (x *ExportConfig_PubSubConfig) GetTopic() string
func (*ExportConfig_PubSubConfig) ProtoMessage ¶
func (*ExportConfig_PubSubConfig) ProtoMessage()
func (*ExportConfig_PubSubConfig) ProtoReflect ¶
func (x *ExportConfig_PubSubConfig) ProtoReflect() protoreflect.Message
func (*ExportConfig_PubSubConfig) Reset ¶
func (x *ExportConfig_PubSubConfig) Reset()
func (*ExportConfig_PubSubConfig) String ¶
func (x *ExportConfig_PubSubConfig) String() string
type ExportConfig_PubsubConfig ¶
type ExportConfig_PubsubConfig struct { // Messages are automatically written from the Pub/Sub Lite topic associated // with this subscription to a Pub/Sub topic. PubsubConfig *ExportConfig_PubSubConfig `protobuf:"bytes,3,opt,name=pubsub_config,json=pubsubConfig,proto3,oneof"` }
type ExportConfig_State ¶
type ExportConfig_State int32
The desired export state.
const ( // Default value. This value is unused. ExportConfig_STATE_UNSPECIFIED ExportConfig_State = 0 // Messages are being exported. ExportConfig_ACTIVE ExportConfig_State = 1 // Exporting messages is suspended. ExportConfig_PAUSED ExportConfig_State = 2 // Messages cannot be exported due to permission denied errors. Output only. ExportConfig_PERMISSION_DENIED ExportConfig_State = 3 // Messages cannot be exported due to missing resources. Output only. ExportConfig_NOT_FOUND ExportConfig_State = 4 )
func (ExportConfig_State) Descriptor ¶
func (ExportConfig_State) Descriptor() protoreflect.EnumDescriptor
func (ExportConfig_State) Enum ¶
func (x ExportConfig_State) Enum() *ExportConfig_State
func (ExportConfig_State) EnumDescriptor ¶
func (ExportConfig_State) EnumDescriptor() ([]byte, []int)
Deprecated: Use ExportConfig_State.Descriptor instead.
func (ExportConfig_State) Number ¶
func (x ExportConfig_State) Number() protoreflect.EnumNumber
func (ExportConfig_State) String ¶
func (x ExportConfig_State) String() string
func (ExportConfig_State) Type ¶
func (ExportConfig_State) Type() protoreflect.EnumType
type FlowControlRequest ¶
type FlowControlRequest struct { // The number of message tokens to grant. Must be greater than or equal to 0. AllowedMessages int64 `protobuf:"varint,1,opt,name=allowed_messages,json=allowedMessages,proto3" json:"allowed_messages,omitempty"` // The number of byte tokens to grant. Must be greater than or equal to 0. AllowedBytes int64 `protobuf:"varint,2,opt,name=allowed_bytes,json=allowedBytes,proto3" json:"allowed_bytes,omitempty"` // contains filtered or unexported fields }
Request to grant tokens to the server, requesting delivery of messages when they become available.
func (*FlowControlRequest) Descriptor ¶
func (*FlowControlRequest) Descriptor() ([]byte, []int)
Deprecated: Use FlowControlRequest.ProtoReflect.Descriptor instead.
func (*FlowControlRequest) GetAllowedBytes ¶
func (x *FlowControlRequest) GetAllowedBytes() int64
func (*FlowControlRequest) GetAllowedMessages ¶
func (x *FlowControlRequest) GetAllowedMessages() int64
func (*FlowControlRequest) ProtoMessage ¶
func (*FlowControlRequest) ProtoMessage()
func (*FlowControlRequest) ProtoReflect ¶
func (x *FlowControlRequest) ProtoReflect() protoreflect.Message
func (*FlowControlRequest) Reset ¶
func (x *FlowControlRequest) Reset()
func (*FlowControlRequest) String ¶
func (x *FlowControlRequest) String() string
type GetReservationRequest ¶
type GetReservationRequest struct { // Required. The name of the reservation whose configuration to return. // Structured like: // projects/{project_number}/locations/{location}/reservations/{reservation_id} Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // contains filtered or unexported fields }
Request for GetReservation.
func (*GetReservationRequest) Descriptor ¶
func (*GetReservationRequest) Descriptor() ([]byte, []int)
Deprecated: Use GetReservationRequest.ProtoReflect.Descriptor instead.
func (*GetReservationRequest) GetName ¶
func (x *GetReservationRequest) GetName() string
func (*GetReservationRequest) ProtoMessage ¶
func (*GetReservationRequest) ProtoMessage()
func (*GetReservationRequest) ProtoReflect ¶
func (x *GetReservationRequest) ProtoReflect() protoreflect.Message
func (*GetReservationRequest) Reset ¶
func (x *GetReservationRequest) Reset()
func (*GetReservationRequest) String ¶
func (x *GetReservationRequest) String() string
type GetSubscriptionRequest ¶
type GetSubscriptionRequest struct { // Required. The name of the subscription whose configuration to return. Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // contains filtered or unexported fields }
Request for GetSubscription.
func (*GetSubscriptionRequest) Descriptor ¶
func (*GetSubscriptionRequest) Descriptor() ([]byte, []int)
Deprecated: Use GetSubscriptionRequest.ProtoReflect.Descriptor instead.
func (*GetSubscriptionRequest) GetName ¶
func (x *GetSubscriptionRequest) GetName() string
func (*GetSubscriptionRequest) ProtoMessage ¶
func (*GetSubscriptionRequest) ProtoMessage()
func (*GetSubscriptionRequest) ProtoReflect ¶
func (x *GetSubscriptionRequest) ProtoReflect() protoreflect.Message
func (*GetSubscriptionRequest) Reset ¶
func (x *GetSubscriptionRequest) Reset()
func (*GetSubscriptionRequest) String ¶
func (x *GetSubscriptionRequest) String() string
type GetTopicPartitionsRequest ¶
type GetTopicPartitionsRequest struct { // Required. The topic whose partition information to return. Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // contains filtered or unexported fields }
Request for GetTopicPartitions.
func (*GetTopicPartitionsRequest) Descriptor ¶
func (*GetTopicPartitionsRequest) Descriptor() ([]byte, []int)
Deprecated: Use GetTopicPartitionsRequest.ProtoReflect.Descriptor instead.
func (*GetTopicPartitionsRequest) GetName ¶
func (x *GetTopicPartitionsRequest) GetName() string
func (*GetTopicPartitionsRequest) ProtoMessage ¶
func (*GetTopicPartitionsRequest) ProtoMessage()
func (*GetTopicPartitionsRequest) ProtoReflect ¶
func (x *GetTopicPartitionsRequest) ProtoReflect() protoreflect.Message
func (*GetTopicPartitionsRequest) Reset ¶
func (x *GetTopicPartitionsRequest) Reset()
func (*GetTopicPartitionsRequest) String ¶
func (x *GetTopicPartitionsRequest) String() string
type GetTopicRequest ¶
type GetTopicRequest struct { // Required. The name of the topic whose configuration to return. Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // contains filtered or unexported fields }
Request for GetTopic.
func (*GetTopicRequest) Descriptor ¶
func (*GetTopicRequest) Descriptor() ([]byte, []int)
Deprecated: Use GetTopicRequest.ProtoReflect.Descriptor instead.
func (*GetTopicRequest) GetName ¶
func (x *GetTopicRequest) GetName() string
func (*GetTopicRequest) ProtoMessage ¶
func (*GetTopicRequest) ProtoMessage()
func (*GetTopicRequest) ProtoReflect ¶
func (x *GetTopicRequest) ProtoReflect() protoreflect.Message
func (*GetTopicRequest) Reset ¶
func (x *GetTopicRequest) Reset()
func (*GetTopicRequest) String ¶
func (x *GetTopicRequest) String() string
type InitialCommitCursorRequest ¶
type InitialCommitCursorRequest struct { // The subscription for which to manage committed cursors. Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"` // The partition for which to manage committed cursors. Partitions are zero // indexed, so `partition` must be in the range [0, topic.num_partitions). Partition int64 `protobuf:"varint,2,opt,name=partition,proto3" json:"partition,omitempty"` // contains filtered or unexported fields }
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.
func (*InitialCommitCursorRequest) Descriptor ¶
func (*InitialCommitCursorRequest) Descriptor() ([]byte, []int)
Deprecated: Use InitialCommitCursorRequest.ProtoReflect.Descriptor instead.
func (*InitialCommitCursorRequest) GetPartition ¶
func (x *InitialCommitCursorRequest) GetPartition() int64
func (*InitialCommitCursorRequest) GetSubscription ¶
func (x *InitialCommitCursorRequest) GetSubscription() string
func (*InitialCommitCursorRequest) ProtoMessage ¶
func (*InitialCommitCursorRequest) ProtoMessage()
func (*InitialCommitCursorRequest) ProtoReflect ¶
func (x *InitialCommitCursorRequest) ProtoReflect() protoreflect.Message
func (*InitialCommitCursorRequest) Reset ¶
func (x *InitialCommitCursorRequest) Reset()
func (*InitialCommitCursorRequest) String ¶
func (x *InitialCommitCursorRequest) String() string
type InitialCommitCursorResponse ¶
type InitialCommitCursorResponse struct {
// contains filtered or unexported fields
}
Response to an InitialCommitCursorRequest.
func (*InitialCommitCursorResponse) Descriptor ¶
func (*InitialCommitCursorResponse) Descriptor() ([]byte, []int)
Deprecated: Use InitialCommitCursorResponse.ProtoReflect.Descriptor instead.
func (*InitialCommitCursorResponse) ProtoMessage ¶
func (*InitialCommitCursorResponse) ProtoMessage()
func (*InitialCommitCursorResponse) ProtoReflect ¶
func (x *InitialCommitCursorResponse) ProtoReflect() protoreflect.Message
func (*InitialCommitCursorResponse) Reset ¶
func (x *InitialCommitCursorResponse) Reset()
func (*InitialCommitCursorResponse) String ¶
func (x *InitialCommitCursorResponse) String() string
type InitialPartitionAssignmentRequest ¶
type InitialPartitionAssignmentRequest struct { // The subscription name. Structured like: // projects/<project number>/locations/<zone name>/subscriptions/<subscription // id> Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"` // An opaque, unique client identifier. This field must be exactly 16 bytes // long and is interpreted as an unsigned 128 bit integer. Other size values // will be rejected and the stream will be failed with a non-retryable error. // // This field is large enough to fit a uuid from standard uuid algorithms like // uuid1 or uuid4, which should be used to generate this number. The same // identifier should be reused following disconnections with retryable stream // errors. ClientId []byte `protobuf:"bytes,2,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"` // contains filtered or unexported fields }
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.
func (*InitialPartitionAssignmentRequest) Descriptor ¶
func (*InitialPartitionAssignmentRequest) Descriptor() ([]byte, []int)
Deprecated: Use InitialPartitionAssignmentRequest.ProtoReflect.Descriptor instead.
func (*InitialPartitionAssignmentRequest) GetClientId ¶
func (x *InitialPartitionAssignmentRequest) GetClientId() []byte
func (*InitialPartitionAssignmentRequest) GetSubscription ¶
func (x *InitialPartitionAssignmentRequest) GetSubscription() string
func (*InitialPartitionAssignmentRequest) ProtoMessage ¶
func (*InitialPartitionAssignmentRequest) ProtoMessage()
func (*InitialPartitionAssignmentRequest) ProtoReflect ¶
func (x *InitialPartitionAssignmentRequest) ProtoReflect() protoreflect.Message
func (*InitialPartitionAssignmentRequest) Reset ¶
func (x *InitialPartitionAssignmentRequest) Reset()
func (*InitialPartitionAssignmentRequest) String ¶
func (x *InitialPartitionAssignmentRequest) String() string
type InitialPublishRequest ¶
type InitialPublishRequest struct { // The topic to which messages will be written. Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"` // The partition within the topic to which messages will be written. // Partitions are zero indexed, so `partition` must be in the range [0, // topic.num_partitions). Partition int64 `protobuf:"varint,2,opt,name=partition,proto3" json:"partition,omitempty"` // Unique identifier for a publisher client. If set, enables publish // idempotency within a publisher client session. // // The length of this field must be exactly 16 bytes long and should be // populated with a 128 bit uuid, generated by standard uuid algorithms like // uuid1 or uuid4. The same identifier should be reused following // disconnections with retryable stream errors. ClientId []byte `protobuf:"bytes,3,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"` // contains filtered or unexported fields }
The first request that must be sent on a newly-opened stream.
func (*InitialPublishRequest) Descriptor ¶
func (*InitialPublishRequest) Descriptor() ([]byte, []int)
Deprecated: Use InitialPublishRequest.ProtoReflect.Descriptor instead.
func (*InitialPublishRequest) GetClientId ¶
func (x *InitialPublishRequest) GetClientId() []byte
func (*InitialPublishRequest) GetPartition ¶
func (x *InitialPublishRequest) GetPartition() int64
func (*InitialPublishRequest) GetTopic ¶
func (x *InitialPublishRequest) GetTopic() string
func (*InitialPublishRequest) ProtoMessage ¶
func (*InitialPublishRequest) ProtoMessage()
func (*InitialPublishRequest) ProtoReflect ¶
func (x *InitialPublishRequest) ProtoReflect() protoreflect.Message
func (*InitialPublishRequest) Reset ¶
func (x *InitialPublishRequest) Reset()
func (*InitialPublishRequest) String ¶
func (x *InitialPublishRequest) String() string
type InitialPublishResponse ¶
type InitialPublishResponse struct {
// contains filtered or unexported fields
}
Response to an InitialPublishRequest.
func (*InitialPublishResponse) Descriptor ¶
func (*InitialPublishResponse) Descriptor() ([]byte, []int)
Deprecated: Use InitialPublishResponse.ProtoReflect.Descriptor instead.
func (*InitialPublishResponse) ProtoMessage ¶
func (*InitialPublishResponse) ProtoMessage()
func (*InitialPublishResponse) ProtoReflect ¶
func (x *InitialPublishResponse) ProtoReflect() protoreflect.Message
func (*InitialPublishResponse) Reset ¶
func (x *InitialPublishResponse) Reset()
func (*InitialPublishResponse) String ¶
func (x *InitialPublishResponse) String() string
type InitialSubscribeRequest ¶
type InitialSubscribeRequest struct { // The subscription from which to receive messages. Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"` // The partition from which to receive messages. Partitions are zero indexed, // so `partition` must be in the range [0, topic.num_partitions). Partition int64 `protobuf:"varint,2,opt,name=partition,proto3" json:"partition,omitempty"` // Optional. Initial target location within the message backlog. If not set, // messages will be delivered from the commit cursor for the given // subscription and partition. InitialLocation *SeekRequest `protobuf:"bytes,4,opt,name=initial_location,json=initialLocation,proto3" json:"initial_location,omitempty"` // contains filtered or unexported fields }
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.
func (*InitialSubscribeRequest) Descriptor ¶
func (*InitialSubscribeRequest) Descriptor() ([]byte, []int)
Deprecated: Use InitialSubscribeRequest.ProtoReflect.Descriptor instead.
func (*InitialSubscribeRequest) GetInitialLocation ¶
func (x *InitialSubscribeRequest) GetInitialLocation() *SeekRequest
func (*InitialSubscribeRequest) GetPartition ¶
func (x *InitialSubscribeRequest) GetPartition() int64
func (*InitialSubscribeRequest) GetSubscription ¶
func (x *InitialSubscribeRequest) GetSubscription() string
func (*InitialSubscribeRequest) ProtoMessage ¶
func (*InitialSubscribeRequest) ProtoMessage()
func (*InitialSubscribeRequest) ProtoReflect ¶
func (x *InitialSubscribeRequest) ProtoReflect() protoreflect.Message
func (*InitialSubscribeRequest) Reset ¶
func (x *InitialSubscribeRequest) Reset()
func (*InitialSubscribeRequest) String ¶
func (x *InitialSubscribeRequest) String() string
type InitialSubscribeResponse ¶
type InitialSubscribeResponse struct { // The cursor from which the subscriber will start receiving messages once // flow control tokens become available. Cursor *Cursor `protobuf:"bytes,1,opt,name=cursor,proto3" json:"cursor,omitempty"` // contains filtered or unexported fields }
Response to an InitialSubscribeRequest.
func (*InitialSubscribeResponse) Descriptor ¶
func (*InitialSubscribeResponse) Descriptor() ([]byte, []int)
Deprecated: Use InitialSubscribeResponse.ProtoReflect.Descriptor instead.
func (*InitialSubscribeResponse) GetCursor ¶
func (x *InitialSubscribeResponse) GetCursor() *Cursor
func (*InitialSubscribeResponse) ProtoMessage ¶
func (*InitialSubscribeResponse) ProtoMessage()
func (*InitialSubscribeResponse) ProtoReflect ¶
func (x *InitialSubscribeResponse) ProtoReflect() protoreflect.Message
func (*InitialSubscribeResponse) Reset ¶
func (x *InitialSubscribeResponse) Reset()
func (*InitialSubscribeResponse) String ¶
func (x *InitialSubscribeResponse) String() string
type ListPartitionCursorsRequest ¶
type ListPartitionCursorsRequest struct { // Required. The subscription for which to retrieve cursors. // Structured like // `projects/{project_number}/locations/{location}/subscriptions/{subscription_id}`. Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"` // The maximum number of cursors to return. The service may return fewer than // this value. // If unset or zero, all cursors for the parent will be returned. PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"` // A page token, received from a previous `ListPartitionCursors` call. // Provide this to retrieve the subsequent page. // // When paginating, all other parameters provided to `ListPartitionCursors` // must match the call that provided the page token. PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"` // contains filtered or unexported fields }
Request for ListPartitionCursors.
func (*ListPartitionCursorsRequest) Descriptor ¶
func (*ListPartitionCursorsRequest) Descriptor() ([]byte, []int)
Deprecated: Use ListPartitionCursorsRequest.ProtoReflect.Descriptor instead.
func (*ListPartitionCursorsRequest) GetPageSize ¶
func (x *ListPartitionCursorsRequest) GetPageSize() int32
func (*ListPartitionCursorsRequest) GetPageToken ¶
func (x *ListPartitionCursorsRequest) GetPageToken() string
func (*ListPartitionCursorsRequest) GetParent ¶
func (x *ListPartitionCursorsRequest) GetParent() string
func (*ListPartitionCursorsRequest) ProtoMessage ¶
func (*ListPartitionCursorsRequest) ProtoMessage()
func (*ListPartitionCursorsRequest) ProtoReflect ¶
func (x *ListPartitionCursorsRequest) ProtoReflect() protoreflect.Message
func (*ListPartitionCursorsRequest) Reset ¶
func (x *ListPartitionCursorsRequest) Reset()
func (*ListPartitionCursorsRequest) String ¶
func (x *ListPartitionCursorsRequest) String() string
type ListPartitionCursorsResponse ¶
type ListPartitionCursorsResponse struct { // The partition cursors from this request. PartitionCursors []*PartitionCursor `protobuf:"bytes,1,rep,name=partition_cursors,json=partitionCursors,proto3" json:"partition_cursors,omitempty"` // A token, which can be sent as `page_token` to retrieve the next page. // If this field is omitted, there are no subsequent pages. NextPageToken string `protobuf:"bytes,2,opt,name=next_page_token,json=nextPageToken,proto3" json:"next_page_token,omitempty"` // contains filtered or unexported fields }
Response for ListPartitionCursors
func (*ListPartitionCursorsResponse) Descriptor ¶
func (*ListPartitionCursorsResponse) Descriptor() ([]byte, []int)
Deprecated: Use ListPartitionCursorsResponse.ProtoReflect.Descriptor instead.
func (*ListPartitionCursorsResponse) GetNextPageToken ¶
func (x *ListPartitionCursorsResponse) GetNextPageToken() string
func (*ListPartitionCursorsResponse) GetPartitionCursors ¶
func (x *ListPartitionCursorsResponse) GetPartitionCursors() []*PartitionCursor
func (*ListPartitionCursorsResponse) ProtoMessage ¶
func (*ListPartitionCursorsResponse) ProtoMessage()
func (*ListPartitionCursorsResponse) ProtoReflect ¶
func (x *ListPartitionCursorsResponse) ProtoReflect() protoreflect.Message
func (*ListPartitionCursorsResponse) Reset ¶
func (x *ListPartitionCursorsResponse) Reset()
func (*ListPartitionCursorsResponse) String ¶
func (x *ListPartitionCursorsResponse) String() string
type ListReservationTopicsRequest ¶
type ListReservationTopicsRequest struct { // Required. The name of the reservation whose topics to list. // Structured like: // projects/{project_number}/locations/{location}/reservations/{reservation_id} Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // The maximum number of topics to return. The service may return fewer // than this value. // If unset or zero, all topics for the given reservation will be returned. PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"` // A page token, received from a previous `ListReservationTopics` call. // Provide this to retrieve the subsequent page. // // When paginating, all other parameters provided to `ListReservationTopics` // must match the call that provided the page token. PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"` // contains filtered or unexported fields }
Request for ListReservationTopics.
func (*ListReservationTopicsRequest) Descriptor ¶
func (*ListReservationTopicsRequest) Descriptor() ([]byte, []int)
Deprecated: Use ListReservationTopicsRequest.ProtoReflect.Descriptor instead.
func (*ListReservationTopicsRequest) GetName ¶
func (x *ListReservationTopicsRequest) GetName() string
func (*ListReservationTopicsRequest) GetPageSize ¶
func (x *ListReservationTopicsRequest) GetPageSize() int32
func (*ListReservationTopicsRequest) GetPageToken ¶
func (x *ListReservationTopicsRequest) GetPageToken() string
func (*ListReservationTopicsRequest) ProtoMessage ¶
func (*ListReservationTopicsRequest) ProtoMessage()
func (*ListReservationTopicsRequest) ProtoReflect ¶
func (x *ListReservationTopicsRequest) ProtoReflect() protoreflect.Message
func (*ListReservationTopicsRequest) Reset ¶
func (x *ListReservationTopicsRequest) Reset()
func (*ListReservationTopicsRequest) String ¶
func (x *ListReservationTopicsRequest) String() string
type ListReservationTopicsResponse ¶
type ListReservationTopicsResponse struct { // The names of topics attached to the reservation. The order of the // topics is unspecified. Topics []string `protobuf:"bytes,1,rep,name=topics,proto3" json:"topics,omitempty"` // A token that can be sent as `page_token` to retrieve the next page of // results. If this field is omitted, there are no more results. NextPageToken string `protobuf:"bytes,2,opt,name=next_page_token,json=nextPageToken,proto3" json:"next_page_token,omitempty"` // contains filtered or unexported fields }
Response for ListReservationTopics.
func (*ListReservationTopicsResponse) Descriptor ¶
func (*ListReservationTopicsResponse) Descriptor() ([]byte, []int)
Deprecated: Use ListReservationTopicsResponse.ProtoReflect.Descriptor instead.
func (*ListReservationTopicsResponse) GetNextPageToken ¶
func (x *ListReservationTopicsResponse) GetNextPageToken() string
func (*ListReservationTopicsResponse) GetTopics ¶
func (x *ListReservationTopicsResponse) GetTopics() []string
func (*ListReservationTopicsResponse) ProtoMessage ¶
func (*ListReservationTopicsResponse) ProtoMessage()
func (*ListReservationTopicsResponse) ProtoReflect ¶
func (x *ListReservationTopicsResponse) ProtoReflect() protoreflect.Message
func (*ListReservationTopicsResponse) Reset ¶
func (x *ListReservationTopicsResponse) Reset()
func (*ListReservationTopicsResponse) String ¶
func (x *ListReservationTopicsResponse) String() string
type ListReservationsRequest ¶
type ListReservationsRequest struct { // Required. The parent whose reservations are to be listed. // Structured like `projects/{project_number}/locations/{location}`. Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"` // The maximum number of reservations to return. The service may return fewer // than this value. If unset or zero, all reservations for the parent will be // returned. PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"` // A page token, received from a previous `ListReservations` call. // Provide this to retrieve the subsequent page. // // When paginating, all other parameters provided to `ListReservations` must // match the call that provided the page token. PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"` // contains filtered or unexported fields }
Request for ListReservations.
func (*ListReservationsRequest) Descriptor ¶
func (*ListReservationsRequest) Descriptor() ([]byte, []int)
Deprecated: Use ListReservationsRequest.ProtoReflect.Descriptor instead.
func (*ListReservationsRequest) GetPageSize ¶
func (x *ListReservationsRequest) GetPageSize() int32
func (*ListReservationsRequest) GetPageToken ¶
func (x *ListReservationsRequest) GetPageToken() string
func (*ListReservationsRequest) GetParent ¶
func (x *ListReservationsRequest) GetParent() string
func (*ListReservationsRequest) ProtoMessage ¶
func (*ListReservationsRequest) ProtoMessage()
func (*ListReservationsRequest) ProtoReflect ¶
func (x *ListReservationsRequest) ProtoReflect() protoreflect.Message
func (*ListReservationsRequest) Reset ¶
func (x *ListReservationsRequest) Reset()
func (*ListReservationsRequest) String ¶
func (x *ListReservationsRequest) String() string
type ListReservationsResponse ¶
type ListReservationsResponse struct { // The list of reservation in the requested parent. The order of the // reservations is unspecified. Reservations []*Reservation `protobuf:"bytes,1,rep,name=reservations,proto3" json:"reservations,omitempty"` // A token that can be sent as `page_token` to retrieve the next page of // results. If this field is omitted, there are no more results. NextPageToken string `protobuf:"bytes,2,opt,name=next_page_token,json=nextPageToken,proto3" json:"next_page_token,omitempty"` // contains filtered or unexported fields }
Response for ListReservations.
func (*ListReservationsResponse) Descriptor ¶
func (*ListReservationsResponse) Descriptor() ([]byte, []int)
Deprecated: Use ListReservationsResponse.ProtoReflect.Descriptor instead.
func (*ListReservationsResponse) GetNextPageToken ¶
func (x *ListReservationsResponse) GetNextPageToken() string
func (*ListReservationsResponse) GetReservations ¶
func (x *ListReservationsResponse) GetReservations() []*Reservation
func (*ListReservationsResponse) ProtoMessage ¶
func (*ListReservationsResponse) ProtoMessage()
func (*ListReservationsResponse) ProtoReflect ¶
func (x *ListReservationsResponse) ProtoReflect() protoreflect.Message
func (*ListReservationsResponse) Reset ¶
func (x *ListReservationsResponse) Reset()
func (*ListReservationsResponse) String ¶
func (x *ListReservationsResponse) String() string
type ListSubscriptionsRequest ¶
type ListSubscriptionsRequest struct { // Required. The parent whose subscriptions are to be listed. // Structured like `projects/{project_number}/locations/{location}`. Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"` // The maximum number of subscriptions to return. The service may return fewer // than this value. // If unset or zero, all subscriptions for the parent will be returned. PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"` // A page token, received from a previous `ListSubscriptions` call. // Provide this to retrieve the subsequent page. // // When paginating, all other parameters provided to `ListSubscriptions` must // match the call that provided the page token. PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"` // contains filtered or unexported fields }
Request for ListSubscriptions.
func (*ListSubscriptionsRequest) Descriptor ¶
func (*ListSubscriptionsRequest) Descriptor() ([]byte, []int)
Deprecated: Use ListSubscriptionsRequest.ProtoReflect.Descriptor instead.
func (*ListSubscriptionsRequest) GetPageSize ¶
func (x *ListSubscriptionsRequest) GetPageSize() int32
func (*ListSubscriptionsRequest) GetPageToken ¶
func (x *ListSubscriptionsRequest) GetPageToken() string
func (*ListSubscriptionsRequest) GetParent ¶
func (x *ListSubscriptionsRequest) GetParent() string
func (*ListSubscriptionsRequest) ProtoMessage ¶
func (*ListSubscriptionsRequest) ProtoMessage()
func (*ListSubscriptionsRequest) ProtoReflect ¶
func (x *ListSubscriptionsRequest) ProtoReflect() protoreflect.Message
func (*ListSubscriptionsRequest) Reset ¶
func (x *ListSubscriptionsRequest) Reset()
func (*ListSubscriptionsRequest) String ¶
func (x *ListSubscriptionsRequest) String() string
type ListSubscriptionsResponse ¶
type ListSubscriptionsResponse struct { // The list of subscriptions in the requested parent. The order of the // subscriptions is unspecified. Subscriptions []*Subscription `protobuf:"bytes,1,rep,name=subscriptions,proto3" json:"subscriptions,omitempty"` // A token that can be sent as `page_token` to retrieve the next page of // results. If this field is omitted, there are no more results. NextPageToken string `protobuf:"bytes,2,opt,name=next_page_token,json=nextPageToken,proto3" json:"next_page_token,omitempty"` // contains filtered or unexported fields }
Response for ListSubscriptions.
func (*ListSubscriptionsResponse) Descriptor ¶
func (*ListSubscriptionsResponse) Descriptor() ([]byte, []int)
Deprecated: Use ListSubscriptionsResponse.ProtoReflect.Descriptor instead.
func (*ListSubscriptionsResponse) GetNextPageToken ¶
func (x *ListSubscriptionsResponse) GetNextPageToken() string
func (*ListSubscriptionsResponse) GetSubscriptions ¶
func (x *ListSubscriptionsResponse) GetSubscriptions() []*Subscription
func (*ListSubscriptionsResponse) ProtoMessage ¶
func (*ListSubscriptionsResponse) ProtoMessage()
func (*ListSubscriptionsResponse) ProtoReflect ¶
func (x *ListSubscriptionsResponse) ProtoReflect() protoreflect.Message
func (*ListSubscriptionsResponse) Reset ¶
func (x *ListSubscriptionsResponse) Reset()
func (*ListSubscriptionsResponse) String ¶
func (x *ListSubscriptionsResponse) String() string
type ListTopicSubscriptionsRequest ¶
type ListTopicSubscriptionsRequest struct { // Required. The name of the topic whose subscriptions to list. Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // The maximum number of subscriptions to return. The service may return fewer // than this value. // If unset or zero, all subscriptions for the given topic will be returned. PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"` // A page token, received from a previous `ListTopicSubscriptions` call. // Provide this to retrieve the subsequent page. // // When paginating, all other parameters provided to `ListTopicSubscriptions` // must match the call that provided the page token. PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"` // contains filtered or unexported fields }
Request for ListTopicSubscriptions.
func (*ListTopicSubscriptionsRequest) Descriptor ¶
func (*ListTopicSubscriptionsRequest) Descriptor() ([]byte, []int)
Deprecated: Use ListTopicSubscriptionsRequest.ProtoReflect.Descriptor instead.
func (*ListTopicSubscriptionsRequest) GetName ¶
func (x *ListTopicSubscriptionsRequest) GetName() string
func (*ListTopicSubscriptionsRequest) GetPageSize ¶
func (x *ListTopicSubscriptionsRequest) GetPageSize() int32
func (*ListTopicSubscriptionsRequest) GetPageToken ¶
func (x *ListTopicSubscriptionsRequest) GetPageToken() string
func (*ListTopicSubscriptionsRequest) ProtoMessage ¶
func (*ListTopicSubscriptionsRequest) ProtoMessage()
func (*ListTopicSubscriptionsRequest) ProtoReflect ¶
func (x *ListTopicSubscriptionsRequest) ProtoReflect() protoreflect.Message
func (*ListTopicSubscriptionsRequest) Reset ¶
func (x *ListTopicSubscriptionsRequest) Reset()
func (*ListTopicSubscriptionsRequest) String ¶
func (x *ListTopicSubscriptionsRequest) String() string
type ListTopicSubscriptionsResponse ¶
type ListTopicSubscriptionsResponse struct { // The names of subscriptions attached to the topic. The order of the // subscriptions is unspecified. Subscriptions []string `protobuf:"bytes,1,rep,name=subscriptions,proto3" json:"subscriptions,omitempty"` // A token that can be sent as `page_token` to retrieve the next page of // results. If this field is omitted, there are no more results. NextPageToken string `protobuf:"bytes,2,opt,name=next_page_token,json=nextPageToken,proto3" json:"next_page_token,omitempty"` // contains filtered or unexported fields }
Response for ListTopicSubscriptions.
func (*ListTopicSubscriptionsResponse) Descriptor ¶
func (*ListTopicSubscriptionsResponse) Descriptor() ([]byte, []int)
Deprecated: Use ListTopicSubscriptionsResponse.ProtoReflect.Descriptor instead.
func (*ListTopicSubscriptionsResponse) GetNextPageToken ¶
func (x *ListTopicSubscriptionsResponse) GetNextPageToken() string
func (*ListTopicSubscriptionsResponse) GetSubscriptions ¶
func (x *ListTopicSubscriptionsResponse) GetSubscriptions() []string
func (*ListTopicSubscriptionsResponse) ProtoMessage ¶
func (*ListTopicSubscriptionsResponse) ProtoMessage()
func (*ListTopicSubscriptionsResponse) ProtoReflect ¶
func (x *ListTopicSubscriptionsResponse) ProtoReflect() protoreflect.Message
func (*ListTopicSubscriptionsResponse) Reset ¶
func (x *ListTopicSubscriptionsResponse) Reset()
func (*ListTopicSubscriptionsResponse) String ¶
func (x *ListTopicSubscriptionsResponse) String() string
type ListTopicsRequest ¶
type ListTopicsRequest struct { // Required. The parent whose topics are to be listed. // Structured like `projects/{project_number}/locations/{location}`. Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"` // The maximum number of topics to return. The service may return fewer than // this value. // If unset or zero, all topics for the parent will be returned. PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"` // A page token, received from a previous `ListTopics` call. // Provide this to retrieve the subsequent page. // // When paginating, all other parameters provided to `ListTopics` must match // the call that provided the page token. PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"` // contains filtered or unexported fields }
Request for ListTopics.
func (*ListTopicsRequest) Descriptor ¶
func (*ListTopicsRequest) Descriptor() ([]byte, []int)
Deprecated: Use ListTopicsRequest.ProtoReflect.Descriptor instead.
func (*ListTopicsRequest) GetPageSize ¶
func (x *ListTopicsRequest) GetPageSize() int32
func (*ListTopicsRequest) GetPageToken ¶
func (x *ListTopicsRequest) GetPageToken() string
func (*ListTopicsRequest) GetParent ¶
func (x *ListTopicsRequest) GetParent() string
func (*ListTopicsRequest) ProtoMessage ¶
func (*ListTopicsRequest) ProtoMessage()
func (*ListTopicsRequest) ProtoReflect ¶
func (x *ListTopicsRequest) ProtoReflect() protoreflect.Message
func (*ListTopicsRequest) Reset ¶
func (x *ListTopicsRequest) Reset()
func (*ListTopicsRequest) String ¶
func (x *ListTopicsRequest) String() string
type ListTopicsResponse ¶
type ListTopicsResponse struct { // The list of topic in the requested parent. The order of the topics is // unspecified. Topics []*Topic `protobuf:"bytes,1,rep,name=topics,proto3" json:"topics,omitempty"` // A token that can be sent as `page_token` to retrieve the next page of // results. If this field is omitted, there are no more results. NextPageToken string `protobuf:"bytes,2,opt,name=next_page_token,json=nextPageToken,proto3" json:"next_page_token,omitempty"` // contains filtered or unexported fields }
Response for ListTopics.
func (*ListTopicsResponse) Descriptor ¶
func (*ListTopicsResponse) Descriptor() ([]byte, []int)
Deprecated: Use ListTopicsResponse.ProtoReflect.Descriptor instead.
func (*ListTopicsResponse) GetNextPageToken ¶
func (x *ListTopicsResponse) GetNextPageToken() string
func (*ListTopicsResponse) GetTopics ¶
func (x *ListTopicsResponse) GetTopics() []*Topic
func (*ListTopicsResponse) ProtoMessage ¶
func (*ListTopicsResponse) ProtoMessage()
func (*ListTopicsResponse) ProtoReflect ¶
func (x *ListTopicsResponse) ProtoReflect() protoreflect.Message
func (*ListTopicsResponse) Reset ¶
func (x *ListTopicsResponse) Reset()
func (*ListTopicsResponse) String ¶
func (x *ListTopicsResponse) String() string
type MessagePublishRequest ¶
type MessagePublishRequest struct { // The messages to publish. Messages []*PubSubMessage `protobuf:"bytes,1,rep,name=messages,proto3" json:"messages,omitempty"` // The sequence number corresponding to the first message in `messages`. // Messages within a batch are ordered and the sequence numbers of all // subsequent messages in the batch are assumed to be incremental. // // Sequence numbers are assigned at the message level and the first message // published in a publisher client session must have a sequence number of 0. // All messages must have contiguous sequence numbers, which uniquely identify // the messages accepted by the publisher client. Since messages are ordered, // the client only needs to specify the sequence number of the first message // in a published batch. The server deduplicates messages with the same // sequence number from the same publisher `client_id`. FirstSequenceNumber int64 `protobuf:"varint,2,opt,name=first_sequence_number,json=firstSequenceNumber,proto3" json:"first_sequence_number,omitempty"` // contains filtered or unexported fields }
Request to publish messages to the topic.
func (*MessagePublishRequest) Descriptor ¶
func (*MessagePublishRequest) Descriptor() ([]byte, []int)
Deprecated: Use MessagePublishRequest.ProtoReflect.Descriptor instead.
func (*MessagePublishRequest) GetFirstSequenceNumber ¶
func (x *MessagePublishRequest) GetFirstSequenceNumber() int64
func (*MessagePublishRequest) GetMessages ¶
func (x *MessagePublishRequest) GetMessages() []*PubSubMessage
func (*MessagePublishRequest) ProtoMessage ¶
func (*MessagePublishRequest) ProtoMessage()
func (*MessagePublishRequest) ProtoReflect ¶
func (x *MessagePublishRequest) ProtoReflect() protoreflect.Message
func (*MessagePublishRequest) Reset ¶
func (x *MessagePublishRequest) Reset()
func (*MessagePublishRequest) String ¶
func (x *MessagePublishRequest) String() string
type MessagePublishResponse ¶
type MessagePublishResponse struct { // The cursor of the first published message in the batch. The cursors for any // remaining messages in the batch are guaranteed to be sequential. StartCursor *Cursor `protobuf:"bytes,1,opt,name=start_cursor,json=startCursor,proto3" json:"start_cursor,omitempty"` // Cursors for messages published in the batch. There will exist multiple // ranges when cursors are not contiguous within the batch. // // The cursor ranges may not account for all messages in the batch when // publish idempotency is enabled. A missing range indicates that cursors // could not be determined for messages within the range, as they were // deduplicated and the necessary data was not available at publish time. // These messages will have offsets when received by a subscriber. CursorRanges []*MessagePublishResponse_CursorRange `protobuf:"bytes,2,rep,name=cursor_ranges,json=cursorRanges,proto3" json:"cursor_ranges,omitempty"` // contains filtered or unexported fields }
Response to a MessagePublishRequest.
func (*MessagePublishResponse) Descriptor ¶
func (*MessagePublishResponse) Descriptor() ([]byte, []int)
Deprecated: Use MessagePublishResponse.ProtoReflect.Descriptor instead.
func (*MessagePublishResponse) GetCursorRanges ¶
func (x *MessagePublishResponse) GetCursorRanges() []*MessagePublishResponse_CursorRange
func (*MessagePublishResponse) GetStartCursor ¶
func (x *MessagePublishResponse) GetStartCursor() *Cursor
func (*MessagePublishResponse) ProtoMessage ¶
func (*MessagePublishResponse) ProtoMessage()
func (*MessagePublishResponse) ProtoReflect ¶
func (x *MessagePublishResponse) ProtoReflect() protoreflect.Message
func (*MessagePublishResponse) Reset ¶
func (x *MessagePublishResponse) Reset()
func (*MessagePublishResponse) String ¶
func (x *MessagePublishResponse) String() string
type MessagePublishResponse_CursorRange ¶
type MessagePublishResponse_CursorRange struct { // The cursor of the message at the start index. The cursors for remaining // messages up to the end index (exclusive) are sequential. StartCursor *Cursor `protobuf:"bytes,1,opt,name=start_cursor,json=startCursor,proto3" json:"start_cursor,omitempty"` // Index of the message in the published batch that corresponds to the // start cursor. Inclusive. StartIndex int32 `protobuf:"varint,2,opt,name=start_index,json=startIndex,proto3" json:"start_index,omitempty"` // Index of the last message in this range. Exclusive. EndIndex int32 `protobuf:"varint,3,opt,name=end_index,json=endIndex,proto3" json:"end_index,omitempty"` // contains filtered or unexported fields }
Cursors for a subrange of published messages.
func (*MessagePublishResponse_CursorRange) Descriptor ¶
func (*MessagePublishResponse_CursorRange) Descriptor() ([]byte, []int)
Deprecated: Use MessagePublishResponse_CursorRange.ProtoReflect.Descriptor instead.
func (*MessagePublishResponse_CursorRange) GetEndIndex ¶
func (x *MessagePublishResponse_CursorRange) GetEndIndex() int32
func (*MessagePublishResponse_CursorRange) GetStartCursor ¶
func (x *MessagePublishResponse_CursorRange) GetStartCursor() *Cursor
func (*MessagePublishResponse_CursorRange) GetStartIndex ¶
func (x *MessagePublishResponse_CursorRange) GetStartIndex() int32
func (*MessagePublishResponse_CursorRange) ProtoMessage ¶
func (*MessagePublishResponse_CursorRange) ProtoMessage()
func (*MessagePublishResponse_CursorRange) ProtoReflect ¶
func (x *MessagePublishResponse_CursorRange) ProtoReflect() protoreflect.Message
func (*MessagePublishResponse_CursorRange) Reset ¶
func (x *MessagePublishResponse_CursorRange) Reset()
func (*MessagePublishResponse_CursorRange) String ¶
func (x *MessagePublishResponse_CursorRange) String() string
type MessageResponse ¶
type MessageResponse struct { // Messages from the topic partition. Messages []*SequencedMessage `protobuf:"bytes,1,rep,name=messages,proto3" json:"messages,omitempty"` // contains filtered or unexported fields }
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.
func (*MessageResponse) Descriptor ¶
func (*MessageResponse) Descriptor() ([]byte, []int)
Deprecated: Use MessageResponse.ProtoReflect.Descriptor instead.
func (*MessageResponse) GetMessages ¶
func (x *MessageResponse) GetMessages() []*SequencedMessage
func (*MessageResponse) ProtoMessage ¶
func (*MessageResponse) ProtoMessage()
func (*MessageResponse) ProtoReflect ¶
func (x *MessageResponse) ProtoReflect() protoreflect.Message
func (*MessageResponse) Reset ¶
func (x *MessageResponse) Reset()
func (*MessageResponse) String ¶
func (x *MessageResponse) String() string
type OperationMetadata ¶
type OperationMetadata struct { // The time the operation was created. CreateTime *timestamppb.Timestamp `protobuf:"bytes,1,opt,name=create_time,json=createTime,proto3" json:"create_time,omitempty"` // The time the operation finished running. Not set if the operation has not // completed. EndTime *timestamppb.Timestamp `protobuf:"bytes,2,opt,name=end_time,json=endTime,proto3" json:"end_time,omitempty"` // Resource path for the target of the operation. For example, targets of // seeks are subscription resources, structured like: // projects/{project_number}/locations/{location}/subscriptions/{subscription_id} Target string `protobuf:"bytes,3,opt,name=target,proto3" json:"target,omitempty"` // Name of the verb executed by the operation. Verb string `protobuf:"bytes,4,opt,name=verb,proto3" json:"verb,omitempty"` // contains filtered or unexported fields }
Metadata for long running operations.
func (*OperationMetadata) Descriptor ¶
func (*OperationMetadata) Descriptor() ([]byte, []int)
Deprecated: Use OperationMetadata.ProtoReflect.Descriptor instead.
func (*OperationMetadata) GetCreateTime ¶
func (x *OperationMetadata) GetCreateTime() *timestamppb.Timestamp
func (*OperationMetadata) GetEndTime ¶
func (x *OperationMetadata) GetEndTime() *timestamppb.Timestamp
func (*OperationMetadata) GetTarget ¶
func (x *OperationMetadata) GetTarget() string
func (*OperationMetadata) GetVerb ¶
func (x *OperationMetadata) GetVerb() string
func (*OperationMetadata) ProtoMessage ¶
func (*OperationMetadata) ProtoMessage()
func (*OperationMetadata) ProtoReflect ¶
func (x *OperationMetadata) ProtoReflect() protoreflect.Message
func (*OperationMetadata) Reset ¶
func (x *OperationMetadata) Reset()
func (*OperationMetadata) String ¶
func (x *OperationMetadata) String() string
type PartitionAssignment ¶
type PartitionAssignment struct { // The list of partition numbers this subscriber is assigned to. Partitions []int64 `protobuf:"varint,1,rep,packed,name=partitions,proto3" json:"partitions,omitempty"` // contains filtered or unexported fields }
PartitionAssignments should not race with acknowledgements. There should be exactly one unacknowledged PartitionAssignment at a time. If not, the client must break the stream.
func (*PartitionAssignment) Descriptor ¶
func (*PartitionAssignment) Descriptor() ([]byte, []int)
Deprecated: Use PartitionAssignment.ProtoReflect.Descriptor instead.
func (*PartitionAssignment) GetPartitions ¶
func (x *PartitionAssignment) GetPartitions() []int64
func (*PartitionAssignment) ProtoMessage ¶
func (*PartitionAssignment) ProtoMessage()
func (*PartitionAssignment) ProtoReflect ¶
func (x *PartitionAssignment) ProtoReflect() protoreflect.Message
func (*PartitionAssignment) Reset ¶
func (x *PartitionAssignment) Reset()
func (*PartitionAssignment) String ¶
func (x *PartitionAssignment) String() string
type PartitionAssignmentAck ¶
type PartitionAssignmentAck struct {
// contains filtered or unexported fields
}
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.
func (*PartitionAssignmentAck) Descriptor ¶
func (*PartitionAssignmentAck) Descriptor() ([]byte, []int)
Deprecated: Use PartitionAssignmentAck.ProtoReflect.Descriptor instead.
func (*PartitionAssignmentAck) ProtoMessage ¶
func (*PartitionAssignmentAck) ProtoMessage()
func (*PartitionAssignmentAck) ProtoReflect ¶
func (x *PartitionAssignmentAck) ProtoReflect() protoreflect.Message
func (*PartitionAssignmentAck) Reset ¶
func (x *PartitionAssignmentAck) Reset()
func (*PartitionAssignmentAck) String ¶
func (x *PartitionAssignmentAck) String() string
type PartitionAssignmentRequest ¶
type PartitionAssignmentRequest struct { // The type of request this is. // // Types that are assignable to Request: // // *PartitionAssignmentRequest_Initial // *PartitionAssignmentRequest_Ack Request isPartitionAssignmentRequest_Request `protobuf_oneof:"request"` // contains filtered or unexported fields }
A request on the PartitionAssignment stream.
func (*PartitionAssignmentRequest) Descriptor ¶
func (*PartitionAssignmentRequest) Descriptor() ([]byte, []int)
Deprecated: Use PartitionAssignmentRequest.ProtoReflect.Descriptor instead.
func (*PartitionAssignmentRequest) GetAck ¶
func (x *PartitionAssignmentRequest) GetAck() *PartitionAssignmentAck
func (*PartitionAssignmentRequest) GetInitial ¶
func (x *PartitionAssignmentRequest) GetInitial() *InitialPartitionAssignmentRequest
func (*PartitionAssignmentRequest) GetRequest ¶
func (m *PartitionAssignmentRequest) GetRequest() isPartitionAssignmentRequest_Request
func (*PartitionAssignmentRequest) ProtoMessage ¶
func (*PartitionAssignmentRequest) ProtoMessage()
func (*PartitionAssignmentRequest) ProtoReflect ¶
func (x *PartitionAssignmentRequest) ProtoReflect() protoreflect.Message
func (*PartitionAssignmentRequest) Reset ¶
func (x *PartitionAssignmentRequest) Reset()
func (*PartitionAssignmentRequest) String ¶
func (x *PartitionAssignmentRequest) String() string
type PartitionAssignmentRequest_Ack ¶
type PartitionAssignmentRequest_Ack struct { // Acknowledgement of a partition assignment. Ack *PartitionAssignmentAck `protobuf:"bytes,2,opt,name=ack,proto3,oneof"` }
type PartitionAssignmentRequest_Initial ¶
type PartitionAssignmentRequest_Initial struct { // Initial request on the stream. Initial *InitialPartitionAssignmentRequest `protobuf:"bytes,1,opt,name=initial,proto3,oneof"` }
type PartitionAssignmentServiceClient ¶
type PartitionAssignmentServiceClient interface { // Assign partitions for this client to handle for the specified subscription. // // The client must send an InitialPartitionAssignmentRequest first. // The server will then send at most one unacknowledged PartitionAssignment // outstanding on the stream at a time. // The client should send a PartitionAssignmentAck after updating the // partitions it is connected to to reflect the new assignment. AssignPartitions(ctx context.Context, opts ...grpc.CallOption) (PartitionAssignmentService_AssignPartitionsClient, error) }
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.
func NewPartitionAssignmentServiceClient ¶
func NewPartitionAssignmentServiceClient(cc grpc.ClientConnInterface) PartitionAssignmentServiceClient
type PartitionAssignmentServiceServer ¶
type PartitionAssignmentServiceServer interface { // Assign partitions for this client to handle for the specified subscription. // // The client must send an InitialPartitionAssignmentRequest first. // The server will then send at most one unacknowledged PartitionAssignment // outstanding on the stream at a time. // The client should send a PartitionAssignmentAck after updating the // partitions it is connected to to reflect the new assignment. AssignPartitions(PartitionAssignmentService_AssignPartitionsServer) error }
PartitionAssignmentServiceServer is the server API for PartitionAssignmentService service.
type PartitionAssignmentService_AssignPartitionsClient ¶
type PartitionAssignmentService_AssignPartitionsClient interface { Send(*PartitionAssignmentRequest) error Recv() (*PartitionAssignment, error) grpc.ClientStream }
type PartitionAssignmentService_AssignPartitionsServer ¶
type PartitionAssignmentService_AssignPartitionsServer interface { Send(*PartitionAssignment) error Recv() (*PartitionAssignmentRequest, error) grpc.ServerStream }
type PartitionCursor ¶
type PartitionCursor struct { // The partition this is for. Partition int64 `protobuf:"varint,1,opt,name=partition,proto3" json:"partition,omitempty"` // The value of the cursor. Cursor *Cursor `protobuf:"bytes,2,opt,name=cursor,proto3" json:"cursor,omitempty"` // contains filtered or unexported fields }
A pair of a Cursor and the partition it is for.
func (*PartitionCursor) Descriptor ¶
func (*PartitionCursor) Descriptor() ([]byte, []int)
Deprecated: Use PartitionCursor.ProtoReflect.Descriptor instead.
func (*PartitionCursor) GetCursor ¶
func (x *PartitionCursor) GetCursor() *Cursor
func (*PartitionCursor) GetPartition ¶
func (x *PartitionCursor) GetPartition() int64
func (*PartitionCursor) ProtoMessage ¶
func (*PartitionCursor) ProtoMessage()
func (*PartitionCursor) ProtoReflect ¶
func (x *PartitionCursor) ProtoReflect() protoreflect.Message
func (*PartitionCursor) Reset ¶
func (x *PartitionCursor) Reset()
func (*PartitionCursor) String ¶
func (x *PartitionCursor) String() string
type PubSubMessage ¶
type PubSubMessage struct { // The key used for routing messages to partitions or for compaction (e.g., // keep the last N messages per key). If the key is empty, the message is // routed to an arbitrary partition. Key []byte `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"` // The payload of the message. Data []byte `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"` // Optional attributes that can be used for message metadata/headers. Attributes map[string]*AttributeValues `protobuf:"bytes,3,rep,name=attributes,proto3" json:"attributes,omitempty" protobuf_key:"bytes,1,opt,name=key,proto3" protobuf_val:"bytes,2,opt,name=value,proto3"` // An optional, user-specified event time. EventTime *timestamppb.Timestamp `protobuf:"bytes,4,opt,name=event_time,json=eventTime,proto3" json:"event_time,omitempty"` // contains filtered or unexported fields }
A message that is published by publishers and delivered to subscribers.
func (*PubSubMessage) Descriptor ¶
func (*PubSubMessage) Descriptor() ([]byte, []int)
Deprecated: Use PubSubMessage.ProtoReflect.Descriptor instead.
func (*PubSubMessage) GetAttributes ¶
func (x *PubSubMessage) GetAttributes() map[string]*AttributeValues
func (*PubSubMessage) GetData ¶
func (x *PubSubMessage) GetData() []byte
func (*PubSubMessage) GetEventTime ¶
func (x *PubSubMessage) GetEventTime() *timestamppb.Timestamp
func (*PubSubMessage) GetKey ¶
func (x *PubSubMessage) GetKey() []byte
func (*PubSubMessage) ProtoMessage ¶
func (*PubSubMessage) ProtoMessage()
func (*PubSubMessage) ProtoReflect ¶
func (x *PubSubMessage) ProtoReflect() protoreflect.Message
func (*PubSubMessage) Reset ¶
func (x *PubSubMessage) Reset()
func (*PubSubMessage) String ¶
func (x *PubSubMessage) String() string
type PublishRequest ¶
type PublishRequest struct { // The type of request this is. // // Types that are assignable to RequestType: // // *PublishRequest_InitialRequest // *PublishRequest_MessagePublishRequest RequestType isPublishRequest_RequestType `protobuf_oneof:"request_type"` // contains filtered or unexported fields }
Request sent from the client to the server on a stream.
func (*PublishRequest) Descriptor ¶
func (*PublishRequest) Descriptor() ([]byte, []int)
Deprecated: Use PublishRequest.ProtoReflect.Descriptor instead.
func (*PublishRequest) GetInitialRequest ¶
func (x *PublishRequest) GetInitialRequest() *InitialPublishRequest
func (*PublishRequest) GetMessagePublishRequest ¶
func (x *PublishRequest) GetMessagePublishRequest() *MessagePublishRequest
func (*PublishRequest) GetRequestType ¶
func (m *PublishRequest) GetRequestType() isPublishRequest_RequestType
func (*PublishRequest) ProtoMessage ¶
func (*PublishRequest) ProtoMessage()
func (*PublishRequest) ProtoReflect ¶
func (x *PublishRequest) ProtoReflect() protoreflect.Message
func (*PublishRequest) Reset ¶
func (x *PublishRequest) Reset()
func (*PublishRequest) String ¶
func (x *PublishRequest) String() string
type PublishRequest_InitialRequest ¶
type PublishRequest_InitialRequest struct { // Initial request on the stream. InitialRequest *InitialPublishRequest `protobuf:"bytes,1,opt,name=initial_request,json=initialRequest,proto3,oneof"` }
type PublishRequest_MessagePublishRequest ¶
type PublishRequest_MessagePublishRequest struct { // Request to publish messages. MessagePublishRequest *MessagePublishRequest `protobuf:"bytes,2,opt,name=message_publish_request,json=messagePublishRequest,proto3,oneof"` }
type PublishResponse ¶
type PublishResponse struct { // The type of response this is. // // Types that are assignable to ResponseType: // // *PublishResponse_InitialResponse // *PublishResponse_MessageResponse ResponseType isPublishResponse_ResponseType `protobuf_oneof:"response_type"` // contains filtered or unexported fields }
Response to a PublishRequest.
func (*PublishResponse) Descriptor ¶
func (*PublishResponse) Descriptor() ([]byte, []int)
Deprecated: Use PublishResponse.ProtoReflect.Descriptor instead.
func (*PublishResponse) GetInitialResponse ¶
func (x *PublishResponse) GetInitialResponse() *InitialPublishResponse
func (*PublishResponse) GetMessageResponse ¶
func (x *PublishResponse) GetMessageResponse() *MessagePublishResponse
func (*PublishResponse) GetResponseType ¶
func (m *PublishResponse) GetResponseType() isPublishResponse_ResponseType
func (*PublishResponse) ProtoMessage ¶
func (*PublishResponse) ProtoMessage()
func (*PublishResponse) ProtoReflect ¶
func (x *PublishResponse) ProtoReflect() protoreflect.Message
func (*PublishResponse) Reset ¶
func (x *PublishResponse) Reset()
func (*PublishResponse) String ¶
func (x *PublishResponse) String() string
type PublishResponse_InitialResponse ¶
type PublishResponse_InitialResponse struct { // Initial response on the stream. InitialResponse *InitialPublishResponse `protobuf:"bytes,1,opt,name=initial_response,json=initialResponse,proto3,oneof"` }
type PublishResponse_MessageResponse ¶
type PublishResponse_MessageResponse struct { // Response to publishing messages. MessageResponse *MessagePublishResponse `protobuf:"bytes,2,opt,name=message_response,json=messageResponse,proto3,oneof"` }
type PublisherServiceClient ¶
type PublisherServiceClient interface { // Establishes a stream with the server for publishing messages. Once the // stream is initialized, the client publishes messages by sending publish // requests on the stream. The server responds with a PublishResponse for each // PublishRequest sent by the client, in the same order that the requests // were sent. Note that multiple PublishRequests can be in flight // simultaneously, but they will be processed by the server in the order that // they are sent by the client on a given stream. Publish(ctx context.Context, opts ...grpc.CallOption) (PublisherService_PublishClient, error) }
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.
func NewPublisherServiceClient ¶
func NewPublisherServiceClient(cc grpc.ClientConnInterface) PublisherServiceClient
type PublisherServiceServer ¶
type PublisherServiceServer interface { // Establishes a stream with the server for publishing messages. Once the // stream is initialized, the client publishes messages by sending publish // requests on the stream. The server responds with a PublishResponse for each // PublishRequest sent by the client, in the same order that the requests // were sent. Note that multiple PublishRequests can be in flight // simultaneously, but they will be processed by the server in the order that // they are sent by the client on a given stream. Publish(PublisherService_PublishServer) error }
PublisherServiceServer is the server API for PublisherService service.
type PublisherService_PublishClient ¶
type PublisherService_PublishClient interface { Send(*PublishRequest) error Recv() (*PublishResponse, error) grpc.ClientStream }
type PublisherService_PublishServer ¶
type PublisherService_PublishServer interface { Send(*PublishResponse) error Recv() (*PublishRequest, error) grpc.ServerStream }
type Reservation ¶
type Reservation struct { // The name of the reservation. // Structured like: // projects/{project_number}/locations/{location}/reservations/{reservation_id} Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // The reserved throughput capacity. Every unit of throughput capacity is // equivalent to 1 MiB/s of published messages or 2 MiB/s of subscribed // messages. // // Any topics which are declared as using capacity from a Reservation will // consume resources from this reservation instead of being charged // individually. ThroughputCapacity int64 `protobuf:"varint,2,opt,name=throughput_capacity,json=throughputCapacity,proto3" json:"throughput_capacity,omitempty"` // contains filtered or unexported fields }
Metadata about a reservation resource.
func (*Reservation) Descriptor ¶
func (*Reservation) Descriptor() ([]byte, []int)
Deprecated: Use Reservation.ProtoReflect.Descriptor instead.
func (*Reservation) GetName ¶
func (x *Reservation) GetName() string
func (*Reservation) GetThroughputCapacity ¶
func (x *Reservation) GetThroughputCapacity() int64
func (*Reservation) ProtoMessage ¶
func (*Reservation) ProtoMessage()
func (*Reservation) ProtoReflect ¶
func (x *Reservation) ProtoReflect() protoreflect.Message
func (*Reservation) Reset ¶
func (x *Reservation) Reset()
func (*Reservation) String ¶
func (x *Reservation) String() string
type SeekRequest ¶
type SeekRequest struct { // The target to seek to. Must be set. // // Types that are assignable to Target: // // *SeekRequest_NamedTarget_ // *SeekRequest_Cursor Target isSeekRequest_Target `protobuf_oneof:"target"` // contains filtered or unexported fields }
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.
func (*SeekRequest) Descriptor ¶
func (*SeekRequest) Descriptor() ([]byte, []int)
Deprecated: Use SeekRequest.ProtoReflect.Descriptor instead.
func (*SeekRequest) GetCursor ¶
func (x *SeekRequest) GetCursor() *Cursor
func (*SeekRequest) GetNamedTarget ¶
func (x *SeekRequest) GetNamedTarget() SeekRequest_NamedTarget
func (*SeekRequest) GetTarget ¶
func (m *SeekRequest) GetTarget() isSeekRequest_Target
func (*SeekRequest) ProtoMessage ¶
func (*SeekRequest) ProtoMessage()
func (*SeekRequest) ProtoReflect ¶
func (x *SeekRequest) ProtoReflect() protoreflect.Message
func (*SeekRequest) Reset ¶
func (x *SeekRequest) Reset()
func (*SeekRequest) String ¶
func (x *SeekRequest) String() string
type SeekRequest_Cursor ¶
type SeekRequest_Cursor struct { // A target corresponding to the cursor, pointing to anywhere in the // topic partition. Cursor *Cursor `protobuf:"bytes,2,opt,name=cursor,proto3,oneof"` }
type SeekRequest_NamedTarget ¶
type SeekRequest_NamedTarget int32
A special target in the partition that takes no other parameters.
const ( // Default value. This value is unused. SeekRequest_NAMED_TARGET_UNSPECIFIED SeekRequest_NamedTarget = 0 // A target corresponding to the most recently published message in the // partition. SeekRequest_HEAD SeekRequest_NamedTarget = 1 // A target corresponding to the committed cursor for the given subscription // and topic partition. SeekRequest_COMMITTED_CURSOR SeekRequest_NamedTarget = 2 )
func (SeekRequest_NamedTarget) Descriptor ¶
func (SeekRequest_NamedTarget) Descriptor() protoreflect.EnumDescriptor
func (SeekRequest_NamedTarget) Enum ¶
func (x SeekRequest_NamedTarget) Enum() *SeekRequest_NamedTarget
func (SeekRequest_NamedTarget) EnumDescriptor ¶
func (SeekRequest_NamedTarget) EnumDescriptor() ([]byte, []int)
Deprecated: Use SeekRequest_NamedTarget.Descriptor instead.
func (SeekRequest_NamedTarget) Number ¶
func (x SeekRequest_NamedTarget) Number() protoreflect.EnumNumber
func (SeekRequest_NamedTarget) String ¶
func (x SeekRequest_NamedTarget) String() string
func (SeekRequest_NamedTarget) Type ¶
func (SeekRequest_NamedTarget) Type() protoreflect.EnumType
type SeekRequest_NamedTarget_ ¶
type SeekRequest_NamedTarget_ struct { // A named target. NamedTarget SeekRequest_NamedTarget `protobuf:"varint,1,opt,name=named_target,json=namedTarget,proto3,enum=google.cloud.pubsublite.v1.SeekRequest_NamedTarget,oneof"` }
type SeekResponse ¶
type SeekResponse struct { // The new delivery cursor for the current stream. Cursor *Cursor `protobuf:"bytes,1,opt,name=cursor,proto3" json:"cursor,omitempty"` // contains filtered or unexported fields }
Response to a SeekRequest.
func (*SeekResponse) Descriptor ¶
func (*SeekResponse) Descriptor() ([]byte, []int)
Deprecated: Use SeekResponse.ProtoReflect.Descriptor instead.
func (*SeekResponse) GetCursor ¶
func (x *SeekResponse) GetCursor() *Cursor
func (*SeekResponse) ProtoMessage ¶
func (*SeekResponse) ProtoMessage()
func (*SeekResponse) ProtoReflect ¶
func (x *SeekResponse) ProtoReflect() protoreflect.Message
func (*SeekResponse) Reset ¶
func (x *SeekResponse) Reset()
func (*SeekResponse) String ¶
func (x *SeekResponse) String() string
type SeekSubscriptionRequest ¶
type SeekSubscriptionRequest struct { // Required. The name of the subscription to seek. Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // The target to seek to. Must be set. // // Types that are assignable to Target: // // *SeekSubscriptionRequest_NamedTarget_ // *SeekSubscriptionRequest_TimeTarget Target isSeekSubscriptionRequest_Target `protobuf_oneof:"target"` // contains filtered or unexported fields }
Request for SeekSubscription.
func (*SeekSubscriptionRequest) Descriptor ¶
func (*SeekSubscriptionRequest) Descriptor() ([]byte, []int)
Deprecated: Use SeekSubscriptionRequest.ProtoReflect.Descriptor instead.
func (*SeekSubscriptionRequest) GetName ¶
func (x *SeekSubscriptionRequest) GetName() string
func (*SeekSubscriptionRequest) GetNamedTarget ¶
func (x *SeekSubscriptionRequest) GetNamedTarget() SeekSubscriptionRequest_NamedTarget
func (*SeekSubscriptionRequest) GetTarget ¶
func (m *SeekSubscriptionRequest) GetTarget() isSeekSubscriptionRequest_Target
func (*SeekSubscriptionRequest) GetTimeTarget ¶
func (x *SeekSubscriptionRequest) GetTimeTarget() *TimeTarget
func (*SeekSubscriptionRequest) ProtoMessage ¶
func (*SeekSubscriptionRequest) ProtoMessage()
func (*SeekSubscriptionRequest) ProtoReflect ¶
func (x *SeekSubscriptionRequest) ProtoReflect() protoreflect.Message
func (*SeekSubscriptionRequest) Reset ¶
func (x *SeekSubscriptionRequest) Reset()
func (*SeekSubscriptionRequest) String ¶
func (x *SeekSubscriptionRequest) String() string
type SeekSubscriptionRequest_NamedTarget ¶
type SeekSubscriptionRequest_NamedTarget int32
A named position with respect to the message backlog.
const ( // Unspecified named target. Do not use. SeekSubscriptionRequest_NAMED_TARGET_UNSPECIFIED SeekSubscriptionRequest_NamedTarget = 0 // Seek to the oldest retained message. SeekSubscriptionRequest_TAIL SeekSubscriptionRequest_NamedTarget = 1 // Seek past all recently published messages, skipping the entire message // backlog. SeekSubscriptionRequest_HEAD SeekSubscriptionRequest_NamedTarget = 2 )
func (SeekSubscriptionRequest_NamedTarget) Descriptor ¶
func (SeekSubscriptionRequest_NamedTarget) Descriptor() protoreflect.EnumDescriptor
func (SeekSubscriptionRequest_NamedTarget) Enum ¶
func (x SeekSubscriptionRequest_NamedTarget) Enum() *SeekSubscriptionRequest_NamedTarget
func (SeekSubscriptionRequest_NamedTarget) EnumDescriptor ¶
func (SeekSubscriptionRequest_NamedTarget) EnumDescriptor() ([]byte, []int)
Deprecated: Use SeekSubscriptionRequest_NamedTarget.Descriptor instead.
func (SeekSubscriptionRequest_NamedTarget) Number ¶
func (x SeekSubscriptionRequest_NamedTarget) Number() protoreflect.EnumNumber
func (SeekSubscriptionRequest_NamedTarget) String ¶
func (x SeekSubscriptionRequest_NamedTarget) String() string
func (SeekSubscriptionRequest_NamedTarget) Type ¶
func (SeekSubscriptionRequest_NamedTarget) Type() protoreflect.EnumType
type SeekSubscriptionRequest_NamedTarget_ ¶
type SeekSubscriptionRequest_NamedTarget_ struct { // Seek to a named position with respect to the message backlog. NamedTarget SeekSubscriptionRequest_NamedTarget `protobuf:"varint,2,opt,name=named_target,json=namedTarget,proto3,enum=google.cloud.pubsublite.v1.SeekSubscriptionRequest_NamedTarget,oneof"` }
type SeekSubscriptionRequest_TimeTarget ¶
type SeekSubscriptionRequest_TimeTarget struct { // Seek to the first message whose publish or event time is greater than or // equal to the specified query time. If no such message can be located, // will seek to the end of the message backlog. TimeTarget *TimeTarget `protobuf:"bytes,3,opt,name=time_target,json=timeTarget,proto3,oneof"` }
type SeekSubscriptionResponse ¶
type SeekSubscriptionResponse struct {
// contains filtered or unexported fields
}
Response for SeekSubscription long running operation.
func (*SeekSubscriptionResponse) Descriptor ¶
func (*SeekSubscriptionResponse) Descriptor() ([]byte, []int)
Deprecated: Use SeekSubscriptionResponse.ProtoReflect.Descriptor instead.
func (*SeekSubscriptionResponse) ProtoMessage ¶
func (*SeekSubscriptionResponse) ProtoMessage()
func (*SeekSubscriptionResponse) ProtoReflect ¶
func (x *SeekSubscriptionResponse) ProtoReflect() protoreflect.Message
func (*SeekSubscriptionResponse) Reset ¶
func (x *SeekSubscriptionResponse) Reset()
func (*SeekSubscriptionResponse) String ¶
func (x *SeekSubscriptionResponse) String() string
type SequencedCommitCursorRequest ¶
type SequencedCommitCursorRequest struct { // The new value for the committed cursor. Cursor *Cursor `protobuf:"bytes,1,opt,name=cursor,proto3" json:"cursor,omitempty"` // contains filtered or unexported fields }
Streaming request to update the committed cursor. Subsequent SequencedCommitCursorRequests override outstanding ones.
func (*SequencedCommitCursorRequest) Descriptor ¶
func (*SequencedCommitCursorRequest) Descriptor() ([]byte, []int)
Deprecated: Use SequencedCommitCursorRequest.ProtoReflect.Descriptor instead.
func (*SequencedCommitCursorRequest) GetCursor ¶
func (x *SequencedCommitCursorRequest) GetCursor() *Cursor
func (*SequencedCommitCursorRequest) ProtoMessage ¶
func (*SequencedCommitCursorRequest) ProtoMessage()
func (*SequencedCommitCursorRequest) ProtoReflect ¶
func (x *SequencedCommitCursorRequest) ProtoReflect() protoreflect.Message
func (*SequencedCommitCursorRequest) Reset ¶
func (x *SequencedCommitCursorRequest) Reset()
func (*SequencedCommitCursorRequest) String ¶
func (x *SequencedCommitCursorRequest) String() string
type SequencedCommitCursorResponse ¶
type SequencedCommitCursorResponse struct { // The number of outstanding SequencedCommitCursorRequests acknowledged by // this response. Note that SequencedCommitCursorRequests are acknowledged in // the order that they are received. AcknowledgedCommits int64 `protobuf:"varint,1,opt,name=acknowledged_commits,json=acknowledgedCommits,proto3" json:"acknowledged_commits,omitempty"` // contains filtered or unexported fields }
Response to a SequencedCommitCursorRequest.
func (*SequencedCommitCursorResponse) Descriptor ¶
func (*SequencedCommitCursorResponse) Descriptor() ([]byte, []int)
Deprecated: Use SequencedCommitCursorResponse.ProtoReflect.Descriptor instead.
func (*SequencedCommitCursorResponse) GetAcknowledgedCommits ¶
func (x *SequencedCommitCursorResponse) GetAcknowledgedCommits() int64
func (*SequencedCommitCursorResponse) ProtoMessage ¶
func (*SequencedCommitCursorResponse) ProtoMessage()
func (*SequencedCommitCursorResponse) ProtoReflect ¶
func (x *SequencedCommitCursorResponse) ProtoReflect() protoreflect.Message
func (*SequencedCommitCursorResponse) Reset ¶
func (x *SequencedCommitCursorResponse) Reset()
func (*SequencedCommitCursorResponse) String ¶
func (x *SequencedCommitCursorResponse) String() string
type SequencedMessage ¶
type SequencedMessage struct { // The position of a message within the partition where it is stored. Cursor *Cursor `protobuf:"bytes,1,opt,name=cursor,proto3" json:"cursor,omitempty"` // The time when the message was received by the server when it was first // published. PublishTime *timestamppb.Timestamp `protobuf:"bytes,2,opt,name=publish_time,json=publishTime,proto3" json:"publish_time,omitempty"` // The user message. Message *PubSubMessage `protobuf:"bytes,3,opt,name=message,proto3" json:"message,omitempty"` // The size in bytes of this message for flow control and quota purposes. SizeBytes int64 `protobuf:"varint,4,opt,name=size_bytes,json=sizeBytes,proto3" json:"size_bytes,omitempty"` // contains filtered or unexported fields }
A message that has been stored and sequenced by the Pub/Sub Lite system.
func (*SequencedMessage) Descriptor ¶
func (*SequencedMessage) Descriptor() ([]byte, []int)
Deprecated: Use SequencedMessage.ProtoReflect.Descriptor instead.
func (*SequencedMessage) GetCursor ¶
func (x *SequencedMessage) GetCursor() *Cursor
func (*SequencedMessage) GetMessage ¶
func (x *SequencedMessage) GetMessage() *PubSubMessage
func (*SequencedMessage) GetPublishTime ¶
func (x *SequencedMessage) GetPublishTime() *timestamppb.Timestamp
func (*SequencedMessage) GetSizeBytes ¶
func (x *SequencedMessage) GetSizeBytes() int64
func (*SequencedMessage) ProtoMessage ¶
func (*SequencedMessage) ProtoMessage()
func (*SequencedMessage) ProtoReflect ¶
func (x *SequencedMessage) ProtoReflect() protoreflect.Message
func (*SequencedMessage) Reset ¶
func (x *SequencedMessage) Reset()
func (*SequencedMessage) String ¶
func (x *SequencedMessage) String() string
type StreamingCommitCursorRequest ¶
type StreamingCommitCursorRequest struct { // The type of request this is. // // Types that are assignable to Request: // // *StreamingCommitCursorRequest_Initial // *StreamingCommitCursorRequest_Commit Request isStreamingCommitCursorRequest_Request `protobuf_oneof:"request"` // contains filtered or unexported fields }
A request sent from the client to the server on a stream.
func (*StreamingCommitCursorRequest) Descriptor ¶
func (*StreamingCommitCursorRequest) Descriptor() ([]byte, []int)
Deprecated: Use StreamingCommitCursorRequest.ProtoReflect.Descriptor instead.
func (*StreamingCommitCursorRequest) GetCommit ¶
func (x *StreamingCommitCursorRequest) GetCommit() *SequencedCommitCursorRequest
func (*StreamingCommitCursorRequest) GetInitial ¶
func (x *StreamingCommitCursorRequest) GetInitial() *InitialCommitCursorRequest
func (*StreamingCommitCursorRequest) GetRequest ¶
func (m *StreamingCommitCursorRequest) GetRequest() isStreamingCommitCursorRequest_Request
func (*StreamingCommitCursorRequest) ProtoMessage ¶
func (*StreamingCommitCursorRequest) ProtoMessage()
func (*StreamingCommitCursorRequest) ProtoReflect ¶
func (x *StreamingCommitCursorRequest) ProtoReflect() protoreflect.Message
func (*StreamingCommitCursorRequest) Reset ¶
func (x *StreamingCommitCursorRequest) Reset()
func (*StreamingCommitCursorRequest) String ¶
func (x *StreamingCommitCursorRequest) String() string
type StreamingCommitCursorRequest_Commit ¶
type StreamingCommitCursorRequest_Commit struct { // Request to commit a new cursor value. Commit *SequencedCommitCursorRequest `protobuf:"bytes,2,opt,name=commit,proto3,oneof"` }
type StreamingCommitCursorRequest_Initial ¶
type StreamingCommitCursorRequest_Initial struct { // Initial request on the stream. Initial *InitialCommitCursorRequest `protobuf:"bytes,1,opt,name=initial,proto3,oneof"` }
type StreamingCommitCursorResponse ¶
type StreamingCommitCursorResponse struct { // The type of request this is. // // Types that are assignable to Request: // // *StreamingCommitCursorResponse_Initial // *StreamingCommitCursorResponse_Commit Request isStreamingCommitCursorResponse_Request `protobuf_oneof:"request"` // contains filtered or unexported fields }
Response to a StreamingCommitCursorRequest.
func (*StreamingCommitCursorResponse) Descriptor ¶
func (*StreamingCommitCursorResponse) Descriptor() ([]byte, []int)
Deprecated: Use StreamingCommitCursorResponse.ProtoReflect.Descriptor instead.
func (*StreamingCommitCursorResponse) GetCommit ¶
func (x *StreamingCommitCursorResponse) GetCommit() *SequencedCommitCursorResponse
func (*StreamingCommitCursorResponse) GetInitial ¶
func (x *StreamingCommitCursorResponse) GetInitial() *InitialCommitCursorResponse
func (*StreamingCommitCursorResponse) GetRequest ¶
func (m *StreamingCommitCursorResponse) GetRequest() isStreamingCommitCursorResponse_Request
func (*StreamingCommitCursorResponse) ProtoMessage ¶
func (*StreamingCommitCursorResponse) ProtoMessage()
func (*StreamingCommitCursorResponse) ProtoReflect ¶
func (x *StreamingCommitCursorResponse) ProtoReflect() protoreflect.Message
func (*StreamingCommitCursorResponse) Reset ¶
func (x *StreamingCommitCursorResponse) Reset()
func (*StreamingCommitCursorResponse) String ¶
func (x *StreamingCommitCursorResponse) String() string
type StreamingCommitCursorResponse_Commit ¶
type StreamingCommitCursorResponse_Commit struct { // Response to committing a new cursor value. Commit *SequencedCommitCursorResponse `protobuf:"bytes,2,opt,name=commit,proto3,oneof"` }
type StreamingCommitCursorResponse_Initial ¶
type StreamingCommitCursorResponse_Initial struct { // Initial response on the stream. Initial *InitialCommitCursorResponse `protobuf:"bytes,1,opt,name=initial,proto3,oneof"` }
type SubscribeRequest ¶
type SubscribeRequest struct { // The type of request this is. // // Types that are assignable to Request: // // *SubscribeRequest_Initial // *SubscribeRequest_Seek // *SubscribeRequest_FlowControl Request isSubscribeRequest_Request `protobuf_oneof:"request"` // contains filtered or unexported fields }
A request sent from the client to the server on a stream.
func (*SubscribeRequest) Descriptor ¶
func (*SubscribeRequest) Descriptor() ([]byte, []int)
Deprecated: Use SubscribeRequest.ProtoReflect.Descriptor instead.
func (*SubscribeRequest) GetFlowControl ¶
func (x *SubscribeRequest) GetFlowControl() *FlowControlRequest
func (*SubscribeRequest) GetInitial ¶
func (x *SubscribeRequest) GetInitial() *InitialSubscribeRequest
func (*SubscribeRequest) GetRequest ¶
func (m *SubscribeRequest) GetRequest() isSubscribeRequest_Request
func (*SubscribeRequest) GetSeek ¶
func (x *SubscribeRequest) GetSeek() *SeekRequest
func (*SubscribeRequest) ProtoMessage ¶
func (*SubscribeRequest) ProtoMessage()
func (*SubscribeRequest) ProtoReflect ¶
func (x *SubscribeRequest) ProtoReflect() protoreflect.Message
func (*SubscribeRequest) Reset ¶
func (x *SubscribeRequest) Reset()
func (*SubscribeRequest) String ¶
func (x *SubscribeRequest) String() string
type SubscribeRequest_FlowControl ¶
type SubscribeRequest_FlowControl struct { // Request to grant tokens to the server, FlowControl *FlowControlRequest `protobuf:"bytes,3,opt,name=flow_control,json=flowControl,proto3,oneof"` }
type SubscribeRequest_Initial ¶
type SubscribeRequest_Initial struct { // Initial request on the stream. Initial *InitialSubscribeRequest `protobuf:"bytes,1,opt,name=initial,proto3,oneof"` }
type SubscribeRequest_Seek ¶
type SubscribeRequest_Seek struct { // Request to update the stream's delivery cursor. Seek *SeekRequest `protobuf:"bytes,2,opt,name=seek,proto3,oneof"` }
type SubscribeResponse ¶
type SubscribeResponse struct { // The type of response this is. // // Types that are assignable to Response: // // *SubscribeResponse_Initial // *SubscribeResponse_Seek // *SubscribeResponse_Messages Response isSubscribeResponse_Response `protobuf_oneof:"response"` // contains filtered or unexported fields }
Response to SubscribeRequest.
func (*SubscribeResponse) Descriptor ¶
func (*SubscribeResponse) Descriptor() ([]byte, []int)
Deprecated: Use SubscribeResponse.ProtoReflect.Descriptor instead.
func (*SubscribeResponse) GetInitial ¶
func (x *SubscribeResponse) GetInitial() *InitialSubscribeResponse
func (*SubscribeResponse) GetMessages ¶
func (x *SubscribeResponse) GetMessages() *MessageResponse
func (*SubscribeResponse) GetResponse ¶
func (m *SubscribeResponse) GetResponse() isSubscribeResponse_Response
func (*SubscribeResponse) GetSeek ¶
func (x *SubscribeResponse) GetSeek() *SeekResponse
func (*SubscribeResponse) ProtoMessage ¶
func (*SubscribeResponse) ProtoMessage()
func (*SubscribeResponse) ProtoReflect ¶
func (x *SubscribeResponse) ProtoReflect() protoreflect.Message
func (*SubscribeResponse) Reset ¶
func (x *SubscribeResponse) Reset()
func (*SubscribeResponse) String ¶
func (x *SubscribeResponse) String() string
type SubscribeResponse_Initial ¶
type SubscribeResponse_Initial struct { // Initial response on the stream. Initial *InitialSubscribeResponse `protobuf:"bytes,1,opt,name=initial,proto3,oneof"` }
type SubscribeResponse_Messages ¶
type SubscribeResponse_Messages struct { // Response containing messages from the topic partition. Messages *MessageResponse `protobuf:"bytes,3,opt,name=messages,proto3,oneof"` }
type SubscribeResponse_Seek ¶
type SubscribeResponse_Seek struct { // Response to a Seek operation. Seek *SeekResponse `protobuf:"bytes,2,opt,name=seek,proto3,oneof"` }
type SubscriberServiceClient ¶
type SubscriberServiceClient interface { // Establishes a stream with the server for receiving messages. Subscribe(ctx context.Context, opts ...grpc.CallOption) (SubscriberService_SubscribeClient, error) }
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.
func NewSubscriberServiceClient ¶
func NewSubscriberServiceClient(cc grpc.ClientConnInterface) SubscriberServiceClient
type SubscriberServiceServer ¶
type SubscriberServiceServer interface { // Establishes a stream with the server for receiving messages. Subscribe(SubscriberService_SubscribeServer) error }
SubscriberServiceServer is the server API for SubscriberService service.
type SubscriberService_SubscribeClient ¶
type SubscriberService_SubscribeClient interface { Send(*SubscribeRequest) error Recv() (*SubscribeResponse, error) grpc.ClientStream }
type SubscriberService_SubscribeServer ¶
type SubscriberService_SubscribeServer interface { Send(*SubscribeResponse) error Recv() (*SubscribeRequest, error) grpc.ServerStream }
type Subscription ¶
type Subscription struct { // The name of the subscription. // Structured like: // projects/{project_number}/locations/{location}/subscriptions/{subscription_id} Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // The name of the topic this subscription is attached to. // Structured like: // projects/{project_number}/locations/{location}/topics/{topic_id} Topic string `protobuf:"bytes,2,opt,name=topic,proto3" json:"topic,omitempty"` // The settings for this subscription's message delivery. DeliveryConfig *Subscription_DeliveryConfig `protobuf:"bytes,3,opt,name=delivery_config,json=deliveryConfig,proto3" json:"delivery_config,omitempty"` // If present, messages are automatically written from the Pub/Sub Lite topic // associated with this subscription to a destination. ExportConfig *ExportConfig `protobuf:"bytes,4,opt,name=export_config,json=exportConfig,proto3" json:"export_config,omitempty"` // contains filtered or unexported fields }
Metadata about a subscription resource.
func (*Subscription) Descriptor ¶
func (*Subscription) Descriptor() ([]byte, []int)
Deprecated: Use Subscription.ProtoReflect.Descriptor instead.
func (*Subscription) GetDeliveryConfig ¶
func (x *Subscription) GetDeliveryConfig() *Subscription_DeliveryConfig
func (*Subscription) GetExportConfig ¶
func (x *Subscription) GetExportConfig() *ExportConfig
func (*Subscription) GetName ¶
func (x *Subscription) GetName() string
func (*Subscription) GetTopic ¶
func (x *Subscription) GetTopic() string
func (*Subscription) ProtoMessage ¶
func (*Subscription) ProtoMessage()
func (*Subscription) ProtoReflect ¶
func (x *Subscription) ProtoReflect() protoreflect.Message
func (*Subscription) Reset ¶
func (x *Subscription) Reset()
func (*Subscription) String ¶
func (x *Subscription) String() string
type Subscription_DeliveryConfig ¶
type Subscription_DeliveryConfig struct { // The DeliveryRequirement for this subscription. DeliveryRequirement Subscription_DeliveryConfig_DeliveryRequirement `protobuf:"varint,3,opt,name=delivery_requirement,json=deliveryRequirement,proto3,enum=google.cloud.pubsublite.v1.Subscription_DeliveryConfig_DeliveryRequirement" json:"delivery_requirement,omitempty"` // contains filtered or unexported fields }
The settings for a subscription's message delivery.
func (*Subscription_DeliveryConfig) Descriptor ¶
func (*Subscription_DeliveryConfig) Descriptor() ([]byte, []int)
Deprecated: Use Subscription_DeliveryConfig.ProtoReflect.Descriptor instead.
func (*Subscription_DeliveryConfig) GetDeliveryRequirement ¶
func (x *Subscription_DeliveryConfig) GetDeliveryRequirement() Subscription_DeliveryConfig_DeliveryRequirement
func (*Subscription_DeliveryConfig) ProtoMessage ¶
func (*Subscription_DeliveryConfig) ProtoMessage()
func (*Subscription_DeliveryConfig) ProtoReflect ¶
func (x *Subscription_DeliveryConfig) ProtoReflect() protoreflect.Message
func (*Subscription_DeliveryConfig) Reset ¶
func (x *Subscription_DeliveryConfig) Reset()
func (*Subscription_DeliveryConfig) String ¶
func (x *Subscription_DeliveryConfig) String() string
type Subscription_DeliveryConfig_DeliveryRequirement ¶
type Subscription_DeliveryConfig_DeliveryRequirement int32
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).
const ( // Default value. This value is unused. Subscription_DeliveryConfig_DELIVERY_REQUIREMENT_UNSPECIFIED Subscription_DeliveryConfig_DeliveryRequirement = 0 // The server does not wait for a published message to be successfully // written to storage before delivering it to subscribers. Subscription_DeliveryConfig_DELIVER_IMMEDIATELY Subscription_DeliveryConfig_DeliveryRequirement = 1 // The server will not deliver a published message to subscribers until // the message has been successfully written to storage. This will result // in higher end-to-end latency, but consistent delivery. Subscription_DeliveryConfig_DELIVER_AFTER_STORED Subscription_DeliveryConfig_DeliveryRequirement = 2 )
func (Subscription_DeliveryConfig_DeliveryRequirement) Descriptor ¶
func (Subscription_DeliveryConfig_DeliveryRequirement) Descriptor() protoreflect.EnumDescriptor
func (Subscription_DeliveryConfig_DeliveryRequirement) Enum ¶
func (x Subscription_DeliveryConfig_DeliveryRequirement) Enum() *Subscription_DeliveryConfig_DeliveryRequirement
func (Subscription_DeliveryConfig_DeliveryRequirement) EnumDescriptor ¶
func (Subscription_DeliveryConfig_DeliveryRequirement) EnumDescriptor() ([]byte, []int)
Deprecated: Use Subscription_DeliveryConfig_DeliveryRequirement.Descriptor instead.
func (Subscription_DeliveryConfig_DeliveryRequirement) Number ¶
func (x Subscription_DeliveryConfig_DeliveryRequirement) Number() protoreflect.EnumNumber
func (Subscription_DeliveryConfig_DeliveryRequirement) String ¶
func (x Subscription_DeliveryConfig_DeliveryRequirement) String() string
func (Subscription_DeliveryConfig_DeliveryRequirement) Type ¶
type TimeTarget ¶
type TimeTarget struct { // The type of message time to query. // // Types that are assignable to Time: // // *TimeTarget_PublishTime // *TimeTarget_EventTime Time isTimeTarget_Time `protobuf_oneof:"time"` // contains filtered or unexported fields }
A target publish or event time. Can be used for seeking to or retrieving the corresponding cursor.
func (*TimeTarget) Descriptor ¶
func (*TimeTarget) Descriptor() ([]byte, []int)
Deprecated: Use TimeTarget.ProtoReflect.Descriptor instead.
func (*TimeTarget) GetEventTime ¶
func (x *TimeTarget) GetEventTime() *timestamppb.Timestamp
func (*TimeTarget) GetPublishTime ¶
func (x *TimeTarget) GetPublishTime() *timestamppb.Timestamp
func (*TimeTarget) GetTime ¶
func (m *TimeTarget) GetTime() isTimeTarget_Time
func (*TimeTarget) ProtoMessage ¶
func (*TimeTarget) ProtoMessage()
func (*TimeTarget) ProtoReflect ¶
func (x *TimeTarget) ProtoReflect() protoreflect.Message
func (*TimeTarget) Reset ¶
func (x *TimeTarget) Reset()
func (*TimeTarget) String ¶
func (x *TimeTarget) String() string
type TimeTarget_EventTime ¶
type TimeTarget_EventTime struct { // Request the cursor of the first message with event time greater than or // equal to `event_time`. If messages are missing an event time, the publish // time is used as a fallback. As event times are user supplied, subsequent // messages may have event times less than `event_time` and should be // filtered by the client, if necessary. EventTime *timestamppb.Timestamp `protobuf:"bytes,2,opt,name=event_time,json=eventTime,proto3,oneof"` }
type TimeTarget_PublishTime ¶
type TimeTarget_PublishTime struct { // Request the cursor of the first message with publish time greater than or // equal to `publish_time`. All messages thereafter are guaranteed to have // publish times >= `publish_time`. PublishTime *timestamppb.Timestamp `protobuf:"bytes,1,opt,name=publish_time,json=publishTime,proto3,oneof"` }
type Topic ¶
type Topic struct { // The name of the topic. // Structured like: // projects/{project_number}/locations/{location}/topics/{topic_id} Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"` // The settings for this topic's partitions. PartitionConfig *Topic_PartitionConfig `protobuf:"bytes,2,opt,name=partition_config,json=partitionConfig,proto3" json:"partition_config,omitempty"` // The settings for this topic's message retention. RetentionConfig *Topic_RetentionConfig `protobuf:"bytes,3,opt,name=retention_config,json=retentionConfig,proto3" json:"retention_config,omitempty"` // The settings for this topic's Reservation usage. ReservationConfig *Topic_ReservationConfig `protobuf:"bytes,4,opt,name=reservation_config,json=reservationConfig,proto3" json:"reservation_config,omitempty"` // contains filtered or unexported fields }
Metadata about a topic resource.
func (*Topic) Descriptor ¶
Deprecated: Use Topic.ProtoReflect.Descriptor instead.
func (*Topic) GetName ¶
func (*Topic) GetPartitionConfig ¶
func (x *Topic) GetPartitionConfig() *Topic_PartitionConfig
func (*Topic) GetReservationConfig ¶
func (x *Topic) GetReservationConfig() *Topic_ReservationConfig
func (*Topic) GetRetentionConfig ¶
func (x *Topic) GetRetentionConfig() *Topic_RetentionConfig
func (*Topic) ProtoMessage ¶
func (*Topic) ProtoMessage()
func (*Topic) ProtoReflect ¶
func (x *Topic) ProtoReflect() protoreflect.Message
func (*Topic) Reset ¶
func (x *Topic) Reset()
func (*Topic) String ¶
type TopicPartitions ¶
type TopicPartitions struct { // The number of partitions in the topic. PartitionCount int64 `protobuf:"varint,1,opt,name=partition_count,json=partitionCount,proto3" json:"partition_count,omitempty"` // contains filtered or unexported fields }
Response for GetTopicPartitions.
func (*TopicPartitions) Descriptor ¶
func (*TopicPartitions) Descriptor() ([]byte, []int)
Deprecated: Use TopicPartitions.ProtoReflect.Descriptor instead.
func (*TopicPartitions) GetPartitionCount ¶
func (x *TopicPartitions) GetPartitionCount() int64
func (*TopicPartitions) ProtoMessage ¶
func (*TopicPartitions) ProtoMessage()
func (*TopicPartitions) ProtoReflect ¶
func (x *TopicPartitions) ProtoReflect() protoreflect.Message
func (*TopicPartitions) Reset ¶
func (x *TopicPartitions) Reset()
func (*TopicPartitions) String ¶
func (x *TopicPartitions) String() string
type TopicStatsServiceClient ¶
type TopicStatsServiceClient interface { // Compute statistics about a range of messages in a given topic and // partition. ComputeMessageStats(ctx context.Context, in *ComputeMessageStatsRequest, opts ...grpc.CallOption) (*ComputeMessageStatsResponse, error) // Compute the head cursor for the partition. // The head cursor's offset is guaranteed to be less than or equal to all // messages which have not yet been acknowledged as published, and // greater than the offset of any message whose publish has already // been acknowledged. It is zero if there have never been messages in the // partition. ComputeHeadCursor(ctx context.Context, in *ComputeHeadCursorRequest, opts ...grpc.CallOption) (*ComputeHeadCursorResponse, error) // Compute the corresponding cursor for a publish or event time in a topic // partition. ComputeTimeCursor(ctx context.Context, in *ComputeTimeCursorRequest, opts ...grpc.CallOption) (*ComputeTimeCursorResponse, error) }
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.
func NewTopicStatsServiceClient ¶
func NewTopicStatsServiceClient(cc grpc.ClientConnInterface) TopicStatsServiceClient
type TopicStatsServiceServer ¶
type TopicStatsServiceServer interface { // Compute statistics about a range of messages in a given topic and // partition. ComputeMessageStats(context.Context, *ComputeMessageStatsRequest) (*ComputeMessageStatsResponse, error) // Compute the head cursor for the partition. // The head cursor's offset is guaranteed to be less than or equal to all // messages which have not yet been acknowledged as published, and // greater than the offset of any message whose publish has already // been acknowledged. It is zero if there have never been messages in the // partition. ComputeHeadCursor(context.Context, *ComputeHeadCursorRequest) (*ComputeHeadCursorResponse, error) // Compute the corresponding cursor for a publish or event time in a topic // partition. ComputeTimeCursor(context.Context, *ComputeTimeCursorRequest) (*ComputeTimeCursorResponse, error) }
TopicStatsServiceServer is the server API for TopicStatsService service.
type Topic_PartitionConfig ¶
type Topic_PartitionConfig struct { // The number of partitions in the topic. Must be at least 1. // // Once a topic has been created the number of partitions can be increased // but not decreased. Message ordering is not guaranteed across a topic // resize. For more information see // https://cloud.google.com/pubsub/lite/docs/topics#scaling_capacity Count int64 `protobuf:"varint,1,opt,name=count,proto3" json:"count,omitempty"` // The throughput dimension of this topic. // // Types that are assignable to Dimension: // // *Topic_PartitionConfig_Scale // *Topic_PartitionConfig_Capacity_ Dimension isTopic_PartitionConfig_Dimension `protobuf_oneof:"dimension"` // contains filtered or unexported fields }
The settings for a topic's partitions.
func (*Topic_PartitionConfig) Descriptor ¶
func (*Topic_PartitionConfig) Descriptor() ([]byte, []int)
Deprecated: Use Topic_PartitionConfig.ProtoReflect.Descriptor instead.
func (*Topic_PartitionConfig) GetCapacity ¶
func (x *Topic_PartitionConfig) GetCapacity() *Topic_PartitionConfig_Capacity
func (*Topic_PartitionConfig) GetCount ¶
func (x *Topic_PartitionConfig) GetCount() int64
func (*Topic_PartitionConfig) GetDimension ¶
func (m *Topic_PartitionConfig) GetDimension() isTopic_PartitionConfig_Dimension
func (*Topic_PartitionConfig) GetScale ¶
func (x *Topic_PartitionConfig) GetScale() int32
Deprecated: Marked as deprecated in google/cloud/pubsublite/v1/common.proto.
func (*Topic_PartitionConfig) ProtoMessage ¶
func (*Topic_PartitionConfig) ProtoMessage()
func (*Topic_PartitionConfig) ProtoReflect ¶
func (x *Topic_PartitionConfig) ProtoReflect() protoreflect.Message
func (*Topic_PartitionConfig) Reset ¶
func (x *Topic_PartitionConfig) Reset()
func (*Topic_PartitionConfig) String ¶
func (x *Topic_PartitionConfig) String() string
type Topic_PartitionConfig_Capacity ¶
type Topic_PartitionConfig_Capacity struct { // Publish throughput capacity per partition in MiB/s. // Must be >= 4 and <= 16. PublishMibPerSec int32 `protobuf:"varint,1,opt,name=publish_mib_per_sec,json=publishMibPerSec,proto3" json:"publish_mib_per_sec,omitempty"` // Subscribe throughput capacity per partition in MiB/s. // Must be >= 4 and <= 32. SubscribeMibPerSec int32 `protobuf:"varint,2,opt,name=subscribe_mib_per_sec,json=subscribeMibPerSec,proto3" json:"subscribe_mib_per_sec,omitempty"` // contains filtered or unexported fields }
The throughput capacity configuration for each partition.
func (*Topic_PartitionConfig_Capacity) Descriptor ¶
func (*Topic_PartitionConfig_Capacity) Descriptor() ([]byte, []int)
Deprecated: Use Topic_PartitionConfig_Capacity.ProtoReflect.Descriptor instead.
func (*Topic_PartitionConfig_Capacity) GetPublishMibPerSec ¶
func (x *Topic_PartitionConfig_Capacity) GetPublishMibPerSec() int32
func (*Topic_PartitionConfig_Capacity) GetSubscribeMibPerSec ¶
func (x *Topic_PartitionConfig_Capacity) GetSubscribeMibPerSec() int32
func (*Topic_PartitionConfig_Capacity) ProtoMessage ¶
func (*Topic_PartitionConfig_Capacity) ProtoMessage()
func (*Topic_PartitionConfig_Capacity) ProtoReflect ¶
func (x *Topic_PartitionConfig_Capacity) ProtoReflect() protoreflect.Message
func (*Topic_PartitionConfig_Capacity) Reset ¶
func (x *Topic_PartitionConfig_Capacity) Reset()
func (*Topic_PartitionConfig_Capacity) String ¶
func (x *Topic_PartitionConfig_Capacity) String() string
type Topic_PartitionConfig_Capacity_ ¶
type Topic_PartitionConfig_Capacity_ struct { // The capacity configuration. Capacity *Topic_PartitionConfig_Capacity `protobuf:"bytes,3,opt,name=capacity,proto3,oneof"` }
type Topic_PartitionConfig_Scale ¶
type Topic_PartitionConfig_Scale struct { // DEPRECATED: Use capacity instead which can express a superset of // configurations. // // Every partition in the topic is allocated throughput equivalent to // `scale` times the standard partition throughput (4 MiB/s). This is also // reflected in the cost of this topic; a topic with `scale` of 2 and // count of 10 is charged for 20 partitions. This value must be in the // range [1,4]. // // Deprecated: Marked as deprecated in google/cloud/pubsublite/v1/common.proto. Scale int32 `protobuf:"varint,2,opt,name=scale,proto3,oneof"` }
type Topic_ReservationConfig ¶
type Topic_ReservationConfig struct { // The Reservation to use for this topic's throughput capacity. // Structured like: // projects/{project_number}/locations/{location}/reservations/{reservation_id} ThroughputReservation string `protobuf:"bytes,1,opt,name=throughput_reservation,json=throughputReservation,proto3" json:"throughput_reservation,omitempty"` // contains filtered or unexported fields }
The settings for this topic's Reservation usage.
func (*Topic_ReservationConfig) Descriptor ¶
func (*Topic_ReservationConfig) Descriptor() ([]byte, []int)
Deprecated: Use Topic_ReservationConfig.ProtoReflect.Descriptor instead.
func (*Topic_ReservationConfig) GetThroughputReservation ¶
func (x *Topic_ReservationConfig) GetThroughputReservation() string
func (*Topic_ReservationConfig) ProtoMessage ¶
func (*Topic_ReservationConfig) ProtoMessage()
func (*Topic_ReservationConfig) ProtoReflect ¶
func (x *Topic_ReservationConfig) ProtoReflect() protoreflect.Message
func (*Topic_ReservationConfig) Reset ¶
func (x *Topic_ReservationConfig) Reset()
func (*Topic_ReservationConfig) String ¶
func (x *Topic_ReservationConfig) String() string
type Topic_RetentionConfig ¶
type Topic_RetentionConfig struct { // The provisioned storage, in bytes, per partition. If the number of bytes // stored in any of the topic's partitions grows beyond this value, older // messages will be dropped to make room for newer ones, regardless of the // value of `period`. PerPartitionBytes int64 `protobuf:"varint,1,opt,name=per_partition_bytes,json=perPartitionBytes,proto3" json:"per_partition_bytes,omitempty"` // How long a published message is retained. If unset, messages will be // retained as long as the bytes retained for each partition is below // `per_partition_bytes`. Period *durationpb.Duration `protobuf:"bytes,2,opt,name=period,proto3" json:"period,omitempty"` // contains filtered or unexported fields }
The settings for a topic's message retention.
func (*Topic_RetentionConfig) Descriptor ¶
func (*Topic_RetentionConfig) Descriptor() ([]byte, []int)
Deprecated: Use Topic_RetentionConfig.ProtoReflect.Descriptor instead.
func (*Topic_RetentionConfig) GetPerPartitionBytes ¶
func (x *Topic_RetentionConfig) GetPerPartitionBytes() int64
func (*Topic_RetentionConfig) GetPeriod ¶
func (x *Topic_RetentionConfig) GetPeriod() *durationpb.Duration
func (*Topic_RetentionConfig) ProtoMessage ¶
func (*Topic_RetentionConfig) ProtoMessage()
func (*Topic_RetentionConfig) ProtoReflect ¶
func (x *Topic_RetentionConfig) ProtoReflect() protoreflect.Message
func (*Topic_RetentionConfig) Reset ¶
func (x *Topic_RetentionConfig) Reset()
func (*Topic_RetentionConfig) String ¶
func (x *Topic_RetentionConfig) String() string
type UnimplementedAdminServiceServer ¶
type UnimplementedAdminServiceServer struct { }
UnimplementedAdminServiceServer can be embedded to have forward compatible implementations.
func (*UnimplementedAdminServiceServer) CreateReservation ¶
func (*UnimplementedAdminServiceServer) CreateReservation(context.Context, *CreateReservationRequest) (*Reservation, error)
func (*UnimplementedAdminServiceServer) CreateSubscription ¶
func (*UnimplementedAdminServiceServer) CreateSubscription(context.Context, *CreateSubscriptionRequest) (*Subscription, error)
func (*UnimplementedAdminServiceServer) CreateTopic ¶
func (*UnimplementedAdminServiceServer) CreateTopic(context.Context, *CreateTopicRequest) (*Topic, error)
func (*UnimplementedAdminServiceServer) DeleteReservation ¶
func (*UnimplementedAdminServiceServer) DeleteReservation(context.Context, *DeleteReservationRequest) (*emptypb.Empty, error)
func (*UnimplementedAdminServiceServer) DeleteSubscription ¶
func (*UnimplementedAdminServiceServer) DeleteSubscription(context.Context, *DeleteSubscriptionRequest) (*emptypb.Empty, error)
func (*UnimplementedAdminServiceServer) DeleteTopic ¶
func (*UnimplementedAdminServiceServer) DeleteTopic(context.Context, *DeleteTopicRequest) (*emptypb.Empty, error)
func (*UnimplementedAdminServiceServer) GetReservation ¶
func (*UnimplementedAdminServiceServer) GetReservation(context.Context, *GetReservationRequest) (*Reservation, error)
func (*UnimplementedAdminServiceServer) GetSubscription ¶
func (*UnimplementedAdminServiceServer) GetSubscription(context.Context, *GetSubscriptionRequest) (*Subscription, error)
func (*UnimplementedAdminServiceServer) GetTopic ¶
func (*UnimplementedAdminServiceServer) GetTopic(context.Context, *GetTopicRequest) (*Topic, error)
func (*UnimplementedAdminServiceServer) GetTopicPartitions ¶
func (*UnimplementedAdminServiceServer) GetTopicPartitions(context.Context, *GetTopicPartitionsRequest) (*TopicPartitions, error)
func (*UnimplementedAdminServiceServer) ListReservationTopics ¶
func (*UnimplementedAdminServiceServer) ListReservationTopics(context.Context, *ListReservationTopicsRequest) (*ListReservationTopicsResponse, error)
func (*UnimplementedAdminServiceServer) ListReservations ¶
func (*UnimplementedAdminServiceServer) ListReservations(context.Context, *ListReservationsRequest) (*ListReservationsResponse, error)
func (*UnimplementedAdminServiceServer) ListSubscriptions ¶
func (*UnimplementedAdminServiceServer) ListSubscriptions(context.Context, *ListSubscriptionsRequest) (*ListSubscriptionsResponse, error)
func (*UnimplementedAdminServiceServer) ListTopicSubscriptions ¶
func (*UnimplementedAdminServiceServer) ListTopicSubscriptions(context.Context, *ListTopicSubscriptionsRequest) (*ListTopicSubscriptionsResponse, error)
func (*UnimplementedAdminServiceServer) ListTopics ¶
func (*UnimplementedAdminServiceServer) ListTopics(context.Context, *ListTopicsRequest) (*ListTopicsResponse, error)
func (*UnimplementedAdminServiceServer) SeekSubscription ¶
func (*UnimplementedAdminServiceServer) SeekSubscription(context.Context, *SeekSubscriptionRequest) (*longrunningpb.Operation, error)
func (*UnimplementedAdminServiceServer) UpdateReservation ¶
func (*UnimplementedAdminServiceServer) UpdateReservation(context.Context, *UpdateReservationRequest) (*Reservation, error)
func (*UnimplementedAdminServiceServer) UpdateSubscription ¶
func (*UnimplementedAdminServiceServer) UpdateSubscription(context.Context, *UpdateSubscriptionRequest) (*Subscription, error)
func (*UnimplementedAdminServiceServer) UpdateTopic ¶
func (*UnimplementedAdminServiceServer) UpdateTopic(context.Context, *UpdateTopicRequest) (*Topic, error)
type UnimplementedCursorServiceServer ¶
type UnimplementedCursorServiceServer struct { }
UnimplementedCursorServiceServer can be embedded to have forward compatible implementations.
func (*UnimplementedCursorServiceServer) CommitCursor ¶
func (*UnimplementedCursorServiceServer) CommitCursor(context.Context, *CommitCursorRequest) (*CommitCursorResponse, error)
func (*UnimplementedCursorServiceServer) ListPartitionCursors ¶
func (*UnimplementedCursorServiceServer) ListPartitionCursors(context.Context, *ListPartitionCursorsRequest) (*ListPartitionCursorsResponse, error)
func (*UnimplementedCursorServiceServer) StreamingCommitCursor ¶
func (*UnimplementedCursorServiceServer) StreamingCommitCursor(CursorService_StreamingCommitCursorServer) error
type UnimplementedPartitionAssignmentServiceServer ¶
type UnimplementedPartitionAssignmentServiceServer struct { }
UnimplementedPartitionAssignmentServiceServer can be embedded to have forward compatible implementations.
func (*UnimplementedPartitionAssignmentServiceServer) AssignPartitions ¶
func (*UnimplementedPartitionAssignmentServiceServer) AssignPartitions(PartitionAssignmentService_AssignPartitionsServer) error
type UnimplementedPublisherServiceServer ¶
type UnimplementedPublisherServiceServer struct { }
UnimplementedPublisherServiceServer can be embedded to have forward compatible implementations.
func (*UnimplementedPublisherServiceServer) Publish ¶
func (*UnimplementedPublisherServiceServer) Publish(PublisherService_PublishServer) error
type UnimplementedSubscriberServiceServer ¶
type UnimplementedSubscriberServiceServer struct { }
UnimplementedSubscriberServiceServer can be embedded to have forward compatible implementations.
func (*UnimplementedSubscriberServiceServer) Subscribe ¶
func (*UnimplementedSubscriberServiceServer) Subscribe(SubscriberService_SubscribeServer) error
type UnimplementedTopicStatsServiceServer ¶
type UnimplementedTopicStatsServiceServer struct { }
UnimplementedTopicStatsServiceServer can be embedded to have forward compatible implementations.
func (*UnimplementedTopicStatsServiceServer) ComputeHeadCursor ¶
func (*UnimplementedTopicStatsServiceServer) ComputeHeadCursor(context.Context, *ComputeHeadCursorRequest) (*ComputeHeadCursorResponse, error)
func (*UnimplementedTopicStatsServiceServer) ComputeMessageStats ¶
func (*UnimplementedTopicStatsServiceServer) ComputeMessageStats(context.Context, *ComputeMessageStatsRequest) (*ComputeMessageStatsResponse, error)
func (*UnimplementedTopicStatsServiceServer) ComputeTimeCursor ¶
func (*UnimplementedTopicStatsServiceServer) ComputeTimeCursor(context.Context, *ComputeTimeCursorRequest) (*ComputeTimeCursorResponse, error)
type UpdateReservationRequest ¶
type UpdateReservationRequest struct { // Required. The reservation to update. Its `name` field must be populated. Reservation *Reservation `protobuf:"bytes,1,opt,name=reservation,proto3" json:"reservation,omitempty"` // Required. A mask specifying the reservation fields to change. UpdateMask *fieldmaskpb.FieldMask `protobuf:"bytes,2,opt,name=update_mask,json=updateMask,proto3" json:"update_mask,omitempty"` // contains filtered or unexported fields }
Request for UpdateReservation.
func (*UpdateReservationRequest) Descriptor ¶
func (*UpdateReservationRequest) Descriptor() ([]byte, []int)
Deprecated: Use UpdateReservationRequest.ProtoReflect.Descriptor instead.
func (*UpdateReservationRequest) GetReservation ¶
func (x *UpdateReservationRequest) GetReservation() *Reservation
func (*UpdateReservationRequest) GetUpdateMask ¶
func (x *UpdateReservationRequest) GetUpdateMask() *fieldmaskpb.FieldMask
func (*UpdateReservationRequest) ProtoMessage ¶
func (*UpdateReservationRequest) ProtoMessage()
func (*UpdateReservationRequest) ProtoReflect ¶
func (x *UpdateReservationRequest) ProtoReflect() protoreflect.Message
func (*UpdateReservationRequest) Reset ¶
func (x *UpdateReservationRequest) Reset()
func (*UpdateReservationRequest) String ¶
func (x *UpdateReservationRequest) String() string
type UpdateSubscriptionRequest ¶
type UpdateSubscriptionRequest struct { // Required. The subscription to update. Its `name` field must be populated. // Topic field must not be populated. Subscription *Subscription `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"` // Required. A mask specifying the subscription fields to change. UpdateMask *fieldmaskpb.FieldMask `protobuf:"bytes,2,opt,name=update_mask,json=updateMask,proto3" json:"update_mask,omitempty"` // contains filtered or unexported fields }
Request for UpdateSubscription.
func (*UpdateSubscriptionRequest) Descriptor ¶
func (*UpdateSubscriptionRequest) Descriptor() ([]byte, []int)
Deprecated: Use UpdateSubscriptionRequest.ProtoReflect.Descriptor instead.
func (*UpdateSubscriptionRequest) GetSubscription ¶
func (x *UpdateSubscriptionRequest) GetSubscription() *Subscription
func (*UpdateSubscriptionRequest) GetUpdateMask ¶
func (x *UpdateSubscriptionRequest) GetUpdateMask() *fieldmaskpb.FieldMask
func (*UpdateSubscriptionRequest) ProtoMessage ¶
func (*UpdateSubscriptionRequest) ProtoMessage()
func (*UpdateSubscriptionRequest) ProtoReflect ¶
func (x *UpdateSubscriptionRequest) ProtoReflect() protoreflect.Message
func (*UpdateSubscriptionRequest) Reset ¶
func (x *UpdateSubscriptionRequest) Reset()
func (*UpdateSubscriptionRequest) String ¶
func (x *UpdateSubscriptionRequest) String() string
type UpdateTopicRequest ¶
type UpdateTopicRequest struct { // Required. The topic to update. Its `name` field must be populated. Topic *Topic `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"` // Required. A mask specifying the topic fields to change. UpdateMask *fieldmaskpb.FieldMask `protobuf:"bytes,2,opt,name=update_mask,json=updateMask,proto3" json:"update_mask,omitempty"` // contains filtered or unexported fields }
Request for UpdateTopic.
func (*UpdateTopicRequest) Descriptor ¶
func (*UpdateTopicRequest) Descriptor() ([]byte, []int)
Deprecated: Use UpdateTopicRequest.ProtoReflect.Descriptor instead.
func (*UpdateTopicRequest) GetTopic ¶
func (x *UpdateTopicRequest) GetTopic() *Topic
func (*UpdateTopicRequest) GetUpdateMask ¶
func (x *UpdateTopicRequest) GetUpdateMask() *fieldmaskpb.FieldMask
func (*UpdateTopicRequest) ProtoMessage ¶
func (*UpdateTopicRequest) ProtoMessage()
func (*UpdateTopicRequest) ProtoReflect ¶
func (x *UpdateTopicRequest) ProtoReflect() protoreflect.Message
func (*UpdateTopicRequest) Reset ¶
func (x *UpdateTopicRequest) Reset()
func (*UpdateTopicRequest) String ¶
func (x *UpdateTopicRequest) String() string
Source Files ¶
admin.pb.go common.pb.go cursor.pb.go publisher.pb.go subscriber.pb.go topic_stats.pb.go
- Version
- v1.8.2 (latest)
- Published
- Jun 5, 2024
- Platform
- linux/amd64
- Imports
- 14 packages
- Last checked
- 5 days ago –
Tools for package owners.