Variables
SeekSubscriptionRequest_NamedTarget_name, SeekSubscriptionRequest_NamedTarget_value
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.
Subscription_DeliveryConfig_DeliveryRequirement_name, Subscription_DeliveryConfig_DeliveryRequirement_value
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.
ExportConfig_State_name, ExportConfig_State_value
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.
SeekRequest_NamedTarget_name, SeekRequest_NamedTarget_value
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.
File_google_cloud_pubsublite_v1_admin_proto
var File_google_cloud_pubsublite_v1_admin_proto protoreflect.FileDescriptor
File_google_cloud_pubsublite_v1_common_proto
var File_google_cloud_pubsublite_v1_common_proto protoreflect.FileDescriptor
File_google_cloud_pubsublite_v1_cursor_proto
var File_google_cloud_pubsublite_v1_cursor_proto protoreflect.FileDescriptor
File_google_cloud_pubsublite_v1_publisher_proto
var File_google_cloud_pubsublite_v1_publisher_proto protoreflect.FileDescriptor
File_google_cloud_pubsublite_v1_subscriber_proto
var File_google_cloud_pubsublite_v1_subscriber_proto protoreflect.FileDescriptor
File_google_cloud_pubsublite_v1_topic_stats_proto
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)
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
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.
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
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
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
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
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
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
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
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
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
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
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
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
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
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
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.
CursorService_StreamingCommitCursorClient
type CursorService_StreamingCommitCursorClient interface {
Send(*StreamingCommitCursorRequest) error
Recv() (*StreamingCommitCursorResponse, error)
grpc.ClientStream
}
CursorService_StreamingCommitCursorServer
type CursorService_StreamingCommitCursorServer interface {
Send(*StreamingCommitCursorResponse) error
Recv() (*StreamingCommitCursorRequest, error)
grpc.ServerStream
}
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
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
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
ExportConfig
type ExportConfig struct {
DesiredState ExportConfig_State "" /* 149 byte string literal not displayed */
CurrentState ExportConfig_State "" /* 149 byte string literal not displayed */
DeadLetterTopic string `protobuf:"bytes,5,opt,name=dead_letter_topic,json=deadLetterTopic,proto3" json:"dead_letter_topic,omitempty"`
Destination isExportConfig_Destination `protobuf_oneof:"destination"`
}
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
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
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"`
}
ExportConfig_State
type ExportConfig_State int32
The desired export state.
ExportConfig_STATE_UNSPECIFIED, ExportConfig_ACTIVE, ExportConfig_PAUSED, ExportConfig_PERMISSION_DENIED, ExportConfig_NOT_FOUND
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
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
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
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
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
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
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
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
InitialPartitionAssignmentRequest
type InitialPartitionAssignmentRequest struct {
// The subscription name. Structured like:
// projects/
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
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
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
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
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
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
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
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
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
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
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
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
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
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.