pubsubpb

package
v1.37.0 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Mar 7, 2024 License: Apache-2.0 Imports: 13 Imported by: 24

Documentation

Index

Constants

This section is empty.

Variables

View Source
var (
	IngestionDataSourceSettings_AwsKinesis_State_name = map[int32]string{
		0: "STATE_UNSPECIFIED",
		1: "ACTIVE",
		2: "KINESIS_PERMISSION_DENIED",
		3: "PUBLISH_PERMISSION_DENIED",
		4: "STREAM_NOT_FOUND",
		5: "CONSUMER_NOT_FOUND",
	}
	IngestionDataSourceSettings_AwsKinesis_State_value = map[string]int32{
		"STATE_UNSPECIFIED":         0,
		"ACTIVE":                    1,
		"KINESIS_PERMISSION_DENIED": 2,
		"PUBLISH_PERMISSION_DENIED": 3,
		"STREAM_NOT_FOUND":          4,
		"CONSUMER_NOT_FOUND":        5,
	}
)

Enum value maps for IngestionDataSourceSettings_AwsKinesis_State.

View Source
var (
	Topic_State_name = map[int32]string{
		0: "STATE_UNSPECIFIED",
		1: "ACTIVE",
		2: "INGESTION_RESOURCE_ERROR",
	}
	Topic_State_value = map[string]int32{
		"STATE_UNSPECIFIED":        0,
		"ACTIVE":                   1,
		"INGESTION_RESOURCE_ERROR": 2,
	}
)

Enum value maps for Topic_State.

View Source
var (
	Subscription_State_name = map[int32]string{
		0: "STATE_UNSPECIFIED",
		1: "ACTIVE",
		2: "RESOURCE_ERROR",
	}
	Subscription_State_value = map[string]int32{
		"STATE_UNSPECIFIED": 0,
		"ACTIVE":            1,
		"RESOURCE_ERROR":    2,
	}
)

Enum value maps for Subscription_State.

View Source
var (
	BigQueryConfig_State_name = map[int32]string{
		0: "STATE_UNSPECIFIED",
		1: "ACTIVE",
		2: "PERMISSION_DENIED",
		3: "NOT_FOUND",
		4: "SCHEMA_MISMATCH",
		5: "IN_TRANSIT_LOCATION_RESTRICTION",
	}
	BigQueryConfig_State_value = map[string]int32{
		"STATE_UNSPECIFIED":               0,
		"ACTIVE":                          1,
		"PERMISSION_DENIED":               2,
		"NOT_FOUND":                       3,
		"SCHEMA_MISMATCH":                 4,
		"IN_TRANSIT_LOCATION_RESTRICTION": 5,
	}
)

Enum value maps for BigQueryConfig_State.

View Source
var (
	CloudStorageConfig_State_name = map[int32]string{
		0: "STATE_UNSPECIFIED",
		1: "ACTIVE",
		2: "PERMISSION_DENIED",
		3: "NOT_FOUND",
		4: "IN_TRANSIT_LOCATION_RESTRICTION",
	}
	CloudStorageConfig_State_value = map[string]int32{
		"STATE_UNSPECIFIED":               0,
		"ACTIVE":                          1,
		"PERMISSION_DENIED":               2,
		"NOT_FOUND":                       3,
		"IN_TRANSIT_LOCATION_RESTRICTION": 4,
	}
)

Enum value maps for CloudStorageConfig_State.

View Source
var (
	SchemaView_name = map[int32]string{
		0: "SCHEMA_VIEW_UNSPECIFIED",
		1: "BASIC",
		2: "FULL",
	}
	SchemaView_value = map[string]int32{
		"SCHEMA_VIEW_UNSPECIFIED": 0,
		"BASIC":                   1,
		"FULL":                    2,
	}
)

Enum value maps for SchemaView.

View Source
var (
	Encoding_name = map[int32]string{
		0: "ENCODING_UNSPECIFIED",
		1: "JSON",
		2: "BINARY",
	}
	Encoding_value = map[string]int32{
		"ENCODING_UNSPECIFIED": 0,
		"JSON":                 1,
		"BINARY":               2,
	}
)

Enum value maps for Encoding.

View Source
var (
	Schema_Type_name = map[int32]string{
		0: "TYPE_UNSPECIFIED",
		1: "PROTOCOL_BUFFER",
		2: "AVRO",
	}
	Schema_Type_value = map[string]int32{
		"TYPE_UNSPECIFIED": 0,
		"PROTOCOL_BUFFER":  1,
		"AVRO":             2,
	}
)

Enum value maps for Schema_Type.

View Source
var File_google_pubsub_v1_pubsub_proto protoreflect.FileDescriptor
View Source
var File_google_pubsub_v1_schema_proto protoreflect.FileDescriptor

Functions

func RegisterPublisherServer

func RegisterPublisherServer(s *grpc.Server, srv PublisherServer)

func RegisterSchemaServiceServer

func RegisterSchemaServiceServer(s *grpc.Server, srv SchemaServiceServer)

func RegisterSubscriberServer

func RegisterSubscriberServer(s *grpc.Server, srv SubscriberServer)

Types

type AcknowledgeRequest

type AcknowledgeRequest struct {

	// Required. The subscription whose message is being acknowledged.
	// Format is `projects/{project}/subscriptions/{sub}`.
	Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// Required. The acknowledgment ID for the messages being acknowledged that
	// was returned by the Pub/Sub system in the `Pull` response. Must not be
	// empty.
	AckIds []string `protobuf:"bytes,2,rep,name=ack_ids,json=ackIds,proto3" json:"ack_ids,omitempty"`
	// contains filtered or unexported fields
}

Request for the Acknowledge method.

func (*AcknowledgeRequest) Descriptor deprecated

func (*AcknowledgeRequest) Descriptor() ([]byte, []int)

Deprecated: Use AcknowledgeRequest.ProtoReflect.Descriptor instead.

func (*AcknowledgeRequest) GetAckIds

func (x *AcknowledgeRequest) GetAckIds() []string

func (*AcknowledgeRequest) GetSubscription

func (x *AcknowledgeRequest) GetSubscription() string

func (*AcknowledgeRequest) ProtoMessage

func (*AcknowledgeRequest) ProtoMessage()

func (*AcknowledgeRequest) ProtoReflect

func (x *AcknowledgeRequest) ProtoReflect() protoreflect.Message

func (*AcknowledgeRequest) Reset

func (x *AcknowledgeRequest) Reset()

func (*AcknowledgeRequest) String

func (x *AcknowledgeRequest) String() string

type BigQueryConfig

type BigQueryConfig struct {

	// Optional. The name of the table to which to write data, of the form
	// {projectId}.{datasetId}.{tableId}
	Table string `protobuf:"bytes,1,opt,name=table,proto3" json:"table,omitempty"`
	// Optional. When true, use the topic's schema as the columns to write to in
	// BigQuery, if it exists. `use_topic_schema` and `use_table_schema` cannot be
	// enabled at the same time.
	UseTopicSchema bool `protobuf:"varint,2,opt,name=use_topic_schema,json=useTopicSchema,proto3" json:"use_topic_schema,omitempty"`
	// Optional. When true, write the subscription name, message_id, publish_time,
	// attributes, and ordering_key to additional columns in the table. The
	// subscription name, message_id, and publish_time fields are put in their own
	// columns while all other message properties (other than data) are written to
	// a JSON object in the attributes column.
	WriteMetadata bool `protobuf:"varint,3,opt,name=write_metadata,json=writeMetadata,proto3" json:"write_metadata,omitempty"`
	// Optional. When true and use_topic_schema is true, any fields that are a
	// part of the topic schema that are not part of the BigQuery table schema are
	// dropped when writing to BigQuery. Otherwise, the schemas must be kept in
	// sync and any messages with extra fields are not written and remain in the
	// subscription's backlog.
	DropUnknownFields bool `protobuf:"varint,4,opt,name=drop_unknown_fields,json=dropUnknownFields,proto3" json:"drop_unknown_fields,omitempty"`
	// Output only. An output-only field that indicates whether or not the
	// subscription can receive messages.
	State BigQueryConfig_State `protobuf:"varint,5,opt,name=state,proto3,enum=google.pubsub.v1.BigQueryConfig_State" json:"state,omitempty"`
	// Optional. When true, use the BigQuery table's schema as the columns to
	// write to in BigQuery. `use_table_schema` and `use_topic_schema` cannot be
	// enabled at the same time.
	UseTableSchema bool `protobuf:"varint,6,opt,name=use_table_schema,json=useTableSchema,proto3" json:"use_table_schema,omitempty"`
	// contains filtered or unexported fields
}

Configuration for a BigQuery subscription.

func (*BigQueryConfig) Descriptor deprecated

func (*BigQueryConfig) Descriptor() ([]byte, []int)

Deprecated: Use BigQueryConfig.ProtoReflect.Descriptor instead.

func (*BigQueryConfig) GetDropUnknownFields

func (x *BigQueryConfig) GetDropUnknownFields() bool

func (*BigQueryConfig) GetState

func (x *BigQueryConfig) GetState() BigQueryConfig_State

func (*BigQueryConfig) GetTable

func (x *BigQueryConfig) GetTable() string

func (*BigQueryConfig) GetUseTableSchema added in v1.34.0

func (x *BigQueryConfig) GetUseTableSchema() bool

func (*BigQueryConfig) GetUseTopicSchema

func (x *BigQueryConfig) GetUseTopicSchema() bool

func (*BigQueryConfig) GetWriteMetadata

func (x *BigQueryConfig) GetWriteMetadata() bool

func (*BigQueryConfig) ProtoMessage

func (*BigQueryConfig) ProtoMessage()

func (*BigQueryConfig) ProtoReflect

func (x *BigQueryConfig) ProtoReflect() protoreflect.Message

func (*BigQueryConfig) Reset

func (x *BigQueryConfig) Reset()

func (*BigQueryConfig) String

func (x *BigQueryConfig) String() string

type BigQueryConfig_State

type BigQueryConfig_State int32

Possible states for a BigQuery subscription.

const (
	// Default value. This value is unused.
	BigQueryConfig_STATE_UNSPECIFIED BigQueryConfig_State = 0
	// The subscription can actively send messages to BigQuery
	BigQueryConfig_ACTIVE BigQueryConfig_State = 1
	// Cannot write to the BigQuery table because of permission denied errors.
	// This can happen if
	// - Pub/Sub SA has not been granted the [appropriate BigQuery IAM
	// permissions](https://cloud.google.com/pubsub/docs/create-subscription#assign_bigquery_service_account)
	// - bigquery.googleapis.com API is not enabled for the project
	// ([instructions](https://cloud.google.com/service-usage/docs/enable-disable))
	BigQueryConfig_PERMISSION_DENIED BigQueryConfig_State = 2
	// Cannot write to the BigQuery table because it does not exist.
	BigQueryConfig_NOT_FOUND BigQueryConfig_State = 3
	// Cannot write to the BigQuery table due to a schema mismatch.
	BigQueryConfig_SCHEMA_MISMATCH BigQueryConfig_State = 4
	// Cannot write to the destination because enforce_in_transit is set to true
	// and the destination locations are not in the allowed regions.
	BigQueryConfig_IN_TRANSIT_LOCATION_RESTRICTION BigQueryConfig_State = 5
)

func (BigQueryConfig_State) Descriptor

func (BigQueryConfig_State) Enum

func (BigQueryConfig_State) EnumDescriptor deprecated

func (BigQueryConfig_State) EnumDescriptor() ([]byte, []int)

Deprecated: Use BigQueryConfig_State.Descriptor instead.

func (BigQueryConfig_State) Number

func (BigQueryConfig_State) String

func (x BigQueryConfig_State) String() string

func (BigQueryConfig_State) Type

type CloudStorageConfig added in v1.31.0

type CloudStorageConfig struct {

	// Required. User-provided name for the Cloud Storage bucket.
	// The bucket must be created by the user. The bucket name must be without
	// any prefix like "gs://". See the [bucket naming
	// requirements] (https://cloud.google.com/storage/docs/buckets#naming).
	Bucket string `protobuf:"bytes,1,opt,name=bucket,proto3" json:"bucket,omitempty"`
	// Optional. User-provided prefix for Cloud Storage filename. See the [object
	// naming requirements](https://cloud.google.com/storage/docs/objects#naming).
	FilenamePrefix string `protobuf:"bytes,2,opt,name=filename_prefix,json=filenamePrefix,proto3" json:"filename_prefix,omitempty"`
	// Optional. User-provided suffix for Cloud Storage filename. See the [object
	// naming requirements](https://cloud.google.com/storage/docs/objects#naming).
	// Must not end in "/".
	FilenameSuffix string `protobuf:"bytes,3,opt,name=filename_suffix,json=filenameSuffix,proto3" json:"filename_suffix,omitempty"`
	// Defaults to text format.
	//
	// Types that are assignable to OutputFormat:
	//
	//	*CloudStorageConfig_TextConfig_
	//	*CloudStorageConfig_AvroConfig_
	OutputFormat isCloudStorageConfig_OutputFormat `protobuf_oneof:"output_format"`
	// Optional. The maximum duration that can elapse before a new Cloud Storage
	// file is created. Min 1 minute, max 10 minutes, default 5 minutes. May not
	// exceed the subscription's acknowledgement deadline.
	MaxDuration *durationpb.Duration `protobuf:"bytes,6,opt,name=max_duration,json=maxDuration,proto3" json:"max_duration,omitempty"`
	// Optional. The maximum bytes that can be written to a Cloud Storage file
	// before a new file is created. Min 1 KB, max 10 GiB. The max_bytes limit may
	// be exceeded in cases where messages are larger than the limit.
	MaxBytes int64 `protobuf:"varint,7,opt,name=max_bytes,json=maxBytes,proto3" json:"max_bytes,omitempty"`
	// Output only. An output-only field that indicates whether or not the
	// subscription can receive messages.
	State CloudStorageConfig_State `protobuf:"varint,9,opt,name=state,proto3,enum=google.pubsub.v1.CloudStorageConfig_State" json:"state,omitempty"`
	// contains filtered or unexported fields
}

Configuration for a Cloud Storage subscription.

func (*CloudStorageConfig) Descriptor deprecated added in v1.31.0

func (*CloudStorageConfig) Descriptor() ([]byte, []int)

Deprecated: Use CloudStorageConfig.ProtoReflect.Descriptor instead.

func (*CloudStorageConfig) GetAvroConfig added in v1.31.0

func (*CloudStorageConfig) GetBucket added in v1.31.0

func (x *CloudStorageConfig) GetBucket() string

func (*CloudStorageConfig) GetFilenamePrefix added in v1.31.0

func (x *CloudStorageConfig) GetFilenamePrefix() string

func (*CloudStorageConfig) GetFilenameSuffix added in v1.31.0

func (x *CloudStorageConfig) GetFilenameSuffix() string

func (*CloudStorageConfig) GetMaxBytes added in v1.31.0

func (x *CloudStorageConfig) GetMaxBytes() int64

func (*CloudStorageConfig) GetMaxDuration added in v1.31.0

func (x *CloudStorageConfig) GetMaxDuration() *durationpb.Duration

func (*CloudStorageConfig) GetOutputFormat added in v1.31.0

func (m *CloudStorageConfig) GetOutputFormat() isCloudStorageConfig_OutputFormat

func (*CloudStorageConfig) GetState added in v1.31.0

func (*CloudStorageConfig) GetTextConfig added in v1.31.0

func (*CloudStorageConfig) ProtoMessage added in v1.31.0

func (*CloudStorageConfig) ProtoMessage()

func (*CloudStorageConfig) ProtoReflect added in v1.31.0

func (x *CloudStorageConfig) ProtoReflect() protoreflect.Message

func (*CloudStorageConfig) Reset added in v1.31.0

func (x *CloudStorageConfig) Reset()

func (*CloudStorageConfig) String added in v1.31.0

func (x *CloudStorageConfig) String() string

type CloudStorageConfig_AvroConfig added in v1.31.0

type CloudStorageConfig_AvroConfig struct {

	// Optional. When true, write the subscription name, message_id,
	// publish_time, attributes, and ordering_key as additional fields in the
	// output. The subscription name, message_id, and publish_time fields are
	// put in their own fields while all other message properties other than
	// data (for example, an ordering_key, if present) are added as entries in
	// the attributes map.
	WriteMetadata bool `protobuf:"varint,1,opt,name=write_metadata,json=writeMetadata,proto3" json:"write_metadata,omitempty"`
	// contains filtered or unexported fields
}

Configuration for writing message data in Avro format. Message payloads and metadata will be written to files as an Avro binary.

func (*CloudStorageConfig_AvroConfig) Descriptor deprecated added in v1.31.0

func (*CloudStorageConfig_AvroConfig) Descriptor() ([]byte, []int)

Deprecated: Use CloudStorageConfig_AvroConfig.ProtoReflect.Descriptor instead.

func (*CloudStorageConfig_AvroConfig) GetWriteMetadata added in v1.31.0

func (x *CloudStorageConfig_AvroConfig) GetWriteMetadata() bool

func (*CloudStorageConfig_AvroConfig) ProtoMessage added in v1.31.0

func (*CloudStorageConfig_AvroConfig) ProtoMessage()

func (*CloudStorageConfig_AvroConfig) ProtoReflect added in v1.31.0

func (*CloudStorageConfig_AvroConfig) Reset added in v1.31.0

func (x *CloudStorageConfig_AvroConfig) Reset()

func (*CloudStorageConfig_AvroConfig) String added in v1.31.0

type CloudStorageConfig_AvroConfig_ added in v1.31.0

type CloudStorageConfig_AvroConfig_ struct {
	// Optional. If set, message data will be written to Cloud Storage in Avro
	// format.
	AvroConfig *CloudStorageConfig_AvroConfig `protobuf:"bytes,5,opt,name=avro_config,json=avroConfig,proto3,oneof"`
}

type CloudStorageConfig_State added in v1.31.0

type CloudStorageConfig_State int32

Possible states for a Cloud Storage subscription.

const (
	// Default value. This value is unused.
	CloudStorageConfig_STATE_UNSPECIFIED CloudStorageConfig_State = 0
	// The subscription can actively send messages to Cloud Storage.
	CloudStorageConfig_ACTIVE CloudStorageConfig_State = 1
	// Cannot write to the Cloud Storage bucket because of permission denied
	// errors.
	CloudStorageConfig_PERMISSION_DENIED CloudStorageConfig_State = 2
	// Cannot write to the Cloud Storage bucket because it does not exist.
	CloudStorageConfig_NOT_FOUND CloudStorageConfig_State = 3
	// Cannot write to the destination because enforce_in_transit is set to true
	// and the destination locations are not in the allowed regions.
	CloudStorageConfig_IN_TRANSIT_LOCATION_RESTRICTION CloudStorageConfig_State = 4
)

func (CloudStorageConfig_State) Descriptor added in v1.31.0

func (CloudStorageConfig_State) Enum added in v1.31.0

func (CloudStorageConfig_State) EnumDescriptor deprecated added in v1.31.0

func (CloudStorageConfig_State) EnumDescriptor() ([]byte, []int)

Deprecated: Use CloudStorageConfig_State.Descriptor instead.

func (CloudStorageConfig_State) Number added in v1.31.0

func (CloudStorageConfig_State) String added in v1.31.0

func (x CloudStorageConfig_State) String() string

func (CloudStorageConfig_State) Type added in v1.31.0

type CloudStorageConfig_TextConfig added in v1.31.0

type CloudStorageConfig_TextConfig struct {
	// contains filtered or unexported fields
}

Configuration for writing message data in text format. Message payloads will be written to files as raw text, separated by a newline.

func (*CloudStorageConfig_TextConfig) Descriptor deprecated added in v1.31.0

func (*CloudStorageConfig_TextConfig) Descriptor() ([]byte, []int)

Deprecated: Use CloudStorageConfig_TextConfig.ProtoReflect.Descriptor instead.

func (*CloudStorageConfig_TextConfig) ProtoMessage added in v1.31.0

func (*CloudStorageConfig_TextConfig) ProtoMessage()

func (*CloudStorageConfig_TextConfig) ProtoReflect added in v1.31.0

func (*CloudStorageConfig_TextConfig) Reset added in v1.31.0

func (x *CloudStorageConfig_TextConfig) Reset()

func (*CloudStorageConfig_TextConfig) String added in v1.31.0

type CloudStorageConfig_TextConfig_ added in v1.31.0

type CloudStorageConfig_TextConfig_ struct {
	// Optional. If set, message data will be written to Cloud Storage in text
	// format.
	TextConfig *CloudStorageConfig_TextConfig `protobuf:"bytes,4,opt,name=text_config,json=textConfig,proto3,oneof"`
}

type CommitSchemaRequest added in v1.29.0

type CommitSchemaRequest struct {

	// Required. The name of the schema we are revising.
	// Format is `projects/{project}/schemas/{schema}`.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Required. The schema revision to commit.
	Schema *Schema `protobuf:"bytes,2,opt,name=schema,proto3" json:"schema,omitempty"`
	// contains filtered or unexported fields
}

Request for CommitSchema method.

func (*CommitSchemaRequest) Descriptor deprecated added in v1.29.0

func (*CommitSchemaRequest) Descriptor() ([]byte, []int)

Deprecated: Use CommitSchemaRequest.ProtoReflect.Descriptor instead.

func (*CommitSchemaRequest) GetName added in v1.29.0

func (x *CommitSchemaRequest) GetName() string

func (*CommitSchemaRequest) GetSchema added in v1.29.0

func (x *CommitSchemaRequest) GetSchema() *Schema

func (*CommitSchemaRequest) ProtoMessage added in v1.29.0

func (*CommitSchemaRequest) ProtoMessage()

func (*CommitSchemaRequest) ProtoReflect added in v1.29.0

func (x *CommitSchemaRequest) ProtoReflect() protoreflect.Message

func (*CommitSchemaRequest) Reset added in v1.29.0

func (x *CommitSchemaRequest) Reset()

func (*CommitSchemaRequest) String added in v1.29.0

func (x *CommitSchemaRequest) String() string

type CreateSchemaRequest

type CreateSchemaRequest struct {

	// Required. The name of the project in which to create the schema.
	// Format is `projects/{project-id}`.
	Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"`
	// Required. The schema object to create.
	//
	// This schema's `name` parameter is ignored. The schema object returned
	// by CreateSchema will have a `name` made using the given `parent` and
	// `schema_id`.
	Schema *Schema `protobuf:"bytes,2,opt,name=schema,proto3" json:"schema,omitempty"`
	// The ID to use for the schema, which will become the final component of
	// the schema's resource name.
	//
	// See https://cloud.google.com/pubsub/docs/pubsub-basics#resource_names for
	// resource name constraints.
	SchemaId string `protobuf:"bytes,3,opt,name=schema_id,json=schemaId,proto3" json:"schema_id,omitempty"`
	// contains filtered or unexported fields
}

Request for the CreateSchema method.

func (*CreateSchemaRequest) Descriptor deprecated

func (*CreateSchemaRequest) Descriptor() ([]byte, []int)

Deprecated: Use CreateSchemaRequest.ProtoReflect.Descriptor instead.

func (*CreateSchemaRequest) GetParent

func (x *CreateSchemaRequest) GetParent() string

func (*CreateSchemaRequest) GetSchema

func (x *CreateSchemaRequest) GetSchema() *Schema

func (*CreateSchemaRequest) GetSchemaId

func (x *CreateSchemaRequest) GetSchemaId() string

func (*CreateSchemaRequest) ProtoMessage

func (*CreateSchemaRequest) ProtoMessage()

func (*CreateSchemaRequest) ProtoReflect

func (x *CreateSchemaRequest) ProtoReflect() protoreflect.Message

func (*CreateSchemaRequest) Reset

func (x *CreateSchemaRequest) Reset()

func (*CreateSchemaRequest) String

func (x *CreateSchemaRequest) String() string

type CreateSnapshotRequest

type CreateSnapshotRequest struct {

	// Required. User-provided name for this snapshot. If the name is not provided
	// in the request, the server will assign a random name for this snapshot on
	// the same project as the subscription. Note that for REST API requests, you
	// must specify a name.  See the [resource name
	// rules](https://cloud.google.com/pubsub/docs/pubsub-basics#resource_names).
	// Format is `projects/{project}/snapshots/{snap}`.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Required. The subscription whose backlog the snapshot retains.
	// Specifically, the created snapshot is guaranteed to retain:
	//
	//	(a) The existing backlog on the subscription. More precisely, this is
	//	    defined as the messages in the subscription's backlog that are
	//	    unacknowledged upon the successful completion of the
	//	    `CreateSnapshot` request; as well as:
	//	(b) Any messages published to the subscription's topic following the
	//	    successful completion of the CreateSnapshot request.
	//
	// Format is `projects/{project}/subscriptions/{sub}`.
	Subscription string `protobuf:"bytes,2,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// Optional. See [Creating and managing
	// labels](https://cloud.google.com/pubsub/docs/labels).
	Labels map[string]string `` /* 153-byte string literal not displayed */
	// contains filtered or unexported fields
}

Request for the `CreateSnapshot` method.

func (*CreateSnapshotRequest) Descriptor deprecated

func (*CreateSnapshotRequest) Descriptor() ([]byte, []int)

Deprecated: Use CreateSnapshotRequest.ProtoReflect.Descriptor instead.

func (*CreateSnapshotRequest) GetLabels

func (x *CreateSnapshotRequest) GetLabels() map[string]string

func (*CreateSnapshotRequest) GetName

func (x *CreateSnapshotRequest) GetName() string

func (*CreateSnapshotRequest) GetSubscription

func (x *CreateSnapshotRequest) GetSubscription() string

func (*CreateSnapshotRequest) ProtoMessage

func (*CreateSnapshotRequest) ProtoMessage()

func (*CreateSnapshotRequest) ProtoReflect

func (x *CreateSnapshotRequest) ProtoReflect() protoreflect.Message

func (*CreateSnapshotRequest) Reset

func (x *CreateSnapshotRequest) Reset()

func (*CreateSnapshotRequest) String

func (x *CreateSnapshotRequest) String() string

type DeadLetterPolicy

type DeadLetterPolicy struct {

	// Optional. The name of the topic to which dead letter messages should be
	// published. Format is `projects/{project}/topics/{topic}`.The Pub/Sub
	// service account associated with the enclosing subscription's parent project
	// (i.e., service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must
	// have permission to Publish() to this topic.
	//
	// The operation will fail if the topic does not exist.
	// Users should ensure that there is a subscription attached to this topic
	// since messages published to a topic with no subscriptions are lost.
	DeadLetterTopic string `protobuf:"bytes,1,opt,name=dead_letter_topic,json=deadLetterTopic,proto3" json:"dead_letter_topic,omitempty"`
	// Optional. The maximum number of delivery attempts for any message. The
	// value must be between 5 and 100.
	//
	// The number of delivery attempts is defined as 1 + (the sum of number of
	// NACKs and number of times the acknowledgement deadline has been exceeded
	// for the message).
	//
	// A NACK is any call to ModifyAckDeadline with a 0 deadline. Note that
	// client libraries may automatically extend ack_deadlines.
	//
	// This field will be honored on a best effort basis.
	//
	// If this parameter is 0, a default value of 5 is used.
	MaxDeliveryAttempts int32 `protobuf:"varint,2,opt,name=max_delivery_attempts,json=maxDeliveryAttempts,proto3" json:"max_delivery_attempts,omitempty"`
	// contains filtered or unexported fields
}

Dead lettering is done on a best effort basis. The same message might be dead lettered multiple times.

If validation on any of the fields fails at subscription creation/updation, the create/update subscription request will fail.

func (*DeadLetterPolicy) Descriptor deprecated

func (*DeadLetterPolicy) Descriptor() ([]byte, []int)

Deprecated: Use DeadLetterPolicy.ProtoReflect.Descriptor instead.

func (*DeadLetterPolicy) GetDeadLetterTopic

func (x *DeadLetterPolicy) GetDeadLetterTopic() string

func (*DeadLetterPolicy) GetMaxDeliveryAttempts

func (x *DeadLetterPolicy) GetMaxDeliveryAttempts() int32

func (*DeadLetterPolicy) ProtoMessage

func (*DeadLetterPolicy) ProtoMessage()

func (*DeadLetterPolicy) ProtoReflect

func (x *DeadLetterPolicy) ProtoReflect() protoreflect.Message

func (*DeadLetterPolicy) Reset

func (x *DeadLetterPolicy) Reset()

func (*DeadLetterPolicy) String

func (x *DeadLetterPolicy) String() string

type DeleteSchemaRequest

type DeleteSchemaRequest struct {

	// Required. Name of the schema to delete.
	// Format is `projects/{project}/schemas/{schema}`.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// contains filtered or unexported fields
}

Request for the `DeleteSchema` method.

func (*DeleteSchemaRequest) Descriptor deprecated

func (*DeleteSchemaRequest) Descriptor() ([]byte, []int)

Deprecated: Use DeleteSchemaRequest.ProtoReflect.Descriptor instead.

func (*DeleteSchemaRequest) GetName

func (x *DeleteSchemaRequest) GetName() string

func (*DeleteSchemaRequest) ProtoMessage

func (*DeleteSchemaRequest) ProtoMessage()

func (*DeleteSchemaRequest) ProtoReflect

func (x *DeleteSchemaRequest) ProtoReflect() protoreflect.Message

func (*DeleteSchemaRequest) Reset

func (x *DeleteSchemaRequest) Reset()

func (*DeleteSchemaRequest) String

func (x *DeleteSchemaRequest) String() string

type DeleteSchemaRevisionRequest added in v1.29.0

type DeleteSchemaRevisionRequest struct {

	// Required. The name of the schema revision to be deleted, with a revision ID
	// explicitly included.
	//
	// Example: `projects/123/schemas/my-schema@c7cfa2a8`
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Optional. This field is deprecated and should not be used for specifying
	// the revision ID. The revision ID should be specified via the `name`
	// parameter.
	//
	// Deprecated: Marked as deprecated in google/pubsub/v1/schema.proto.
	RevisionId string `protobuf:"bytes,2,opt,name=revision_id,json=revisionId,proto3" json:"revision_id,omitempty"`
	// contains filtered or unexported fields
}

Request for the `DeleteSchemaRevision` method.

func (*DeleteSchemaRevisionRequest) Descriptor deprecated added in v1.29.0

func (*DeleteSchemaRevisionRequest) Descriptor() ([]byte, []int)

Deprecated: Use DeleteSchemaRevisionRequest.ProtoReflect.Descriptor instead.

func (*DeleteSchemaRevisionRequest) GetName added in v1.29.0

func (x *DeleteSchemaRevisionRequest) GetName() string

func (*DeleteSchemaRevisionRequest) GetRevisionId deprecated added in v1.29.0

func (x *DeleteSchemaRevisionRequest) GetRevisionId() string

Deprecated: Marked as deprecated in google/pubsub/v1/schema.proto.

func (*DeleteSchemaRevisionRequest) ProtoMessage added in v1.29.0

func (*DeleteSchemaRevisionRequest) ProtoMessage()

func (*DeleteSchemaRevisionRequest) ProtoReflect added in v1.29.0

func (*DeleteSchemaRevisionRequest) Reset added in v1.29.0

func (x *DeleteSchemaRevisionRequest) Reset()

func (*DeleteSchemaRevisionRequest) String added in v1.29.0

func (x *DeleteSchemaRevisionRequest) String() string

type DeleteSnapshotRequest

type DeleteSnapshotRequest struct {

	// Required. The name of the snapshot to delete.
	// Format is `projects/{project}/snapshots/{snap}`.
	Snapshot string `protobuf:"bytes,1,opt,name=snapshot,proto3" json:"snapshot,omitempty"`
	// contains filtered or unexported fields
}

Request for the `DeleteSnapshot` method.

func (*DeleteSnapshotRequest) Descriptor deprecated

func (*DeleteSnapshotRequest) Descriptor() ([]byte, []int)

Deprecated: Use DeleteSnapshotRequest.ProtoReflect.Descriptor instead.

func (*DeleteSnapshotRequest) GetSnapshot

func (x *DeleteSnapshotRequest) GetSnapshot() string

func (*DeleteSnapshotRequest) ProtoMessage

func (*DeleteSnapshotRequest) ProtoMessage()

func (*DeleteSnapshotRequest) ProtoReflect

func (x *DeleteSnapshotRequest) ProtoReflect() protoreflect.Message

func (*DeleteSnapshotRequest) Reset

func (x *DeleteSnapshotRequest) Reset()

func (*DeleteSnapshotRequest) String

func (x *DeleteSnapshotRequest) String() string

type DeleteSubscriptionRequest

type DeleteSubscriptionRequest struct {

	// Required. The subscription to delete.
	// Format is `projects/{project}/subscriptions/{sub}`.
	Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// contains filtered or unexported fields
}

Request for the DeleteSubscription method.

func (*DeleteSubscriptionRequest) Descriptor deprecated

func (*DeleteSubscriptionRequest) Descriptor() ([]byte, []int)

Deprecated: Use DeleteSubscriptionRequest.ProtoReflect.Descriptor instead.

func (*DeleteSubscriptionRequest) GetSubscription

func (x *DeleteSubscriptionRequest) GetSubscription() string

func (*DeleteSubscriptionRequest) ProtoMessage

func (*DeleteSubscriptionRequest) ProtoMessage()

func (*DeleteSubscriptionRequest) ProtoReflect

func (*DeleteSubscriptionRequest) Reset

func (x *DeleteSubscriptionRequest) Reset()

func (*DeleteSubscriptionRequest) String

func (x *DeleteSubscriptionRequest) String() string

type DeleteTopicRequest

type DeleteTopicRequest struct {

	// Required. Name of the topic to delete.
	// Format is `projects/{project}/topics/{topic}`.
	Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"`
	// contains filtered or unexported fields
}

Request for the `DeleteTopic` method.

func (*DeleteTopicRequest) Descriptor deprecated

func (*DeleteTopicRequest) Descriptor() ([]byte, []int)

Deprecated: Use DeleteTopicRequest.ProtoReflect.Descriptor instead.

func (*DeleteTopicRequest) GetTopic

func (x *DeleteTopicRequest) GetTopic() 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 DetachSubscriptionRequest

type DetachSubscriptionRequest struct {

	// Required. The subscription to detach.
	// Format is `projects/{project}/subscriptions/{subscription}`.
	Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// contains filtered or unexported fields
}

Request for the DetachSubscription method.

func (*DetachSubscriptionRequest) Descriptor deprecated

func (*DetachSubscriptionRequest) Descriptor() ([]byte, []int)

Deprecated: Use DetachSubscriptionRequest.ProtoReflect.Descriptor instead.

func (*DetachSubscriptionRequest) GetSubscription

func (x *DetachSubscriptionRequest) GetSubscription() string

func (*DetachSubscriptionRequest) ProtoMessage

func (*DetachSubscriptionRequest) ProtoMessage()

func (*DetachSubscriptionRequest) ProtoReflect

func (*DetachSubscriptionRequest) Reset

func (x *DetachSubscriptionRequest) Reset()

func (*DetachSubscriptionRequest) String

func (x *DetachSubscriptionRequest) String() string

type DetachSubscriptionResponse

type DetachSubscriptionResponse struct {
	// contains filtered or unexported fields
}

Response for the DetachSubscription method. Reserved for future use.

func (*DetachSubscriptionResponse) Descriptor deprecated

func (*DetachSubscriptionResponse) Descriptor() ([]byte, []int)

Deprecated: Use DetachSubscriptionResponse.ProtoReflect.Descriptor instead.

func (*DetachSubscriptionResponse) ProtoMessage

func (*DetachSubscriptionResponse) ProtoMessage()

func (*DetachSubscriptionResponse) ProtoReflect

func (*DetachSubscriptionResponse) Reset

func (x *DetachSubscriptionResponse) Reset()

func (*DetachSubscriptionResponse) String

func (x *DetachSubscriptionResponse) String() string

type Encoding

type Encoding int32

Possible encoding types for messages.

const (
	// Unspecified
	Encoding_ENCODING_UNSPECIFIED Encoding = 0
	// JSON encoding
	Encoding_JSON Encoding = 1
	// Binary encoding, as defined by the schema type. For some schema types,
	// binary encoding may not be available.
	Encoding_BINARY Encoding = 2
)

func (Encoding) Descriptor

func (Encoding) Descriptor() protoreflect.EnumDescriptor

func (Encoding) Enum

func (x Encoding) Enum() *Encoding

func (Encoding) EnumDescriptor deprecated

func (Encoding) EnumDescriptor() ([]byte, []int)

Deprecated: Use Encoding.Descriptor instead.

func (Encoding) Number

func (x Encoding) Number() protoreflect.EnumNumber

func (Encoding) String

func (x Encoding) String() string

func (Encoding) Type

type ExpirationPolicy

type ExpirationPolicy struct {

	// Optional. Specifies the "time-to-live" duration for an associated resource.
	// The resource expires if it is not active for a period of `ttl`. The
	// definition of "activity" depends on the type of the associated resource.
	// The minimum and maximum allowed values for `ttl` depend on the type of the
	// associated resource, as well. If `ttl` is not set, the associated resource
	// never expires.
	Ttl *durationpb.Duration `protobuf:"bytes,1,opt,name=ttl,proto3" json:"ttl,omitempty"`
	// contains filtered or unexported fields
}

A policy that specifies the conditions for resource expiration (i.e., automatic resource deletion).

func (*ExpirationPolicy) Descriptor deprecated

func (*ExpirationPolicy) Descriptor() ([]byte, []int)

Deprecated: Use ExpirationPolicy.ProtoReflect.Descriptor instead.

func (*ExpirationPolicy) GetTtl

func (x *ExpirationPolicy) GetTtl() *durationpb.Duration

func (*ExpirationPolicy) ProtoMessage

func (*ExpirationPolicy) ProtoMessage()

func (*ExpirationPolicy) ProtoReflect

func (x *ExpirationPolicy) ProtoReflect() protoreflect.Message

func (*ExpirationPolicy) Reset

func (x *ExpirationPolicy) Reset()

func (*ExpirationPolicy) String

func (x *ExpirationPolicy) String() string

type GetSchemaRequest

type GetSchemaRequest struct {

	// Required. The name of the schema to get.
	// Format is `projects/{project}/schemas/{schema}`.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// The set of fields to return in the response. If not set, returns a Schema
	// with all fields filled out. Set to `BASIC` to omit the `definition`.
	View SchemaView `protobuf:"varint,2,opt,name=view,proto3,enum=google.pubsub.v1.SchemaView" json:"view,omitempty"`
	// contains filtered or unexported fields
}

Request for the GetSchema method.

func (*GetSchemaRequest) Descriptor deprecated

func (*GetSchemaRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetSchemaRequest.ProtoReflect.Descriptor instead.

func (*GetSchemaRequest) GetName

func (x *GetSchemaRequest) GetName() string

func (*GetSchemaRequest) GetView

func (x *GetSchemaRequest) GetView() SchemaView

func (*GetSchemaRequest) ProtoMessage

func (*GetSchemaRequest) ProtoMessage()

func (*GetSchemaRequest) ProtoReflect

func (x *GetSchemaRequest) ProtoReflect() protoreflect.Message

func (*GetSchemaRequest) Reset

func (x *GetSchemaRequest) Reset()

func (*GetSchemaRequest) String

func (x *GetSchemaRequest) String() string

type GetSnapshotRequest

type GetSnapshotRequest struct {

	// Required. The name of the snapshot to get.
	// Format is `projects/{project}/snapshots/{snap}`.
	Snapshot string `protobuf:"bytes,1,opt,name=snapshot,proto3" json:"snapshot,omitempty"`
	// contains filtered or unexported fields
}

Request for the GetSnapshot method.

func (*GetSnapshotRequest) Descriptor deprecated

func (*GetSnapshotRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetSnapshotRequest.ProtoReflect.Descriptor instead.

func (*GetSnapshotRequest) GetSnapshot

func (x *GetSnapshotRequest) GetSnapshot() string

func (*GetSnapshotRequest) ProtoMessage

func (*GetSnapshotRequest) ProtoMessage()

func (*GetSnapshotRequest) ProtoReflect

func (x *GetSnapshotRequest) ProtoReflect() protoreflect.Message

func (*GetSnapshotRequest) Reset

func (x *GetSnapshotRequest) Reset()

func (*GetSnapshotRequest) String

func (x *GetSnapshotRequest) String() string

type GetSubscriptionRequest

type GetSubscriptionRequest struct {

	// Required. The name of the subscription to get.
	// Format is `projects/{project}/subscriptions/{sub}`.
	Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// contains filtered or unexported fields
}

Request for the GetSubscription method.

func (*GetSubscriptionRequest) Descriptor deprecated

func (*GetSubscriptionRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetSubscriptionRequest.ProtoReflect.Descriptor instead.

func (*GetSubscriptionRequest) GetSubscription

func (x *GetSubscriptionRequest) GetSubscription() 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 GetTopicRequest

type GetTopicRequest struct {

	// Required. The name of the topic to get.
	// Format is `projects/{project}/topics/{topic}`.
	Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"`
	// contains filtered or unexported fields
}

Request for the GetTopic method.

func (*GetTopicRequest) Descriptor deprecated

func (*GetTopicRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetTopicRequest.ProtoReflect.Descriptor instead.

func (*GetTopicRequest) GetTopic

func (x *GetTopicRequest) GetTopic() 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 IngestionDataSourceSettings added in v1.36.0

type IngestionDataSourceSettings struct {

	// Only one source type can have settings set.
	//
	// Types that are assignable to Source:
	//
	//	*IngestionDataSourceSettings_AwsKinesis_
	Source isIngestionDataSourceSettings_Source `protobuf_oneof:"source"`
	// contains filtered or unexported fields
}

Settings for an ingestion data source on a topic.

func (*IngestionDataSourceSettings) Descriptor deprecated added in v1.36.0

func (*IngestionDataSourceSettings) Descriptor() ([]byte, []int)

Deprecated: Use IngestionDataSourceSettings.ProtoReflect.Descriptor instead.

func (*IngestionDataSourceSettings) GetAwsKinesis added in v1.36.0

func (*IngestionDataSourceSettings) GetSource added in v1.36.0

func (m *IngestionDataSourceSettings) GetSource() isIngestionDataSourceSettings_Source

func (*IngestionDataSourceSettings) ProtoMessage added in v1.36.0

func (*IngestionDataSourceSettings) ProtoMessage()

func (*IngestionDataSourceSettings) ProtoReflect added in v1.36.0

func (*IngestionDataSourceSettings) Reset added in v1.36.0

func (x *IngestionDataSourceSettings) Reset()

func (*IngestionDataSourceSettings) String added in v1.36.0

func (x *IngestionDataSourceSettings) String() string

type IngestionDataSourceSettings_AwsKinesis added in v1.36.0

type IngestionDataSourceSettings_AwsKinesis struct {

	// Output only. An output-only field that indicates the state of the Kinesis
	// ingestion source.
	State IngestionDataSourceSettings_AwsKinesis_State `` /* 131-byte string literal not displayed */
	// Required. The Kinesis stream ARN to ingest data from.
	StreamArn string `protobuf:"bytes,2,opt,name=stream_arn,json=streamArn,proto3" json:"stream_arn,omitempty"`
	// Required. The Kinesis consumer ARN to used for ingestion in Enhanced
	// Fan-Out mode. The consumer must be already created and ready to be used.
	ConsumerArn string `protobuf:"bytes,3,opt,name=consumer_arn,json=consumerArn,proto3" json:"consumer_arn,omitempty"`
	// Required. AWS role ARN to be used for Federated Identity authentication
	// with Kinesis. Check the Pub/Sub docs for how to set up this role and the
	// required permissions that need to be attached to it.
	AwsRoleArn string `protobuf:"bytes,4,opt,name=aws_role_arn,json=awsRoleArn,proto3" json:"aws_role_arn,omitempty"`
	// Required. The GCP service account to be used for Federated Identity
	// authentication with Kinesis (via a `AssumeRoleWithWebIdentity` call for
	// the provided role). The `aws_role_arn` must be set up with
	// `accounts.google.com:sub` equals to this service account number.
	GcpServiceAccount string `protobuf:"bytes,5,opt,name=gcp_service_account,json=gcpServiceAccount,proto3" json:"gcp_service_account,omitempty"`
	// contains filtered or unexported fields
}

Ingestion settings for Amazon Kinesis Data Streams.

func (*IngestionDataSourceSettings_AwsKinesis) Descriptor deprecated added in v1.36.0

func (*IngestionDataSourceSettings_AwsKinesis) Descriptor() ([]byte, []int)

Deprecated: Use IngestionDataSourceSettings_AwsKinesis.ProtoReflect.Descriptor instead.

func (*IngestionDataSourceSettings_AwsKinesis) GetAwsRoleArn added in v1.36.0

func (*IngestionDataSourceSettings_AwsKinesis) GetConsumerArn added in v1.36.0

func (x *IngestionDataSourceSettings_AwsKinesis) GetConsumerArn() string

func (*IngestionDataSourceSettings_AwsKinesis) GetGcpServiceAccount added in v1.36.0

func (x *IngestionDataSourceSettings_AwsKinesis) GetGcpServiceAccount() string

func (*IngestionDataSourceSettings_AwsKinesis) GetState added in v1.36.0

func (*IngestionDataSourceSettings_AwsKinesis) GetStreamArn added in v1.36.0

func (*IngestionDataSourceSettings_AwsKinesis) ProtoMessage added in v1.36.0

func (*IngestionDataSourceSettings_AwsKinesis) ProtoReflect added in v1.36.0

func (*IngestionDataSourceSettings_AwsKinesis) Reset added in v1.36.0

func (*IngestionDataSourceSettings_AwsKinesis) String added in v1.36.0

type IngestionDataSourceSettings_AwsKinesis_ added in v1.36.0

type IngestionDataSourceSettings_AwsKinesis_ struct {
	// Optional. Amazon Kinesis Data Streams.
	AwsKinesis *IngestionDataSourceSettings_AwsKinesis `protobuf:"bytes,1,opt,name=aws_kinesis,json=awsKinesis,proto3,oneof"`
}

type IngestionDataSourceSettings_AwsKinesis_State added in v1.36.0

type IngestionDataSourceSettings_AwsKinesis_State int32

Possible states for ingestion from Amazon Kinesis Data Streams.

const (
	// Default value. This value is unused.
	IngestionDataSourceSettings_AwsKinesis_STATE_UNSPECIFIED IngestionDataSourceSettings_AwsKinesis_State = 0
	// Ingestion is active.
	IngestionDataSourceSettings_AwsKinesis_ACTIVE IngestionDataSourceSettings_AwsKinesis_State = 1
	// Permission denied encountered while consuming data from Kinesis.
	// This can happen if:
	//   - The provided `aws_role_arn` does not exist or does not have the
	//     appropriate permissions attached.
	//   - The provided `aws_role_arn` is not set up properly for Identity
	//     Federation using `gcp_service_account`.
	//   - The Pub/Sub SA is not granted the
	//     `iam.serviceAccounts.getOpenIdToken` permission on
	//     `gcp_service_account`.
	IngestionDataSourceSettings_AwsKinesis_KINESIS_PERMISSION_DENIED IngestionDataSourceSettings_AwsKinesis_State = 2
	// Permission denied encountered while publishing to the topic. This can
	// happen due to Pub/Sub SA has not been granted the [appropriate publish
	// permissions](https://cloud.google.com/pubsub/docs/access-control#pubsub.publisher)
	IngestionDataSourceSettings_AwsKinesis_PUBLISH_PERMISSION_DENIED IngestionDataSourceSettings_AwsKinesis_State = 3
	// The Kinesis stream does not exist.
	IngestionDataSourceSettings_AwsKinesis_STREAM_NOT_FOUND IngestionDataSourceSettings_AwsKinesis_State = 4
	// The Kinesis consumer does not exist.
	IngestionDataSourceSettings_AwsKinesis_CONSUMER_NOT_FOUND IngestionDataSourceSettings_AwsKinesis_State = 5
)

func (IngestionDataSourceSettings_AwsKinesis_State) Descriptor added in v1.36.0

func (IngestionDataSourceSettings_AwsKinesis_State) Enum added in v1.36.0

func (IngestionDataSourceSettings_AwsKinesis_State) EnumDescriptor deprecated added in v1.36.0

func (IngestionDataSourceSettings_AwsKinesis_State) EnumDescriptor() ([]byte, []int)

Deprecated: Use IngestionDataSourceSettings_AwsKinesis_State.Descriptor instead.

func (IngestionDataSourceSettings_AwsKinesis_State) Number added in v1.36.0

func (IngestionDataSourceSettings_AwsKinesis_State) String added in v1.36.0

func (IngestionDataSourceSettings_AwsKinesis_State) Type added in v1.36.0

type ListSchemaRevisionsRequest added in v1.29.0

type ListSchemaRevisionsRequest struct {

	// Required. The name of the schema to list revisions for.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// The set of Schema fields to return in the response. If not set, returns
	// Schemas with `name` and `type`, but not `definition`. Set to `FULL` to
	// retrieve all fields.
	View SchemaView `protobuf:"varint,2,opt,name=view,proto3,enum=google.pubsub.v1.SchemaView" json:"view,omitempty"`
	// The maximum number of revisions to return per page.
	PageSize int32 `protobuf:"varint,3,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"`
	// The page token, received from a previous ListSchemaRevisions call.
	// Provide this to retrieve the subsequent page.
	PageToken string `protobuf:"bytes,4,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"`
	// contains filtered or unexported fields
}

Request for the `ListSchemaRevisions` method.

func (*ListSchemaRevisionsRequest) Descriptor deprecated added in v1.29.0

func (*ListSchemaRevisionsRequest) Descriptor() ([]byte, []int)

Deprecated: Use ListSchemaRevisionsRequest.ProtoReflect.Descriptor instead.

func (*ListSchemaRevisionsRequest) GetName added in v1.29.0

func (x *ListSchemaRevisionsRequest) GetName() string

func (*ListSchemaRevisionsRequest) GetPageSize added in v1.29.0

func (x *ListSchemaRevisionsRequest) GetPageSize() int32

func (*ListSchemaRevisionsRequest) GetPageToken added in v1.29.0

func (x *ListSchemaRevisionsRequest) GetPageToken() string

func (*ListSchemaRevisionsRequest) GetView added in v1.29.0

func (*ListSchemaRevisionsRequest) ProtoMessage added in v1.29.0

func (*ListSchemaRevisionsRequest) ProtoMessage()

func (*ListSchemaRevisionsRequest) ProtoReflect added in v1.29.0

func (*ListSchemaRevisionsRequest) Reset added in v1.29.0

func (x *ListSchemaRevisionsRequest) Reset()

func (*ListSchemaRevisionsRequest) String added in v1.29.0

func (x *ListSchemaRevisionsRequest) String() string

type ListSchemaRevisionsResponse added in v1.29.0

type ListSchemaRevisionsResponse struct {

	// The revisions of the schema.
	Schemas []*Schema `protobuf:"bytes,1,rep,name=schemas,proto3" json:"schemas,omitempty"`
	// A token that can be sent as `page_token` to retrieve the next page.
	// If this field is empty, 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 the `ListSchemaRevisions` method.

func (*ListSchemaRevisionsResponse) Descriptor deprecated added in v1.29.0

func (*ListSchemaRevisionsResponse) Descriptor() ([]byte, []int)

Deprecated: Use ListSchemaRevisionsResponse.ProtoReflect.Descriptor instead.

func (*ListSchemaRevisionsResponse) GetNextPageToken added in v1.29.0

func (x *ListSchemaRevisionsResponse) GetNextPageToken() string

func (*ListSchemaRevisionsResponse) GetSchemas added in v1.29.0

func (x *ListSchemaRevisionsResponse) GetSchemas() []*Schema

func (*ListSchemaRevisionsResponse) ProtoMessage added in v1.29.0

func (*ListSchemaRevisionsResponse) ProtoMessage()

func (*ListSchemaRevisionsResponse) ProtoReflect added in v1.29.0

func (*ListSchemaRevisionsResponse) Reset added in v1.29.0

func (x *ListSchemaRevisionsResponse) Reset()

func (*ListSchemaRevisionsResponse) String added in v1.29.0

func (x *ListSchemaRevisionsResponse) String() string

type ListSchemasRequest

type ListSchemasRequest struct {

	// Required. The name of the project in which to list schemas.
	// Format is `projects/{project-id}`.
	Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"`
	// The set of Schema fields to return in the response. If not set, returns
	// Schemas with `name` and `type`, but not `definition`. Set to `FULL` to
	// retrieve all fields.
	View SchemaView `protobuf:"varint,2,opt,name=view,proto3,enum=google.pubsub.v1.SchemaView" json:"view,omitempty"`
	// Maximum number of schemas to return.
	PageSize int32 `protobuf:"varint,3,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"`
	// The value returned by the last `ListSchemasResponse`; indicates that
	// this is a continuation of a prior `ListSchemas` call, and that the
	// system should return the next page of data.
	PageToken string `protobuf:"bytes,4,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"`
	// contains filtered or unexported fields
}

Request for the `ListSchemas` method.

func (*ListSchemasRequest) Descriptor deprecated

func (*ListSchemasRequest) Descriptor() ([]byte, []int)

Deprecated: Use ListSchemasRequest.ProtoReflect.Descriptor instead.

func (*ListSchemasRequest) GetPageSize

func (x *ListSchemasRequest) GetPageSize() int32

func (*ListSchemasRequest) GetPageToken

func (x *ListSchemasRequest) GetPageToken() string

func (*ListSchemasRequest) GetParent

func (x *ListSchemasRequest) GetParent() string

func (*ListSchemasRequest) GetView

func (x *ListSchemasRequest) GetView() SchemaView

func (*ListSchemasRequest) ProtoMessage

func (*ListSchemasRequest) ProtoMessage()

func (*ListSchemasRequest) ProtoReflect

func (x *ListSchemasRequest) ProtoReflect() protoreflect.Message

func (*ListSchemasRequest) Reset

func (x *ListSchemasRequest) Reset()

func (*ListSchemasRequest) String

func (x *ListSchemasRequest) String() string

type ListSchemasResponse

type ListSchemasResponse struct {

	// The resulting schemas.
	Schemas []*Schema `protobuf:"bytes,1,rep,name=schemas,proto3" json:"schemas,omitempty"`
	// If not empty, indicates that there may be more schemas that match the
	// request; this value should be passed in a new `ListSchemasRequest`.
	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 the `ListSchemas` method.

func (*ListSchemasResponse) Descriptor deprecated

func (*ListSchemasResponse) Descriptor() ([]byte, []int)

Deprecated: Use ListSchemasResponse.ProtoReflect.Descriptor instead.

func (*ListSchemasResponse) GetNextPageToken

func (x *ListSchemasResponse) GetNextPageToken() string

func (*ListSchemasResponse) GetSchemas

func (x *ListSchemasResponse) GetSchemas() []*Schema

func (*ListSchemasResponse) ProtoMessage

func (*ListSchemasResponse) ProtoMessage()

func (*ListSchemasResponse) ProtoReflect

func (x *ListSchemasResponse) ProtoReflect() protoreflect.Message

func (*ListSchemasResponse) Reset

func (x *ListSchemasResponse) Reset()

func (*ListSchemasResponse) String

func (x *ListSchemasResponse) String() string

type ListSnapshotsRequest

type ListSnapshotsRequest struct {

	// Required. The name of the project in which to list snapshots.
	// Format is `projects/{project-id}`.
	Project string `protobuf:"bytes,1,opt,name=project,proto3" json:"project,omitempty"`
	// Optional. Maximum number of snapshots to return.
	PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"`
	// Optional. The value returned by the last `ListSnapshotsResponse`; indicates
	// that this is a continuation of a prior `ListSnapshots` call, and that the
	// system should return the next page of data.
	PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"`
	// contains filtered or unexported fields
}

Request for the `ListSnapshots` method.

func (*ListSnapshotsRequest) Descriptor deprecated

func (*ListSnapshotsRequest) Descriptor() ([]byte, []int)

Deprecated: Use ListSnapshotsRequest.ProtoReflect.Descriptor instead.

func (*ListSnapshotsRequest) GetPageSize

func (x *ListSnapshotsRequest) GetPageSize() int32

func (*ListSnapshotsRequest) GetPageToken

func (x *ListSnapshotsRequest) GetPageToken() string

func (*ListSnapshotsRequest) GetProject

func (x *ListSnapshotsRequest) GetProject() string

func (*ListSnapshotsRequest) ProtoMessage

func (*ListSnapshotsRequest) ProtoMessage()

func (*ListSnapshotsRequest) ProtoReflect

func (x *ListSnapshotsRequest) ProtoReflect() protoreflect.Message

func (*ListSnapshotsRequest) Reset

func (x *ListSnapshotsRequest) Reset()

func (*ListSnapshotsRequest) String

func (x *ListSnapshotsRequest) String() string

type ListSnapshotsResponse

type ListSnapshotsResponse struct {

	// Optional. The resulting snapshots.
	Snapshots []*Snapshot `protobuf:"bytes,1,rep,name=snapshots,proto3" json:"snapshots,omitempty"`
	// Optional. If not empty, indicates that there may be more snapshot that
	// match the request; this value should be passed in a new
	// `ListSnapshotsRequest`.
	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 the `ListSnapshots` method.

func (*ListSnapshotsResponse) Descriptor deprecated

func (*ListSnapshotsResponse) Descriptor() ([]byte, []int)

Deprecated: Use ListSnapshotsResponse.ProtoReflect.Descriptor instead.

func (*ListSnapshotsResponse) GetNextPageToken

func (x *ListSnapshotsResponse) GetNextPageToken() string

func (*ListSnapshotsResponse) GetSnapshots

func (x *ListSnapshotsResponse) GetSnapshots() []*Snapshot

func (*ListSnapshotsResponse) ProtoMessage

func (*ListSnapshotsResponse) ProtoMessage()

func (*ListSnapshotsResponse) ProtoReflect

func (x *ListSnapshotsResponse) ProtoReflect() protoreflect.Message

func (*ListSnapshotsResponse) Reset

func (x *ListSnapshotsResponse) Reset()

func (*ListSnapshotsResponse) String

func (x *ListSnapshotsResponse) String() string

type ListSubscriptionsRequest

type ListSubscriptionsRequest struct {

	// Required. The name of the project in which to list subscriptions.
	// Format is `projects/{project-id}`.
	Project string `protobuf:"bytes,1,opt,name=project,proto3" json:"project,omitempty"`
	// Optional. Maximum number of subscriptions to return.
	PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"`
	// Optional. The value returned by the last `ListSubscriptionsResponse`;
	// indicates that this is a continuation of a prior `ListSubscriptions` call,
	// and that the system should return the next page of data.
	PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"`
	// contains filtered or unexported fields
}

Request for the `ListSubscriptions` method.

func (*ListSubscriptionsRequest) Descriptor deprecated

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

func (x *ListSubscriptionsRequest) GetProject() 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 {

	// Optional. The subscriptions that match the request.
	Subscriptions []*Subscription `protobuf:"bytes,1,rep,name=subscriptions,proto3" json:"subscriptions,omitempty"`
	// Optional. If not empty, indicates that there may be more subscriptions that
	// match the request; this value should be passed in a new
	// `ListSubscriptionsRequest` to get more subscriptions.
	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 the `ListSubscriptions` method.

func (*ListSubscriptionsResponse) Descriptor deprecated

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 (*ListSubscriptionsResponse) Reset

func (x *ListSubscriptionsResponse) Reset()

func (*ListSubscriptionsResponse) String

func (x *ListSubscriptionsResponse) String() string

type ListTopicSnapshotsRequest

type ListTopicSnapshotsRequest struct {

	// Required. The name of the topic that snapshots are attached to.
	// Format is `projects/{project}/topics/{topic}`.
	Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"`
	// Optional. Maximum number of snapshot names to return.
	PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"`
	// Optional. The value returned by the last `ListTopicSnapshotsResponse`;
	// indicates that this is a continuation of a prior `ListTopicSnapshots` call,
	// and that the system should return the next page of data.
	PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"`
	// contains filtered or unexported fields
}

Request for the `ListTopicSnapshots` method.

func (*ListTopicSnapshotsRequest) Descriptor deprecated

func (*ListTopicSnapshotsRequest) Descriptor() ([]byte, []int)

Deprecated: Use ListTopicSnapshotsRequest.ProtoReflect.Descriptor instead.

func (*ListTopicSnapshotsRequest) GetPageSize

func (x *ListTopicSnapshotsRequest) GetPageSize() int32

func (*ListTopicSnapshotsRequest) GetPageToken

func (x *ListTopicSnapshotsRequest) GetPageToken() string

func (*ListTopicSnapshotsRequest) GetTopic

func (x *ListTopicSnapshotsRequest) GetTopic() string

func (*ListTopicSnapshotsRequest) ProtoMessage

func (*ListTopicSnapshotsRequest) ProtoMessage()

func (*ListTopicSnapshotsRequest) ProtoReflect

func (*ListTopicSnapshotsRequest) Reset

func (x *ListTopicSnapshotsRequest) Reset()

func (*ListTopicSnapshotsRequest) String

func (x *ListTopicSnapshotsRequest) String() string

type ListTopicSnapshotsResponse

type ListTopicSnapshotsResponse struct {

	// Optional. The names of the snapshots that match the request.
	Snapshots []string `protobuf:"bytes,1,rep,name=snapshots,proto3" json:"snapshots,omitempty"`
	// Optional. If not empty, indicates that there may be more snapshots that
	// match the request; this value should be passed in a new
	// `ListTopicSnapshotsRequest` to get more snapshots.
	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 the `ListTopicSnapshots` method.

func (*ListTopicSnapshotsResponse) Descriptor deprecated

func (*ListTopicSnapshotsResponse) Descriptor() ([]byte, []int)

Deprecated: Use ListTopicSnapshotsResponse.ProtoReflect.Descriptor instead.

func (*ListTopicSnapshotsResponse) GetNextPageToken

func (x *ListTopicSnapshotsResponse) GetNextPageToken() string

func (*ListTopicSnapshotsResponse) GetSnapshots

func (x *ListTopicSnapshotsResponse) GetSnapshots() []string

func (*ListTopicSnapshotsResponse) ProtoMessage

func (*ListTopicSnapshotsResponse) ProtoMessage()

func (*ListTopicSnapshotsResponse) ProtoReflect

func (*ListTopicSnapshotsResponse) Reset

func (x *ListTopicSnapshotsResponse) Reset()

func (*ListTopicSnapshotsResponse) String

func (x *ListTopicSnapshotsResponse) String() string

type ListTopicSubscriptionsRequest

type ListTopicSubscriptionsRequest struct {

	// Required. The name of the topic that subscriptions are attached to.
	// Format is `projects/{project}/topics/{topic}`.
	Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"`
	// Optional. Maximum number of subscription names to return.
	PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"`
	// Optional. The value returned by the last `ListTopicSubscriptionsResponse`;
	// indicates that this is a continuation of a prior `ListTopicSubscriptions`
	// call, and that the system should return the next page of data.
	PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"`
	// contains filtered or unexported fields
}

Request for the `ListTopicSubscriptions` method.

func (*ListTopicSubscriptionsRequest) Descriptor deprecated

func (*ListTopicSubscriptionsRequest) Descriptor() ([]byte, []int)

Deprecated: Use ListTopicSubscriptionsRequest.ProtoReflect.Descriptor instead.

func (*ListTopicSubscriptionsRequest) GetPageSize

func (x *ListTopicSubscriptionsRequest) GetPageSize() int32

func (*ListTopicSubscriptionsRequest) GetPageToken

func (x *ListTopicSubscriptionsRequest) GetPageToken() string

func (*ListTopicSubscriptionsRequest) GetTopic

func (x *ListTopicSubscriptionsRequest) GetTopic() string

func (*ListTopicSubscriptionsRequest) ProtoMessage

func (*ListTopicSubscriptionsRequest) ProtoMessage()

func (*ListTopicSubscriptionsRequest) ProtoReflect

func (*ListTopicSubscriptionsRequest) Reset

func (x *ListTopicSubscriptionsRequest) Reset()

func (*ListTopicSubscriptionsRequest) String

type ListTopicSubscriptionsResponse

type ListTopicSubscriptionsResponse struct {

	// Optional. The names of subscriptions attached to the topic specified in the
	// request.
	Subscriptions []string `protobuf:"bytes,1,rep,name=subscriptions,proto3" json:"subscriptions,omitempty"`
	// Optional. If not empty, indicates that there may be more subscriptions that
	// match the request; this value should be passed in a new
	// `ListTopicSubscriptionsRequest` to get more subscriptions.
	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 the `ListTopicSubscriptions` method.

func (*ListTopicSubscriptionsResponse) Descriptor deprecated

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 (*ListTopicSubscriptionsResponse) Reset

func (x *ListTopicSubscriptionsResponse) Reset()

func (*ListTopicSubscriptionsResponse) String

type ListTopicsRequest

type ListTopicsRequest struct {

	// Required. The name of the project in which to list topics.
	// Format is `projects/{project-id}`.
	Project string `protobuf:"bytes,1,opt,name=project,proto3" json:"project,omitempty"`
	// Optional. Maximum number of topics to return.
	PageSize int32 `protobuf:"varint,2,opt,name=page_size,json=pageSize,proto3" json:"page_size,omitempty"`
	// Optional. The value returned by the last `ListTopicsResponse`; indicates
	// that this is a continuation of a prior `ListTopics` call, and that the
	// system should return the next page of data.
	PageToken string `protobuf:"bytes,3,opt,name=page_token,json=pageToken,proto3" json:"page_token,omitempty"`
	// contains filtered or unexported fields
}

Request for the `ListTopics` method.

func (*ListTopicsRequest) Descriptor deprecated

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

func (x *ListTopicsRequest) GetProject() 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 {

	// Optional. The resulting topics.
	Topics []*Topic `protobuf:"bytes,1,rep,name=topics,proto3" json:"topics,omitempty"`
	// Optional. If not empty, indicates that there may be more topics that match
	// the request; this value should be passed in a new `ListTopicsRequest`.
	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 the `ListTopics` method.

func (*ListTopicsResponse) Descriptor deprecated

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 MessageStoragePolicy

type MessageStoragePolicy struct {

	// Optional. A list of IDs of Google Cloud regions where messages that are
	// published to the topic may be persisted in storage. Messages published by
	// publishers running in non-allowed Google Cloud regions (or running outside
	// of Google Cloud altogether) are routed for storage in one of the allowed
	// regions. An empty list means that no regions are allowed, and is not a
	// valid configuration.
	AllowedPersistenceRegions []string `` /* 138-byte string literal not displayed */
	// Optional. If true, `allowed_persistence_regions` is also used to enforce
	// in-transit guarantees for messages. That is, Pub/Sub will fail
	// Publish operations on this topic and subscribe operations
	// on any subscription attached to this topic in any region that is
	// not in `allowed_persistence_regions`.
	EnforceInTransit bool `protobuf:"varint,2,opt,name=enforce_in_transit,json=enforceInTransit,proto3" json:"enforce_in_transit,omitempty"`
	// contains filtered or unexported fields
}

A policy constraining the storage of messages published to the topic.

func (*MessageStoragePolicy) Descriptor deprecated

func (*MessageStoragePolicy) Descriptor() ([]byte, []int)

Deprecated: Use MessageStoragePolicy.ProtoReflect.Descriptor instead.

func (*MessageStoragePolicy) GetAllowedPersistenceRegions

func (x *MessageStoragePolicy) GetAllowedPersistenceRegions() []string

func (*MessageStoragePolicy) GetEnforceInTransit added in v1.36.0

func (x *MessageStoragePolicy) GetEnforceInTransit() bool

func (*MessageStoragePolicy) ProtoMessage

func (*MessageStoragePolicy) ProtoMessage()

func (*MessageStoragePolicy) ProtoReflect

func (x *MessageStoragePolicy) ProtoReflect() protoreflect.Message

func (*MessageStoragePolicy) Reset

func (x *MessageStoragePolicy) Reset()

func (*MessageStoragePolicy) String

func (x *MessageStoragePolicy) String() string

type ModifyAckDeadlineRequest

type ModifyAckDeadlineRequest struct {

	// Required. The name of the subscription.
	// Format is `projects/{project}/subscriptions/{sub}`.
	Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// Required. List of acknowledgment IDs.
	AckIds []string `protobuf:"bytes,4,rep,name=ack_ids,json=ackIds,proto3" json:"ack_ids,omitempty"`
	// Required. The new ack deadline with respect to the time this request was
	// sent to the Pub/Sub system. For example, if the value is 10, the new ack
	// deadline will expire 10 seconds after the `ModifyAckDeadline` call was
	// made. Specifying zero might immediately make the message available for
	// delivery to another subscriber client. This typically results in an
	// increase in the rate of message redeliveries (that is, duplicates).
	// The minimum deadline you can specify is 0 seconds.
	// The maximum deadline you can specify in a single request is 600 seconds
	// (10 minutes).
	AckDeadlineSeconds int32 `protobuf:"varint,3,opt,name=ack_deadline_seconds,json=ackDeadlineSeconds,proto3" json:"ack_deadline_seconds,omitempty"`
	// contains filtered or unexported fields
}

Request for the ModifyAckDeadline method.

func (*ModifyAckDeadlineRequest) Descriptor deprecated

func (*ModifyAckDeadlineRequest) Descriptor() ([]byte, []int)

Deprecated: Use ModifyAckDeadlineRequest.ProtoReflect.Descriptor instead.

func (*ModifyAckDeadlineRequest) GetAckDeadlineSeconds

func (x *ModifyAckDeadlineRequest) GetAckDeadlineSeconds() int32

func (*ModifyAckDeadlineRequest) GetAckIds

func (x *ModifyAckDeadlineRequest) GetAckIds() []string

func (*ModifyAckDeadlineRequest) GetSubscription

func (x *ModifyAckDeadlineRequest) GetSubscription() string

func (*ModifyAckDeadlineRequest) ProtoMessage

func (*ModifyAckDeadlineRequest) ProtoMessage()

func (*ModifyAckDeadlineRequest) ProtoReflect

func (x *ModifyAckDeadlineRequest) ProtoReflect() protoreflect.Message

func (*ModifyAckDeadlineRequest) Reset

func (x *ModifyAckDeadlineRequest) Reset()

func (*ModifyAckDeadlineRequest) String

func (x *ModifyAckDeadlineRequest) String() string

type ModifyPushConfigRequest

type ModifyPushConfigRequest struct {

	// Required. The name of the subscription.
	// Format is `projects/{project}/subscriptions/{sub}`.
	Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// Required. The push configuration for future deliveries.
	//
	// An empty `pushConfig` indicates that the Pub/Sub system should
	// stop pushing messages from the given subscription and allow
	// messages to be pulled and acknowledged - effectively pausing
	// the subscription if `Pull` or `StreamingPull` is not called.
	PushConfig *PushConfig `protobuf:"bytes,2,opt,name=push_config,json=pushConfig,proto3" json:"push_config,omitempty"`
	// contains filtered or unexported fields
}

Request for the ModifyPushConfig method.

func (*ModifyPushConfigRequest) Descriptor deprecated

func (*ModifyPushConfigRequest) Descriptor() ([]byte, []int)

Deprecated: Use ModifyPushConfigRequest.ProtoReflect.Descriptor instead.

func (*ModifyPushConfigRequest) GetPushConfig

func (x *ModifyPushConfigRequest) GetPushConfig() *PushConfig

func (*ModifyPushConfigRequest) GetSubscription

func (x *ModifyPushConfigRequest) GetSubscription() string

func (*ModifyPushConfigRequest) ProtoMessage

func (*ModifyPushConfigRequest) ProtoMessage()

func (*ModifyPushConfigRequest) ProtoReflect

func (x *ModifyPushConfigRequest) ProtoReflect() protoreflect.Message

func (*ModifyPushConfigRequest) Reset

func (x *ModifyPushConfigRequest) Reset()

func (*ModifyPushConfigRequest) String

func (x *ModifyPushConfigRequest) String() string

type PublishRequest

type PublishRequest struct {

	// Required. The messages in the request will be published on this topic.
	// Format is `projects/{project}/topics/{topic}`.
	Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"`
	// Required. The messages to publish.
	Messages []*PubsubMessage `protobuf:"bytes,2,rep,name=messages,proto3" json:"messages,omitempty"`
	// contains filtered or unexported fields
}

Request for the Publish method.

func (*PublishRequest) Descriptor deprecated

func (*PublishRequest) Descriptor() ([]byte, []int)

Deprecated: Use PublishRequest.ProtoReflect.Descriptor instead.

func (*PublishRequest) GetMessages

func (x *PublishRequest) GetMessages() []*PubsubMessage

func (*PublishRequest) GetTopic

func (x *PublishRequest) GetTopic() string

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 PublishResponse

type PublishResponse struct {

	// Optional. The server-assigned ID of each published message, in the same
	// order as the messages in the request. IDs are guaranteed to be unique
	// within the topic.
	MessageIds []string `protobuf:"bytes,1,rep,name=message_ids,json=messageIds,proto3" json:"message_ids,omitempty"`
	// contains filtered or unexported fields
}

Response for the `Publish` method.

func (*PublishResponse) Descriptor deprecated

func (*PublishResponse) Descriptor() ([]byte, []int)

Deprecated: Use PublishResponse.ProtoReflect.Descriptor instead.

func (*PublishResponse) GetMessageIds

func (x *PublishResponse) GetMessageIds() []string

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 PublisherClient

type PublisherClient interface {
	// Creates the given topic with the given name. See the [resource name rules]
	// (https://cloud.google.com/pubsub/docs/pubsub-basics#resource_names).
	CreateTopic(ctx context.Context, in *Topic, opts ...grpc.CallOption) (*Topic, error)
	// Updates an existing topic by updating the fields specified in the update
	// mask. Note that certain properties of a topic are not modifiable.
	UpdateTopic(ctx context.Context, in *UpdateTopicRequest, opts ...grpc.CallOption) (*Topic, error)
	// Adds one or more messages to the topic. Returns `NOT_FOUND` if the topic
	// does not exist.
	Publish(ctx context.Context, in *PublishRequest, opts ...grpc.CallOption) (*PublishResponse, error)
	// Gets the configuration of a topic.
	GetTopic(ctx context.Context, in *GetTopicRequest, opts ...grpc.CallOption) (*Topic, error)
	// Lists matching topics.
	ListTopics(ctx context.Context, in *ListTopicsRequest, opts ...grpc.CallOption) (*ListTopicsResponse, error)
	// Lists the names of the attached subscriptions on this topic.
	ListTopicSubscriptions(ctx context.Context, in *ListTopicSubscriptionsRequest, opts ...grpc.CallOption) (*ListTopicSubscriptionsResponse, error)
	// Lists the names of the snapshots on this topic. Snapshots are used in
	// [Seek](https://cloud.google.com/pubsub/docs/replay-overview) operations,
	// which allow you to manage message acknowledgments in bulk. That is, you can
	// set the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	ListTopicSnapshots(ctx context.Context, in *ListTopicSnapshotsRequest, opts ...grpc.CallOption) (*ListTopicSnapshotsResponse, error)
	// Deletes the topic with the given name. Returns `NOT_FOUND` if the topic
	// does not exist. After a topic is deleted, a new topic may be created with
	// the same name; this is an entirely new topic with none of the old
	// configuration or subscriptions. Existing subscriptions to this topic are
	// not deleted, but their `topic` field is set to `_deleted-topic_`.
	DeleteTopic(ctx context.Context, in *DeleteTopicRequest, opts ...grpc.CallOption) (*emptypb.Empty, error)
	// Detaches a subscription from this topic. All messages retained in the
	// subscription are dropped. Subsequent `Pull` and `StreamingPull` requests
	// will return FAILED_PRECONDITION. If the subscription is a push
	// subscription, pushes to the endpoint will stop.
	DetachSubscription(ctx context.Context, in *DetachSubscriptionRequest, opts ...grpc.CallOption) (*DetachSubscriptionResponse, error)
}

PublisherClient is the client API for Publisher service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

func NewPublisherClient

func NewPublisherClient(cc grpc.ClientConnInterface) PublisherClient

type PublisherServer

type PublisherServer interface {
	// Creates the given topic with the given name. See the [resource name rules]
	// (https://cloud.google.com/pubsub/docs/pubsub-basics#resource_names).
	CreateTopic(context.Context, *Topic) (*Topic, error)
	// Updates an existing topic by updating the fields specified in the update
	// mask. Note that certain properties of a topic are not modifiable.
	UpdateTopic(context.Context, *UpdateTopicRequest) (*Topic, error)
	// Adds one or more messages to the topic. Returns `NOT_FOUND` if the topic
	// does not exist.
	Publish(context.Context, *PublishRequest) (*PublishResponse, error)
	// Gets the configuration of a topic.
	GetTopic(context.Context, *GetTopicRequest) (*Topic, error)
	// Lists matching topics.
	ListTopics(context.Context, *ListTopicsRequest) (*ListTopicsResponse, error)
	// Lists the names of the attached subscriptions on this topic.
	ListTopicSubscriptions(context.Context, *ListTopicSubscriptionsRequest) (*ListTopicSubscriptionsResponse, error)
	// Lists the names of the snapshots on this topic. Snapshots are used in
	// [Seek](https://cloud.google.com/pubsub/docs/replay-overview) operations,
	// which allow you to manage message acknowledgments in bulk. That is, you can
	// set the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	ListTopicSnapshots(context.Context, *ListTopicSnapshotsRequest) (*ListTopicSnapshotsResponse, error)
	// Deletes the topic with the given name. Returns `NOT_FOUND` if the topic
	// does not exist. After a topic is deleted, a new topic may be created with
	// the same name; this is an entirely new topic with none of the old
	// configuration or subscriptions. Existing subscriptions to this topic are
	// not deleted, but their `topic` field is set to `_deleted-topic_`.
	DeleteTopic(context.Context, *DeleteTopicRequest) (*emptypb.Empty, error)
	// Detaches a subscription from this topic. All messages retained in the
	// subscription are dropped. Subsequent `Pull` and `StreamingPull` requests
	// will return FAILED_PRECONDITION. If the subscription is a push
	// subscription, pushes to the endpoint will stop.
	DetachSubscription(context.Context, *DetachSubscriptionRequest) (*DetachSubscriptionResponse, error)
}

PublisherServer is the server API for Publisher service.

type PubsubMessage

type PubsubMessage struct {

	// Optional. The message data field. If this field is empty, the message must
	// contain at least one attribute.
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
	// Optional. Attributes for this message. If this field is empty, the message
	// must contain non-empty data. This can be used to filter messages on the
	// subscription.
	Attributes map[string]string `` /* 161-byte string literal not displayed */
	// ID of this message, assigned by the server when the message is published.
	// Guaranteed to be unique within the topic. This value may be read by a
	// subscriber that receives a `PubsubMessage` via a `Pull` call or a push
	// delivery. It must not be populated by the publisher in a `Publish` call.
	MessageId string `protobuf:"bytes,3,opt,name=message_id,json=messageId,proto3" json:"message_id,omitempty"`
	// The time at which the message was published, populated by the server when
	// it receives the `Publish` call. It must not be populated by the
	// publisher in a `Publish` call.
	PublishTime *timestamppb.Timestamp `protobuf:"bytes,4,opt,name=publish_time,json=publishTime,proto3" json:"publish_time,omitempty"`
	// Optional. If non-empty, identifies related messages for which publish order
	// should be respected. If a `Subscription` has `enable_message_ordering` set
	// to `true`, messages published with the same non-empty `ordering_key` value
	// will be delivered to subscribers in the order in which they are received by
	// the Pub/Sub system. All `PubsubMessage`s published in a given
	// `PublishRequest` must specify the same `ordering_key` value. For more
	// information, see [ordering
	// messages](https://cloud.google.com/pubsub/docs/ordering).
	OrderingKey string `protobuf:"bytes,5,opt,name=ordering_key,json=orderingKey,proto3" json:"ordering_key,omitempty"`
	// contains filtered or unexported fields
}

A message that is published by publishers and consumed by subscribers. The message must contain either a non-empty data field or at least one attribute. Note that client libraries represent this object differently depending on the language. See the corresponding [client library documentation](https://cloud.google.com/pubsub/docs/reference/libraries) for more information. See [quotas and limits] (https://cloud.google.com/pubsub/quotas) for more information about message limits.

func (*PubsubMessage) Descriptor deprecated

func (*PubsubMessage) Descriptor() ([]byte, []int)

Deprecated: Use PubsubMessage.ProtoReflect.Descriptor instead.

func (*PubsubMessage) GetAttributes

func (x *PubsubMessage) GetAttributes() map[string]string

func (*PubsubMessage) GetData

func (x *PubsubMessage) GetData() []byte

func (*PubsubMessage) GetMessageId

func (x *PubsubMessage) GetMessageId() string

func (*PubsubMessage) GetOrderingKey

func (x *PubsubMessage) GetOrderingKey() string

func (*PubsubMessage) GetPublishTime

func (x *PubsubMessage) GetPublishTime() *timestamppb.Timestamp

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 PullRequest

type PullRequest struct {

	// Required. The subscription from which messages should be pulled.
	// Format is `projects/{project}/subscriptions/{sub}`.
	Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// Optional. If this field set to true, the system will respond immediately
	// even if it there are no messages available to return in the `Pull`
	// response. Otherwise, the system may wait (for a bounded amount of time)
	// until at least one message is available, rather than returning no messages.
	// Warning: setting this field to `true` is discouraged because it adversely
	// impacts the performance of `Pull` operations. We recommend that users do
	// not set this field.
	//
	// Deprecated: Marked as deprecated in google/pubsub/v1/pubsub.proto.
	ReturnImmediately bool `protobuf:"varint,2,opt,name=return_immediately,json=returnImmediately,proto3" json:"return_immediately,omitempty"`
	// Required. The maximum number of messages to return for this request. Must
	// be a positive integer. The Pub/Sub system may return fewer than the number
	// specified.
	MaxMessages int32 `protobuf:"varint,3,opt,name=max_messages,json=maxMessages,proto3" json:"max_messages,omitempty"`
	// contains filtered or unexported fields
}

Request for the `Pull` method.

func (*PullRequest) Descriptor deprecated

func (*PullRequest) Descriptor() ([]byte, []int)

Deprecated: Use PullRequest.ProtoReflect.Descriptor instead.

func (*PullRequest) GetMaxMessages

func (x *PullRequest) GetMaxMessages() int32

func (*PullRequest) GetReturnImmediately deprecated

func (x *PullRequest) GetReturnImmediately() bool

Deprecated: Marked as deprecated in google/pubsub/v1/pubsub.proto.

func (*PullRequest) GetSubscription

func (x *PullRequest) GetSubscription() string

func (*PullRequest) ProtoMessage

func (*PullRequest) ProtoMessage()

func (*PullRequest) ProtoReflect

func (x *PullRequest) ProtoReflect() protoreflect.Message

func (*PullRequest) Reset

func (x *PullRequest) Reset()

func (*PullRequest) String

func (x *PullRequest) String() string

type PullResponse

type PullResponse struct {

	// Optional. Received Pub/Sub messages. The list will be empty if there are no
	// more messages available in the backlog, or if no messages could be returned
	// before the request timeout. For JSON, the response can be entirely
	// empty. The Pub/Sub system may return fewer than the `maxMessages` requested
	// even if there are more messages available in the backlog.
	ReceivedMessages []*ReceivedMessage `protobuf:"bytes,1,rep,name=received_messages,json=receivedMessages,proto3" json:"received_messages,omitempty"`
	// contains filtered or unexported fields
}

Response for the `Pull` method.

func (*PullResponse) Descriptor deprecated

func (*PullResponse) Descriptor() ([]byte, []int)

Deprecated: Use PullResponse.ProtoReflect.Descriptor instead.

func (*PullResponse) GetReceivedMessages

func (x *PullResponse) GetReceivedMessages() []*ReceivedMessage

func (*PullResponse) ProtoMessage

func (*PullResponse) ProtoMessage()

func (*PullResponse) ProtoReflect

func (x *PullResponse) ProtoReflect() protoreflect.Message

func (*PullResponse) Reset

func (x *PullResponse) Reset()

func (*PullResponse) String

func (x *PullResponse) String() string

type PushConfig

type PushConfig struct {

	// Optional. A URL locating the endpoint to which messages should be pushed.
	// For example, a Webhook endpoint might use `https://example.com/push`.
	PushEndpoint string `protobuf:"bytes,1,opt,name=push_endpoint,json=pushEndpoint,proto3" json:"push_endpoint,omitempty"`
	// Optional. Endpoint configuration attributes that can be used to control
	// different aspects of the message delivery.
	//
	// The only currently supported attribute is `x-goog-version`, which you can
	// use to change the format of the pushed message. This attribute
	// indicates the version of the data expected by the endpoint. This
	// controls the shape of the pushed message (i.e., its fields and metadata).
	//
	// If not present during the `CreateSubscription` call, it will default to
	// the version of the Pub/Sub API used to make such call. If not present in a
	// `ModifyPushConfig` call, its value will not be changed. `GetSubscription`
	// calls will always return a valid version, even if the subscription was
	// created without this attribute.
	//
	// The only supported values for the `x-goog-version` attribute are:
	//
	// * `v1beta1`: uses the push format defined in the v1beta1 Pub/Sub API.
	// * `v1` or `v1beta2`: uses the push format defined in the v1 Pub/Sub API.
	//
	// For example:
	// `attributes { "x-goog-version": "v1" }`
	Attributes map[string]string `` /* 161-byte string literal not displayed */
	// An authentication method used by push endpoints to verify the source of
	// push requests. This can be used with push endpoints that are private by
	// default to allow requests only from the Pub/Sub system, for example.
	// This field is optional and should be set only by users interested in
	// authenticated push.
	//
	// Types that are assignable to AuthenticationMethod:
	//
	//	*PushConfig_OidcToken_
	AuthenticationMethod isPushConfig_AuthenticationMethod `protobuf_oneof:"authentication_method"`
	// The format of the delivered message to the push endpoint is defined by
	// the chosen wrapper. When unset, `PubsubWrapper` is used.
	//
	// Types that are assignable to Wrapper:
	//
	//	*PushConfig_PubsubWrapper_
	//	*PushConfig_NoWrapper_
	Wrapper isPushConfig_Wrapper `protobuf_oneof:"wrapper"`
	// contains filtered or unexported fields
}

Configuration for a push delivery endpoint.

func (*PushConfig) Descriptor deprecated

func (*PushConfig) Descriptor() ([]byte, []int)

Deprecated: Use PushConfig.ProtoReflect.Descriptor instead.

func (*PushConfig) GetAttributes

func (x *PushConfig) GetAttributes() map[string]string

func (*PushConfig) GetAuthenticationMethod

func (m *PushConfig) GetAuthenticationMethod() isPushConfig_AuthenticationMethod

func (*PushConfig) GetNoWrapper added in v1.32.0

func (x *PushConfig) GetNoWrapper() *PushConfig_NoWrapper

func (*PushConfig) GetOidcToken

func (x *PushConfig) GetOidcToken() *PushConfig_OidcToken

func (*PushConfig) GetPubsubWrapper added in v1.32.0

func (x *PushConfig) GetPubsubWrapper() *PushConfig_PubsubWrapper

func (*PushConfig) GetPushEndpoint

func (x *PushConfig) GetPushEndpoint() string

func (*PushConfig) GetWrapper added in v1.32.0

func (m *PushConfig) GetWrapper() isPushConfig_Wrapper

func (*PushConfig) ProtoMessage

func (*PushConfig) ProtoMessage()

func (*PushConfig) ProtoReflect

func (x *PushConfig) ProtoReflect() protoreflect.Message

func (*PushConfig) Reset

func (x *PushConfig) Reset()

func (*PushConfig) String

func (x *PushConfig) String() string

type PushConfig_NoWrapper added in v1.32.0

type PushConfig_NoWrapper struct {

	// Optional. When true, writes the Pub/Sub message metadata to
	// `x-goog-pubsub-<KEY>:<VAL>` headers of the HTTP request. Writes the
	// Pub/Sub message attributes to `<KEY>:<VAL>` headers of the HTTP request.
	WriteMetadata bool `protobuf:"varint,1,opt,name=write_metadata,json=writeMetadata,proto3" json:"write_metadata,omitempty"`
	// contains filtered or unexported fields
}

Sets the `data` field as the HTTP body for delivery.

func (*PushConfig_NoWrapper) Descriptor deprecated added in v1.32.0

func (*PushConfig_NoWrapper) Descriptor() ([]byte, []int)

Deprecated: Use PushConfig_NoWrapper.ProtoReflect.Descriptor instead.

func (*PushConfig_NoWrapper) GetWriteMetadata added in v1.32.0

func (x *PushConfig_NoWrapper) GetWriteMetadata() bool

func (*PushConfig_NoWrapper) ProtoMessage added in v1.32.0

func (*PushConfig_NoWrapper) ProtoMessage()

func (*PushConfig_NoWrapper) ProtoReflect added in v1.32.0

func (x *PushConfig_NoWrapper) ProtoReflect() protoreflect.Message

func (*PushConfig_NoWrapper) Reset added in v1.32.0

func (x *PushConfig_NoWrapper) Reset()

func (*PushConfig_NoWrapper) String added in v1.32.0

func (x *PushConfig_NoWrapper) String() string

type PushConfig_NoWrapper_ added in v1.32.0

type PushConfig_NoWrapper_ struct {
	// Optional. When set, the payload to the push endpoint is not wrapped.
	NoWrapper *PushConfig_NoWrapper `protobuf:"bytes,5,opt,name=no_wrapper,json=noWrapper,proto3,oneof"`
}

type PushConfig_OidcToken

type PushConfig_OidcToken struct {

	// Optional. [Service account
	// email](https://cloud.google.com/iam/docs/service-accounts)
	// used for generating the OIDC token. For more information
	// on setting up authentication, see
	// [Push subscriptions](https://cloud.google.com/pubsub/docs/push).
	ServiceAccountEmail string `protobuf:"bytes,1,opt,name=service_account_email,json=serviceAccountEmail,proto3" json:"service_account_email,omitempty"`
	// Optional. Audience to be used when generating OIDC token. The audience
	// claim identifies the recipients that the JWT is intended for. The
	// audience value is a single case-sensitive string. Having multiple values
	// (array) for the audience field is not supported. More info about the OIDC
	// JWT token audience here:
	// https://tools.ietf.org/html/rfc7519#section-4.1.3 Note: if not specified,
	// the Push endpoint URL will be used.
	Audience string `protobuf:"bytes,2,opt,name=audience,proto3" json:"audience,omitempty"`
	// contains filtered or unexported fields
}

Contains information needed for generating an [OpenID Connect token](https://developers.google.com/identity/protocols/OpenIDConnect).

func (*PushConfig_OidcToken) Descriptor deprecated

func (*PushConfig_OidcToken) Descriptor() ([]byte, []int)

Deprecated: Use PushConfig_OidcToken.ProtoReflect.Descriptor instead.

func (*PushConfig_OidcToken) GetAudience

func (x *PushConfig_OidcToken) GetAudience() string

func (*PushConfig_OidcToken) GetServiceAccountEmail

func (x *PushConfig_OidcToken) GetServiceAccountEmail() string

func (*PushConfig_OidcToken) ProtoMessage

func (*PushConfig_OidcToken) ProtoMessage()

func (*PushConfig_OidcToken) ProtoReflect

func (x *PushConfig_OidcToken) ProtoReflect() protoreflect.Message

func (*PushConfig_OidcToken) Reset

func (x *PushConfig_OidcToken) Reset()

func (*PushConfig_OidcToken) String

func (x *PushConfig_OidcToken) String() string

type PushConfig_OidcToken_

type PushConfig_OidcToken_ struct {
	// Optional. If specified, Pub/Sub will generate and attach an OIDC JWT
	// token as an `Authorization` header in the HTTP request for every pushed
	// message.
	OidcToken *PushConfig_OidcToken `protobuf:"bytes,3,opt,name=oidc_token,json=oidcToken,proto3,oneof"`
}

type PushConfig_PubsubWrapper added in v1.32.0

type PushConfig_PubsubWrapper struct {
	// contains filtered or unexported fields
}

The payload to the push endpoint is in the form of the JSON representation of a PubsubMessage (https://cloud.google.com/pubsub/docs/reference/rpc/google.pubsub.v1#pubsubmessage).

func (*PushConfig_PubsubWrapper) Descriptor deprecated added in v1.32.0

func (*PushConfig_PubsubWrapper) Descriptor() ([]byte, []int)

Deprecated: Use PushConfig_PubsubWrapper.ProtoReflect.Descriptor instead.

func (*PushConfig_PubsubWrapper) ProtoMessage added in v1.32.0

func (*PushConfig_PubsubWrapper) ProtoMessage()

func (*PushConfig_PubsubWrapper) ProtoReflect added in v1.32.0

func (x *PushConfig_PubsubWrapper) ProtoReflect() protoreflect.Message

func (*PushConfig_PubsubWrapper) Reset added in v1.32.0

func (x *PushConfig_PubsubWrapper) Reset()

func (*PushConfig_PubsubWrapper) String added in v1.32.0

func (x *PushConfig_PubsubWrapper) String() string

type PushConfig_PubsubWrapper_ added in v1.32.0

type PushConfig_PubsubWrapper_ struct {
	// Optional. When set, the payload to the push endpoint is in the form of
	// the JSON representation of a PubsubMessage
	// (https://cloud.google.com/pubsub/docs/reference/rpc/google.pubsub.v1#pubsubmessage).
	PubsubWrapper *PushConfig_PubsubWrapper `protobuf:"bytes,4,opt,name=pubsub_wrapper,json=pubsubWrapper,proto3,oneof"`
}

type ReceivedMessage

type ReceivedMessage struct {

	// Optional. This ID can be used to acknowledge the received message.
	AckId string `protobuf:"bytes,1,opt,name=ack_id,json=ackId,proto3" json:"ack_id,omitempty"`
	// Optional. The message.
	Message *PubsubMessage `protobuf:"bytes,2,opt,name=message,proto3" json:"message,omitempty"`
	// Optional. The approximate number of times that Pub/Sub has attempted to
	// deliver the associated message to a subscriber.
	//
	// More precisely, this is 1 + (number of NACKs) +
	// (number of ack_deadline exceeds) for this message.
	//
	// A NACK is any call to ModifyAckDeadline with a 0 deadline. An ack_deadline
	// exceeds event is whenever a message is not acknowledged within
	// ack_deadline. Note that ack_deadline is initially
	// Subscription.ackDeadlineSeconds, but may get extended automatically by
	// the client library.
	//
	// Upon the first delivery of a given message, `delivery_attempt` will have a
	// value of 1. The value is calculated at best effort and is approximate.
	//
	// If a DeadLetterPolicy is not set on the subscription, this will be 0.
	DeliveryAttempt int32 `protobuf:"varint,3,opt,name=delivery_attempt,json=deliveryAttempt,proto3" json:"delivery_attempt,omitempty"`
	// contains filtered or unexported fields
}

A message and its corresponding acknowledgment ID.

func (*ReceivedMessage) Descriptor deprecated

func (*ReceivedMessage) Descriptor() ([]byte, []int)

Deprecated: Use ReceivedMessage.ProtoReflect.Descriptor instead.

func (*ReceivedMessage) GetAckId

func (x *ReceivedMessage) GetAckId() string

func (*ReceivedMessage) GetDeliveryAttempt

func (x *ReceivedMessage) GetDeliveryAttempt() int32

func (*ReceivedMessage) GetMessage

func (x *ReceivedMessage) GetMessage() *PubsubMessage

func (*ReceivedMessage) ProtoMessage

func (*ReceivedMessage) ProtoMessage()

func (*ReceivedMessage) ProtoReflect

func (x *ReceivedMessage) ProtoReflect() protoreflect.Message

func (*ReceivedMessage) Reset

func (x *ReceivedMessage) Reset()

func (*ReceivedMessage) String

func (x *ReceivedMessage) String() string

type RetryPolicy

type RetryPolicy struct {

	// Optional. The minimum delay between consecutive deliveries of a given
	// message. Value should be between 0 and 600 seconds. Defaults to 10 seconds.
	MinimumBackoff *durationpb.Duration `protobuf:"bytes,1,opt,name=minimum_backoff,json=minimumBackoff,proto3" json:"minimum_backoff,omitempty"`
	// Optional. The maximum delay between consecutive deliveries of a given
	// message. Value should be between 0 and 600 seconds. Defaults to 600
	// seconds.
	MaximumBackoff *durationpb.Duration `protobuf:"bytes,2,opt,name=maximum_backoff,json=maximumBackoff,proto3" json:"maximum_backoff,omitempty"`
	// contains filtered or unexported fields
}

A policy that specifies how Pub/Sub retries message delivery.

Retry delay will be exponential based on provided minimum and maximum backoffs. https://en.wikipedia.org/wiki/Exponential_backoff.

RetryPolicy will be triggered on NACKs or acknowledgement deadline exceeded events for a given message.

Retry Policy is implemented on a best effort basis. At times, the delay between consecutive deliveries may not match the configuration. That is, delay can be more or less than configured backoff.

func (*RetryPolicy) Descriptor deprecated

func (*RetryPolicy) Descriptor() ([]byte, []int)

Deprecated: Use RetryPolicy.ProtoReflect.Descriptor instead.

func (*RetryPolicy) GetMaximumBackoff

func (x *RetryPolicy) GetMaximumBackoff() *durationpb.Duration

func (*RetryPolicy) GetMinimumBackoff

func (x *RetryPolicy) GetMinimumBackoff() *durationpb.Duration

func (*RetryPolicy) ProtoMessage

func (*RetryPolicy) ProtoMessage()

func (*RetryPolicy) ProtoReflect

func (x *RetryPolicy) ProtoReflect() protoreflect.Message

func (*RetryPolicy) Reset

func (x *RetryPolicy) Reset()

func (*RetryPolicy) String

func (x *RetryPolicy) String() string

type RollbackSchemaRequest added in v1.29.0

type RollbackSchemaRequest struct {

	// Required. The schema being rolled back with revision id.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Required. The revision ID to roll back to.
	// It must be a revision of the same schema.
	//
	//	Example: c7cfa2a8
	RevisionId string `protobuf:"bytes,2,opt,name=revision_id,json=revisionId,proto3" json:"revision_id,omitempty"`
	// contains filtered or unexported fields
}

Request for the `RollbackSchema` method.

func (*RollbackSchemaRequest) Descriptor deprecated added in v1.29.0

func (*RollbackSchemaRequest) Descriptor() ([]byte, []int)

Deprecated: Use RollbackSchemaRequest.ProtoReflect.Descriptor instead.

func (*RollbackSchemaRequest) GetName added in v1.29.0

func (x *RollbackSchemaRequest) GetName() string

func (*RollbackSchemaRequest) GetRevisionId added in v1.29.0

func (x *RollbackSchemaRequest) GetRevisionId() string

func (*RollbackSchemaRequest) ProtoMessage added in v1.29.0

func (*RollbackSchemaRequest) ProtoMessage()

func (*RollbackSchemaRequest) ProtoReflect added in v1.29.0

func (x *RollbackSchemaRequest) ProtoReflect() protoreflect.Message

func (*RollbackSchemaRequest) Reset added in v1.29.0

func (x *RollbackSchemaRequest) Reset()

func (*RollbackSchemaRequest) String added in v1.29.0

func (x *RollbackSchemaRequest) String() string

type Schema

type Schema struct {

	// Required. Name of the schema.
	// Format is `projects/{project}/schemas/{schema}`.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// The type of the schema definition.
	Type Schema_Type `protobuf:"varint,2,opt,name=type,proto3,enum=google.pubsub.v1.Schema_Type" json:"type,omitempty"`
	// The definition of the schema. This should contain a string representing
	// the full definition of the schema that is a valid schema definition of
	// the type specified in `type`.
	Definition string `protobuf:"bytes,3,opt,name=definition,proto3" json:"definition,omitempty"`
	// Output only. Immutable. The revision ID of the schema.
	RevisionId string `protobuf:"bytes,4,opt,name=revision_id,json=revisionId,proto3" json:"revision_id,omitempty"`
	// Output only. The timestamp that the revision was created.
	RevisionCreateTime *timestamppb.Timestamp `protobuf:"bytes,6,opt,name=revision_create_time,json=revisionCreateTime,proto3" json:"revision_create_time,omitempty"`
	// contains filtered or unexported fields
}

A schema resource.

func (*Schema) Descriptor deprecated

func (*Schema) Descriptor() ([]byte, []int)

Deprecated: Use Schema.ProtoReflect.Descriptor instead.

func (*Schema) GetDefinition

func (x *Schema) GetDefinition() string

func (*Schema) GetName

func (x *Schema) GetName() string

func (*Schema) GetRevisionCreateTime added in v1.29.0

func (x *Schema) GetRevisionCreateTime() *timestamppb.Timestamp

func (*Schema) GetRevisionId added in v1.29.0

func (x *Schema) GetRevisionId() string

func (*Schema) GetType

func (x *Schema) GetType() Schema_Type

func (*Schema) ProtoMessage

func (*Schema) ProtoMessage()

func (*Schema) ProtoReflect

func (x *Schema) ProtoReflect() protoreflect.Message

func (*Schema) Reset

func (x *Schema) Reset()

func (*Schema) String

func (x *Schema) String() string

type SchemaServiceClient

type SchemaServiceClient interface {
	// Creates a schema.
	CreateSchema(ctx context.Context, in *CreateSchemaRequest, opts ...grpc.CallOption) (*Schema, error)
	// Gets a schema.
	GetSchema(ctx context.Context, in *GetSchemaRequest, opts ...grpc.CallOption) (*Schema, error)
	// Lists schemas in a project.
	ListSchemas(ctx context.Context, in *ListSchemasRequest, opts ...grpc.CallOption) (*ListSchemasResponse, error)
	// Lists all schema revisions for the named schema.
	ListSchemaRevisions(ctx context.Context, in *ListSchemaRevisionsRequest, opts ...grpc.CallOption) (*ListSchemaRevisionsResponse, error)
	// Commits a new schema revision to an existing schema.
	CommitSchema(ctx context.Context, in *CommitSchemaRequest, opts ...grpc.CallOption) (*Schema, error)
	// Creates a new schema revision that is a copy of the provided revision_id.
	RollbackSchema(ctx context.Context, in *RollbackSchemaRequest, opts ...grpc.CallOption) (*Schema, error)
	// Deletes a specific schema revision.
	DeleteSchemaRevision(ctx context.Context, in *DeleteSchemaRevisionRequest, opts ...grpc.CallOption) (*Schema, error)
	// Deletes a schema.
	DeleteSchema(ctx context.Context, in *DeleteSchemaRequest, opts ...grpc.CallOption) (*emptypb.Empty, error)
	// Validates a schema.
	ValidateSchema(ctx context.Context, in *ValidateSchemaRequest, opts ...grpc.CallOption) (*ValidateSchemaResponse, error)
	// Validates a message against a schema.
	ValidateMessage(ctx context.Context, in *ValidateMessageRequest, opts ...grpc.CallOption) (*ValidateMessageResponse, error)
}

SchemaServiceClient is the client API for SchemaService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

type SchemaServiceServer

type SchemaServiceServer interface {
	// Creates a schema.
	CreateSchema(context.Context, *CreateSchemaRequest) (*Schema, error)
	// Gets a schema.
	GetSchema(context.Context, *GetSchemaRequest) (*Schema, error)
	// Lists schemas in a project.
	ListSchemas(context.Context, *ListSchemasRequest) (*ListSchemasResponse, error)
	// Lists all schema revisions for the named schema.
	ListSchemaRevisions(context.Context, *ListSchemaRevisionsRequest) (*ListSchemaRevisionsResponse, error)
	// Commits a new schema revision to an existing schema.
	CommitSchema(context.Context, *CommitSchemaRequest) (*Schema, error)
	// Creates a new schema revision that is a copy of the provided revision_id.
	RollbackSchema(context.Context, *RollbackSchemaRequest) (*Schema, error)
	// Deletes a specific schema revision.
	DeleteSchemaRevision(context.Context, *DeleteSchemaRevisionRequest) (*Schema, error)
	// Deletes a schema.
	DeleteSchema(context.Context, *DeleteSchemaRequest) (*emptypb.Empty, error)
	// Validates a schema.
	ValidateSchema(context.Context, *ValidateSchemaRequest) (*ValidateSchemaResponse, error)
	// Validates a message against a schema.
	ValidateMessage(context.Context, *ValidateMessageRequest) (*ValidateMessageResponse, error)
}

SchemaServiceServer is the server API for SchemaService service.

type SchemaSettings

type SchemaSettings struct {

	// Required. The name of the schema that messages published should be
	// validated against. Format is `projects/{project}/schemas/{schema}`. The
	// value of this field will be `_deleted-schema_` if the schema has been
	// deleted.
	Schema string `protobuf:"bytes,1,opt,name=schema,proto3" json:"schema,omitempty"`
	// Optional. The encoding of messages validated against `schema`.
	Encoding Encoding `protobuf:"varint,2,opt,name=encoding,proto3,enum=google.pubsub.v1.Encoding" json:"encoding,omitempty"`
	// Optional. The minimum (inclusive) revision allowed for validating messages.
	// If empty or not present, allow any revision to be validated against
	// last_revision or any revision created before.
	FirstRevisionId string `protobuf:"bytes,3,opt,name=first_revision_id,json=firstRevisionId,proto3" json:"first_revision_id,omitempty"`
	// Optional. The maximum (inclusive) revision allowed for validating messages.
	// If empty or not present, allow any revision to be validated against
	// first_revision or any revision created after.
	LastRevisionId string `protobuf:"bytes,4,opt,name=last_revision_id,json=lastRevisionId,proto3" json:"last_revision_id,omitempty"`
	// contains filtered or unexported fields
}

Settings for validating messages published against a schema.

func (*SchemaSettings) Descriptor deprecated

func (*SchemaSettings) Descriptor() ([]byte, []int)

Deprecated: Use SchemaSettings.ProtoReflect.Descriptor instead.

func (*SchemaSettings) GetEncoding

func (x *SchemaSettings) GetEncoding() Encoding

func (*SchemaSettings) GetFirstRevisionId added in v1.29.0

func (x *SchemaSettings) GetFirstRevisionId() string

func (*SchemaSettings) GetLastRevisionId added in v1.29.0

func (x *SchemaSettings) GetLastRevisionId() string

func (*SchemaSettings) GetSchema

func (x *SchemaSettings) GetSchema() string

func (*SchemaSettings) ProtoMessage

func (*SchemaSettings) ProtoMessage()

func (*SchemaSettings) ProtoReflect

func (x *SchemaSettings) ProtoReflect() protoreflect.Message

func (*SchemaSettings) Reset

func (x *SchemaSettings) Reset()

func (*SchemaSettings) String

func (x *SchemaSettings) String() string

type SchemaView

type SchemaView int32

View of Schema object fields to be returned by GetSchema and ListSchemas.

const (
	// The default / unset value.
	// The API will default to the BASIC view.
	SchemaView_SCHEMA_VIEW_UNSPECIFIED SchemaView = 0
	// Include the name and type of the schema, but not the definition.
	SchemaView_BASIC SchemaView = 1
	// Include all Schema object fields.
	SchemaView_FULL SchemaView = 2
)

func (SchemaView) Descriptor

func (SchemaView) Descriptor() protoreflect.EnumDescriptor

func (SchemaView) Enum

func (x SchemaView) Enum() *SchemaView

func (SchemaView) EnumDescriptor deprecated

func (SchemaView) EnumDescriptor() ([]byte, []int)

Deprecated: Use SchemaView.Descriptor instead.

func (SchemaView) Number

func (x SchemaView) Number() protoreflect.EnumNumber

func (SchemaView) String

func (x SchemaView) String() string

func (SchemaView) Type

type Schema_Type

type Schema_Type int32

Possible schema definition types.

const (
	// Default value. This value is unused.
	Schema_TYPE_UNSPECIFIED Schema_Type = 0
	// A Protocol Buffer schema definition.
	Schema_PROTOCOL_BUFFER Schema_Type = 1
	// An Avro schema definition.
	Schema_AVRO Schema_Type = 2
)

func (Schema_Type) Descriptor

func (Schema_Type) Enum

func (x Schema_Type) Enum() *Schema_Type

func (Schema_Type) EnumDescriptor deprecated

func (Schema_Type) EnumDescriptor() ([]byte, []int)

Deprecated: Use Schema_Type.Descriptor instead.

func (Schema_Type) Number

func (x Schema_Type) Number() protoreflect.EnumNumber

func (Schema_Type) String

func (x Schema_Type) String() string

func (Schema_Type) Type

type SeekRequest

type SeekRequest struct {

	// Required. The subscription to affect.
	Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// Types that are assignable to Target:
	//
	//	*SeekRequest_Time
	//	*SeekRequest_Snapshot
	Target isSeekRequest_Target `protobuf_oneof:"target"`
	// contains filtered or unexported fields
}

Request for the `Seek` method.

func (*SeekRequest) Descriptor deprecated

func (*SeekRequest) Descriptor() ([]byte, []int)

Deprecated: Use SeekRequest.ProtoReflect.Descriptor instead.

func (*SeekRequest) GetSnapshot

func (x *SeekRequest) GetSnapshot() string

func (*SeekRequest) GetSubscription

func (x *SeekRequest) GetSubscription() string

func (*SeekRequest) GetTarget

func (m *SeekRequest) GetTarget() isSeekRequest_Target

func (*SeekRequest) GetTime

func (x *SeekRequest) GetTime() *timestamppb.Timestamp

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_Snapshot

type SeekRequest_Snapshot struct {
	// Optional. The snapshot to seek to. The snapshot's topic must be the same
	// as that of the provided subscription. Format is
	// `projects/{project}/snapshots/{snap}`.
	Snapshot string `protobuf:"bytes,3,opt,name=snapshot,proto3,oneof"`
}

type SeekRequest_Time

type SeekRequest_Time struct {
	// Optional. The time to seek to.
	// Messages retained in the subscription that were published before this
	// time are marked as acknowledged, and messages retained in the
	// subscription that were published after this time are marked as
	// unacknowledged. Note that this operation affects only those messages
	// retained in the subscription (configured by the combination of
	// `message_retention_duration` and `retain_acked_messages`). For example,
	// if `time` corresponds to a point before the message retention
	// window (or to a point before the system's notion of the subscription
	// creation time), only retained messages will be marked as unacknowledged,
	// and already-expunged messages will not be restored.
	Time *timestamppb.Timestamp `protobuf:"bytes,2,opt,name=time,proto3,oneof"`
}

type SeekResponse

type SeekResponse struct {
	// contains filtered or unexported fields
}

Response for the `Seek` method (this response is empty).

func (*SeekResponse) Descriptor deprecated

func (*SeekResponse) Descriptor() ([]byte, []int)

Deprecated: Use SeekResponse.ProtoReflect.Descriptor instead.

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 Snapshot

type Snapshot struct {

	// Optional. The name of the snapshot.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Optional. The name of the topic from which this snapshot is retaining
	// messages.
	Topic string `protobuf:"bytes,2,opt,name=topic,proto3" json:"topic,omitempty"`
	// Optional. The snapshot is guaranteed to exist up until this time.
	// A newly-created snapshot expires no later than 7 days from the time of its
	// creation. Its exact lifetime is determined at creation by the existing
	// backlog in the source subscription. Specifically, the lifetime of the
	// snapshot is `7 days - (age of oldest unacked message in the subscription)`.
	// For example, consider a subscription whose oldest unacked message is 3 days
	// old. If a snapshot is created from this subscription, the snapshot -- which
	// will always capture this 3-day-old backlog as long as the snapshot
	// exists -- will expire in 4 days. The service will refuse to create a
	// snapshot that would expire in less than 1 hour after creation.
	ExpireTime *timestamppb.Timestamp `protobuf:"bytes,3,opt,name=expire_time,json=expireTime,proto3" json:"expire_time,omitempty"`
	// Optional. See [Creating and managing labels]
	// (https://cloud.google.com/pubsub/docs/labels).
	Labels map[string]string `` /* 153-byte string literal not displayed */
	// contains filtered or unexported fields
}

A snapshot resource. Snapshots are used in [Seek](https://cloud.google.com/pubsub/docs/replay-overview) operations, which allow you to manage message acknowledgments in bulk. That is, you can set the acknowledgment state of messages in an existing subscription to the state captured by a snapshot.

func (*Snapshot) Descriptor deprecated

func (*Snapshot) Descriptor() ([]byte, []int)

Deprecated: Use Snapshot.ProtoReflect.Descriptor instead.

func (*Snapshot) GetExpireTime

func (x *Snapshot) GetExpireTime() *timestamppb.Timestamp

func (*Snapshot) GetLabels

func (x *Snapshot) GetLabels() map[string]string

func (*Snapshot) GetName

func (x *Snapshot) GetName() string

func (*Snapshot) GetTopic

func (x *Snapshot) GetTopic() string

func (*Snapshot) ProtoMessage

func (*Snapshot) ProtoMessage()

func (*Snapshot) ProtoReflect

func (x *Snapshot) ProtoReflect() protoreflect.Message

func (*Snapshot) Reset

func (x *Snapshot) Reset()

func (*Snapshot) String

func (x *Snapshot) String() string

type StreamingPullRequest

type StreamingPullRequest struct {

	// Required. The subscription for which to initialize the new stream. This
	// must be provided in the first request on the stream, and must not be set in
	// subsequent requests from client to server.
	// Format is `projects/{project}/subscriptions/{sub}`.
	Subscription string `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// Optional. List of acknowledgement IDs for acknowledging previously received
	// messages (received on this stream or a different stream). If an ack ID has
	// expired, the corresponding message may be redelivered later. Acknowledging
	// a message more than once will not result in an error. If the
	// acknowledgement ID is malformed, the stream will be aborted with status
	// `INVALID_ARGUMENT`.
	AckIds []string `protobuf:"bytes,2,rep,name=ack_ids,json=ackIds,proto3" json:"ack_ids,omitempty"`
	// Optional. The list of new ack deadlines for the IDs listed in
	// `modify_deadline_ack_ids`. The size of this list must be the same as the
	// size of `modify_deadline_ack_ids`. If it differs the stream will be aborted
	// with `INVALID_ARGUMENT`. Each element in this list is applied to the
	// element in the same position in `modify_deadline_ack_ids`. The new ack
	// deadline is with respect to the time this request was sent to the Pub/Sub
	// system. Must be >= 0. For example, if the value is 10, the new ack deadline
	// will expire 10 seconds after this request is received. If the value is 0,
	// the message is immediately made available for another streaming or
	// non-streaming pull request. If the value is < 0 (an error), the stream will
	// be aborted with status `INVALID_ARGUMENT`.
	ModifyDeadlineSeconds []int32 `` /* 134-byte string literal not displayed */
	// Optional. List of acknowledgement IDs whose deadline will be modified based
	// on the corresponding element in `modify_deadline_seconds`. This field can
	// be used to indicate that more time is needed to process a message by the
	// subscriber, or to make the message available for redelivery if the
	// processing was interrupted.
	ModifyDeadlineAckIds []string `protobuf:"bytes,4,rep,name=modify_deadline_ack_ids,json=modifyDeadlineAckIds,proto3" json:"modify_deadline_ack_ids,omitempty"`
	// Required. The ack deadline to use for the stream. This must be provided in
	// the first request on the stream, but it can also be updated on subsequent
	// requests from client to server. The minimum deadline you can specify is 10
	// seconds. The maximum deadline you can specify is 600 seconds (10 minutes).
	StreamAckDeadlineSeconds int32 `` /* 138-byte string literal not displayed */
	// Optional. A unique identifier that is used to distinguish client instances
	// from each other. Only needs to be provided on the initial request. When a
	// stream disconnects and reconnects for the same stream, the client_id should
	// be set to the same value so that state associated with the old stream can
	// be transferred to the new stream. The same client_id should not be used for
	// different client instances.
	ClientId string `protobuf:"bytes,6,opt,name=client_id,json=clientId,proto3" json:"client_id,omitempty"`
	// Optional. Flow control settings for the maximum number of outstanding
	// messages. When there are `max_outstanding_messages` currently sent to the
	// streaming pull client that have not yet been acked or nacked, the server
	// stops sending more messages. The sending of messages resumes once the
	// number of outstanding messages is less than this value. If the value is
	// <= 0, there is no limit to the number of outstanding messages. This
	// property can only be set on the initial StreamingPullRequest. If it is set
	// on a subsequent request, the stream will be aborted with status
	// `INVALID_ARGUMENT`.
	MaxOutstandingMessages int64 `` /* 130-byte string literal not displayed */
	// Optional. Flow control settings for the maximum number of outstanding
	// bytes. When there are `max_outstanding_bytes` or more worth of messages
	// currently sent to the streaming pull client that have not yet been acked or
	// nacked, the server will stop sending more messages. The sending of messages
	// resumes once the number of outstanding bytes is less than this value. If
	// the value is <= 0, there is no limit to the number of outstanding bytes.
	// This property can only be set on the initial StreamingPullRequest. If it is
	// set on a subsequent request, the stream will be aborted with status
	// `INVALID_ARGUMENT`.
	MaxOutstandingBytes int64 `protobuf:"varint,8,opt,name=max_outstanding_bytes,json=maxOutstandingBytes,proto3" json:"max_outstanding_bytes,omitempty"`
	// contains filtered or unexported fields
}

Request for the `StreamingPull` streaming RPC method. This request is used to establish the initial stream as well as to stream acknowledgements and ack deadline modifications from the client to the server.

func (*StreamingPullRequest) Descriptor deprecated

func (*StreamingPullRequest) Descriptor() ([]byte, []int)

Deprecated: Use StreamingPullRequest.ProtoReflect.Descriptor instead.

func (*StreamingPullRequest) GetAckIds

func (x *StreamingPullRequest) GetAckIds() []string

func (*StreamingPullRequest) GetClientId

func (x *StreamingPullRequest) GetClientId() string

func (*StreamingPullRequest) GetMaxOutstandingBytes

func (x *StreamingPullRequest) GetMaxOutstandingBytes() int64

func (*StreamingPullRequest) GetMaxOutstandingMessages

func (x *StreamingPullRequest) GetMaxOutstandingMessages() int64

func (*StreamingPullRequest) GetModifyDeadlineAckIds

func (x *StreamingPullRequest) GetModifyDeadlineAckIds() []string

func (*StreamingPullRequest) GetModifyDeadlineSeconds

func (x *StreamingPullRequest) GetModifyDeadlineSeconds() []int32

func (*StreamingPullRequest) GetStreamAckDeadlineSeconds

func (x *StreamingPullRequest) GetStreamAckDeadlineSeconds() int32

func (*StreamingPullRequest) GetSubscription

func (x *StreamingPullRequest) GetSubscription() string

func (*StreamingPullRequest) ProtoMessage

func (*StreamingPullRequest) ProtoMessage()

func (*StreamingPullRequest) ProtoReflect

func (x *StreamingPullRequest) ProtoReflect() protoreflect.Message

func (*StreamingPullRequest) Reset

func (x *StreamingPullRequest) Reset()

func (*StreamingPullRequest) String

func (x *StreamingPullRequest) String() string

type StreamingPullResponse

type StreamingPullResponse struct {

	// Optional. Received Pub/Sub messages. This will not be empty.
	ReceivedMessages []*ReceivedMessage `protobuf:"bytes,1,rep,name=received_messages,json=receivedMessages,proto3" json:"received_messages,omitempty"`
	// Optional. This field will only be set if `enable_exactly_once_delivery` is
	// set to `true`.
	AcknowledgeConfirmation *StreamingPullResponse_AcknowledgeConfirmation `` /* 130-byte string literal not displayed */
	// Optional. This field will only be set if `enable_exactly_once_delivery` is
	// set to `true`.
	ModifyAckDeadlineConfirmation *StreamingPullResponse_ModifyAckDeadlineConfirmation `` /* 152-byte string literal not displayed */
	// Optional. Properties associated with this subscription.
	SubscriptionProperties *StreamingPullResponse_SubscriptionProperties `` /* 127-byte string literal not displayed */
	// contains filtered or unexported fields
}

Response for the `StreamingPull` method. This response is used to stream messages from the server to the client.

func (*StreamingPullResponse) Descriptor deprecated

func (*StreamingPullResponse) Descriptor() ([]byte, []int)

Deprecated: Use StreamingPullResponse.ProtoReflect.Descriptor instead.

func (*StreamingPullResponse) GetAcknowledgeConfirmation

func (*StreamingPullResponse) GetModifyAckDeadlineConfirmation

func (x *StreamingPullResponse) GetModifyAckDeadlineConfirmation() *StreamingPullResponse_ModifyAckDeadlineConfirmation

func (*StreamingPullResponse) GetReceivedMessages

func (x *StreamingPullResponse) GetReceivedMessages() []*ReceivedMessage

func (*StreamingPullResponse) GetSubscriptionProperties

func (*StreamingPullResponse) ProtoMessage

func (*StreamingPullResponse) ProtoMessage()

func (*StreamingPullResponse) ProtoReflect

func (x *StreamingPullResponse) ProtoReflect() protoreflect.Message

func (*StreamingPullResponse) Reset

func (x *StreamingPullResponse) Reset()

func (*StreamingPullResponse) String

func (x *StreamingPullResponse) String() string

type StreamingPullResponse_AcknowledgeConfirmation

type StreamingPullResponse_AcknowledgeConfirmation struct {

	// Optional. Successfully processed acknowledgement IDs.
	AckIds []string `protobuf:"bytes,1,rep,name=ack_ids,json=ackIds,proto3" json:"ack_ids,omitempty"`
	// Optional. List of acknowledgement IDs that were malformed or whose
	// acknowledgement deadline has expired.
	InvalidAckIds []string `protobuf:"bytes,2,rep,name=invalid_ack_ids,json=invalidAckIds,proto3" json:"invalid_ack_ids,omitempty"`
	// Optional. List of acknowledgement IDs that were out of order.
	UnorderedAckIds []string `protobuf:"bytes,3,rep,name=unordered_ack_ids,json=unorderedAckIds,proto3" json:"unordered_ack_ids,omitempty"`
	// Optional. List of acknowledgement IDs that failed processing with
	// temporary issues.
	TemporaryFailedAckIds []string `` /* 128-byte string literal not displayed */
	// contains filtered or unexported fields
}

Acknowledgement IDs sent in one or more previous requests to acknowledge a previously received message.

func (*StreamingPullResponse_AcknowledgeConfirmation) Descriptor deprecated

Deprecated: Use StreamingPullResponse_AcknowledgeConfirmation.ProtoReflect.Descriptor instead.

func (*StreamingPullResponse_AcknowledgeConfirmation) GetAckIds

func (*StreamingPullResponse_AcknowledgeConfirmation) GetInvalidAckIds

func (x *StreamingPullResponse_AcknowledgeConfirmation) GetInvalidAckIds() []string

func (*StreamingPullResponse_AcknowledgeConfirmation) GetTemporaryFailedAckIds added in v1.29.0

func (x *StreamingPullResponse_AcknowledgeConfirmation) GetTemporaryFailedAckIds() []string

func (*StreamingPullResponse_AcknowledgeConfirmation) GetUnorderedAckIds

func (x *StreamingPullResponse_AcknowledgeConfirmation) GetUnorderedAckIds() []string

func (*StreamingPullResponse_AcknowledgeConfirmation) ProtoMessage

func (*StreamingPullResponse_AcknowledgeConfirmation) ProtoReflect

func (*StreamingPullResponse_AcknowledgeConfirmation) Reset

func (*StreamingPullResponse_AcknowledgeConfirmation) String

type StreamingPullResponse_ModifyAckDeadlineConfirmation

type StreamingPullResponse_ModifyAckDeadlineConfirmation struct {

	// Optional. Successfully processed acknowledgement IDs.
	AckIds []string `protobuf:"bytes,1,rep,name=ack_ids,json=ackIds,proto3" json:"ack_ids,omitempty"`
	// Optional. List of acknowledgement IDs that were malformed or whose
	// acknowledgement deadline has expired.
	InvalidAckIds []string `protobuf:"bytes,2,rep,name=invalid_ack_ids,json=invalidAckIds,proto3" json:"invalid_ack_ids,omitempty"`
	// Optional. List of acknowledgement IDs that failed processing with
	// temporary issues.
	TemporaryFailedAckIds []string `` /* 128-byte string literal not displayed */
	// contains filtered or unexported fields
}

Acknowledgement IDs sent in one or more previous requests to modify the deadline for a specific message.

func (*StreamingPullResponse_ModifyAckDeadlineConfirmation) Descriptor deprecated

Deprecated: Use StreamingPullResponse_ModifyAckDeadlineConfirmation.ProtoReflect.Descriptor instead.

func (*StreamingPullResponse_ModifyAckDeadlineConfirmation) GetAckIds

func (*StreamingPullResponse_ModifyAckDeadlineConfirmation) GetInvalidAckIds

func (*StreamingPullResponse_ModifyAckDeadlineConfirmation) GetTemporaryFailedAckIds added in v1.29.0

func (x *StreamingPullResponse_ModifyAckDeadlineConfirmation) GetTemporaryFailedAckIds() []string

func (*StreamingPullResponse_ModifyAckDeadlineConfirmation) ProtoMessage

func (*StreamingPullResponse_ModifyAckDeadlineConfirmation) ProtoReflect

func (*StreamingPullResponse_ModifyAckDeadlineConfirmation) Reset

func (*StreamingPullResponse_ModifyAckDeadlineConfirmation) String

type StreamingPullResponse_SubscriptionProperties

type StreamingPullResponse_SubscriptionProperties struct {

	// Optional. True iff exactly once delivery is enabled for this
	// subscription.
	ExactlyOnceDeliveryEnabled bool `` /* 144-byte string literal not displayed */
	// Optional. True iff message ordering is enabled for this subscription.
	MessageOrderingEnabled bool `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

Subscription properties sent as part of the response.

func (*StreamingPullResponse_SubscriptionProperties) Descriptor deprecated

Deprecated: Use StreamingPullResponse_SubscriptionProperties.ProtoReflect.Descriptor instead.

func (*StreamingPullResponse_SubscriptionProperties) GetExactlyOnceDeliveryEnabled

func (x *StreamingPullResponse_SubscriptionProperties) GetExactlyOnceDeliveryEnabled() bool

func (*StreamingPullResponse_SubscriptionProperties) GetMessageOrderingEnabled

func (x *StreamingPullResponse_SubscriptionProperties) GetMessageOrderingEnabled() bool

func (*StreamingPullResponse_SubscriptionProperties) ProtoMessage

func (*StreamingPullResponse_SubscriptionProperties) ProtoReflect

func (*StreamingPullResponse_SubscriptionProperties) Reset

func (*StreamingPullResponse_SubscriptionProperties) String

type SubscriberClient

type SubscriberClient interface {
	// Creates a subscription to a given topic. See the [resource name rules]
	// (https://cloud.google.com/pubsub/docs/pubsub-basics#resource_names).
	// If the subscription already exists, returns `ALREADY_EXISTS`.
	// If the corresponding topic doesn't exist, returns `NOT_FOUND`.
	//
	// If the name is not provided in the request, the server will assign a random
	// name for this subscription on the same project as the topic, conforming
	// to the [resource name format]
	// (https://cloud.google.com/pubsub/docs/pubsub-basics#resource_names). The
	// generated name is populated in the returned Subscription object. Note that
	// for REST API requests, you must specify a name in the request.
	CreateSubscription(ctx context.Context, in *Subscription, opts ...grpc.CallOption) (*Subscription, error)
	// Gets the configuration details of a subscription.
	GetSubscription(ctx context.Context, in *GetSubscriptionRequest, opts ...grpc.CallOption) (*Subscription, error)
	// Updates an existing subscription by updating the fields specified in the
	// update mask. Note that certain properties of a subscription, such as its
	// topic, are not modifiable.
	UpdateSubscription(ctx context.Context, in *UpdateSubscriptionRequest, opts ...grpc.CallOption) (*Subscription, error)
	// Lists matching subscriptions.
	ListSubscriptions(ctx context.Context, in *ListSubscriptionsRequest, opts ...grpc.CallOption) (*ListSubscriptionsResponse, error)
	// Deletes an existing subscription. All messages retained in the subscription
	// are immediately dropped. Calls to `Pull` after deletion will return
	// `NOT_FOUND`. After a subscription is deleted, a new one may be created with
	// the same name, but the new one has no association with the old
	// subscription or its topic unless the same topic is specified.
	DeleteSubscription(ctx context.Context, in *DeleteSubscriptionRequest, opts ...grpc.CallOption) (*emptypb.Empty, error)
	// Modifies the ack deadline for a specific message. This method is useful
	// to indicate that more time is needed to process a message by the
	// subscriber, or to make the message available for redelivery if the
	// processing was interrupted. Note that this does not modify the
	// subscription-level `ackDeadlineSeconds` used for subsequent messages.
	ModifyAckDeadline(ctx context.Context, in *ModifyAckDeadlineRequest, opts ...grpc.CallOption) (*emptypb.Empty, error)
	// Acknowledges the messages associated with the `ack_ids` in the
	// `AcknowledgeRequest`. The Pub/Sub system can remove the relevant messages
	// from the subscription.
	//
	// Acknowledging a message whose ack deadline has expired may succeed,
	// but such a message may be redelivered later. Acknowledging a message more
	// than once will not result in an error.
	Acknowledge(ctx context.Context, in *AcknowledgeRequest, opts ...grpc.CallOption) (*emptypb.Empty, error)
	// Pulls messages from the server.
	Pull(ctx context.Context, in *PullRequest, opts ...grpc.CallOption) (*PullResponse, error)
	// Establishes a stream with the server, which sends messages down to the
	// client. The client streams acknowledgements and ack deadline modifications
	// back to the server. The server will close the stream and return the status
	// on any error. The server may close the stream with status `UNAVAILABLE` to
	// reassign server-side resources, in which case, the client should
	// re-establish the stream. Flow control can be achieved by configuring the
	// underlying RPC channel.
	StreamingPull(ctx context.Context, opts ...grpc.CallOption) (Subscriber_StreamingPullClient, error)
	// Modifies the `PushConfig` for a specified subscription.
	//
	// This may be used to change a push subscription to a pull one (signified by
	// an empty `PushConfig`) or vice versa, or change the endpoint URL and other
	// attributes of a push subscription. Messages will accumulate for delivery
	// continuously through the call regardless of changes to the `PushConfig`.
	ModifyPushConfig(ctx context.Context, in *ModifyPushConfigRequest, opts ...grpc.CallOption) (*emptypb.Empty, error)
	// Gets the configuration details of a snapshot. Snapshots are used in
	// [Seek](https://cloud.google.com/pubsub/docs/replay-overview) operations,
	// which allow you to manage message acknowledgments in bulk. That is, you can
	// set the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	GetSnapshot(ctx context.Context, in *GetSnapshotRequest, opts ...grpc.CallOption) (*Snapshot, error)
	// Lists the existing snapshots. Snapshots are used in [Seek](
	// https://cloud.google.com/pubsub/docs/replay-overview) operations, which
	// allow you to manage message acknowledgments in bulk. That is, you can set
	// the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	ListSnapshots(ctx context.Context, in *ListSnapshotsRequest, opts ...grpc.CallOption) (*ListSnapshotsResponse, error)
	// Creates a snapshot from the requested subscription. Snapshots are used in
	// [Seek](https://cloud.google.com/pubsub/docs/replay-overview) operations,
	// which allow you to manage message acknowledgments in bulk. That is, you can
	// set the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	// If the snapshot already exists, returns `ALREADY_EXISTS`.
	// If the requested subscription doesn't exist, returns `NOT_FOUND`.
	// If the backlog in the subscription is too old -- and the resulting snapshot
	// would expire in less than 1 hour -- then `FAILED_PRECONDITION` is returned.
	// See also the `Snapshot.expire_time` field. If the name is not provided in
	// the request, the server will assign a random
	// name for this snapshot on the same project as the subscription, conforming
	// to the [resource name format]
	// (https://cloud.google.com/pubsub/docs/pubsub-basics#resource_names). The
	// generated name is populated in the returned Snapshot object. Note that for
	// REST API requests, you must specify a name in the request.
	CreateSnapshot(ctx context.Context, in *CreateSnapshotRequest, opts ...grpc.CallOption) (*Snapshot, error)
	// Updates an existing snapshot by updating the fields specified in the update
	// mask. Snapshots are used in
	// [Seek](https://cloud.google.com/pubsub/docs/replay-overview) operations,
	// which allow you to manage message acknowledgments in bulk. That is, you can
	// set the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	UpdateSnapshot(ctx context.Context, in *UpdateSnapshotRequest, opts ...grpc.CallOption) (*Snapshot, error)
	// Removes an existing snapshot. Snapshots are used in [Seek]
	// (https://cloud.google.com/pubsub/docs/replay-overview) operations, which
	// allow you to manage message acknowledgments in bulk. That is, you can set
	// the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	// When the snapshot is deleted, all messages retained in the snapshot
	// are immediately dropped. After a snapshot is deleted, a new one may be
	// created with the same name, but the new one has no association with the old
	// snapshot or its subscription, unless the same subscription is specified.
	DeleteSnapshot(ctx context.Context, in *DeleteSnapshotRequest, opts ...grpc.CallOption) (*emptypb.Empty, error)
	// Seeks an existing subscription to a point in time or to a given snapshot,
	// whichever is provided in the request. Snapshots are used in [Seek]
	// (https://cloud.google.com/pubsub/docs/replay-overview) operations, which
	// allow you to manage message acknowledgments in bulk. That is, you can set
	// the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot. Note that both the subscription and the
	// snapshot must be on the same topic.
	Seek(ctx context.Context, in *SeekRequest, opts ...grpc.CallOption) (*SeekResponse, error)
}

SubscriberClient is the client API for Subscriber service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

func NewSubscriberClient

func NewSubscriberClient(cc grpc.ClientConnInterface) SubscriberClient

type SubscriberServer

type SubscriberServer interface {
	// Creates a subscription to a given topic. See the [resource name rules]
	// (https://cloud.google.com/pubsub/docs/pubsub-basics#resource_names).
	// If the subscription already exists, returns `ALREADY_EXISTS`.
	// If the corresponding topic doesn't exist, returns `NOT_FOUND`.
	//
	// If the name is not provided in the request, the server will assign a random
	// name for this subscription on the same project as the topic, conforming
	// to the [resource name format]
	// (https://cloud.google.com/pubsub/docs/pubsub-basics#resource_names). The
	// generated name is populated in the returned Subscription object. Note that
	// for REST API requests, you must specify a name in the request.
	CreateSubscription(context.Context, *Subscription) (*Subscription, error)
	// Gets the configuration details of a subscription.
	GetSubscription(context.Context, *GetSubscriptionRequest) (*Subscription, error)
	// Updates an existing subscription by updating the fields specified in the
	// update mask. Note that certain properties of a subscription, such as its
	// topic, are not modifiable.
	UpdateSubscription(context.Context, *UpdateSubscriptionRequest) (*Subscription, error)
	// Lists matching subscriptions.
	ListSubscriptions(context.Context, *ListSubscriptionsRequest) (*ListSubscriptionsResponse, error)
	// Deletes an existing subscription. All messages retained in the subscription
	// are immediately dropped. Calls to `Pull` after deletion will return
	// `NOT_FOUND`. After a subscription is deleted, a new one may be created with
	// the same name, but the new one has no association with the old
	// subscription or its topic unless the same topic is specified.
	DeleteSubscription(context.Context, *DeleteSubscriptionRequest) (*emptypb.Empty, error)
	// Modifies the ack deadline for a specific message. This method is useful
	// to indicate that more time is needed to process a message by the
	// subscriber, or to make the message available for redelivery if the
	// processing was interrupted. Note that this does not modify the
	// subscription-level `ackDeadlineSeconds` used for subsequent messages.
	ModifyAckDeadline(context.Context, *ModifyAckDeadlineRequest) (*emptypb.Empty, error)
	// Acknowledges the messages associated with the `ack_ids` in the
	// `AcknowledgeRequest`. The Pub/Sub system can remove the relevant messages
	// from the subscription.
	//
	// Acknowledging a message whose ack deadline has expired may succeed,
	// but such a message may be redelivered later. Acknowledging a message more
	// than once will not result in an error.
	Acknowledge(context.Context, *AcknowledgeRequest) (*emptypb.Empty, error)
	// Pulls messages from the server.
	Pull(context.Context, *PullRequest) (*PullResponse, error)
	// Establishes a stream with the server, which sends messages down to the
	// client. The client streams acknowledgements and ack deadline modifications
	// back to the server. The server will close the stream and return the status
	// on any error. The server may close the stream with status `UNAVAILABLE` to
	// reassign server-side resources, in which case, the client should
	// re-establish the stream. Flow control can be achieved by configuring the
	// underlying RPC channel.
	StreamingPull(Subscriber_StreamingPullServer) error
	// Modifies the `PushConfig` for a specified subscription.
	//
	// This may be used to change a push subscription to a pull one (signified by
	// an empty `PushConfig`) or vice versa, or change the endpoint URL and other
	// attributes of a push subscription. Messages will accumulate for delivery
	// continuously through the call regardless of changes to the `PushConfig`.
	ModifyPushConfig(context.Context, *ModifyPushConfigRequest) (*emptypb.Empty, error)
	// Gets the configuration details of a snapshot. Snapshots are used in
	// [Seek](https://cloud.google.com/pubsub/docs/replay-overview) operations,
	// which allow you to manage message acknowledgments in bulk. That is, you can
	// set the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	GetSnapshot(context.Context, *GetSnapshotRequest) (*Snapshot, error)
	// Lists the existing snapshots. Snapshots are used in [Seek](
	// https://cloud.google.com/pubsub/docs/replay-overview) operations, which
	// allow you to manage message acknowledgments in bulk. That is, you can set
	// the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	ListSnapshots(context.Context, *ListSnapshotsRequest) (*ListSnapshotsResponse, error)
	// Creates a snapshot from the requested subscription. Snapshots are used in
	// [Seek](https://cloud.google.com/pubsub/docs/replay-overview) operations,
	// which allow you to manage message acknowledgments in bulk. That is, you can
	// set the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	// If the snapshot already exists, returns `ALREADY_EXISTS`.
	// If the requested subscription doesn't exist, returns `NOT_FOUND`.
	// If the backlog in the subscription is too old -- and the resulting snapshot
	// would expire in less than 1 hour -- then `FAILED_PRECONDITION` is returned.
	// See also the `Snapshot.expire_time` field. If the name is not provided in
	// the request, the server will assign a random
	// name for this snapshot on the same project as the subscription, conforming
	// to the [resource name format]
	// (https://cloud.google.com/pubsub/docs/pubsub-basics#resource_names). The
	// generated name is populated in the returned Snapshot object. Note that for
	// REST API requests, you must specify a name in the request.
	CreateSnapshot(context.Context, *CreateSnapshotRequest) (*Snapshot, error)
	// Updates an existing snapshot by updating the fields specified in the update
	// mask. Snapshots are used in
	// [Seek](https://cloud.google.com/pubsub/docs/replay-overview) operations,
	// which allow you to manage message acknowledgments in bulk. That is, you can
	// set the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	UpdateSnapshot(context.Context, *UpdateSnapshotRequest) (*Snapshot, error)
	// Removes an existing snapshot. Snapshots are used in [Seek]
	// (https://cloud.google.com/pubsub/docs/replay-overview) operations, which
	// allow you to manage message acknowledgments in bulk. That is, you can set
	// the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot.
	// When the snapshot is deleted, all messages retained in the snapshot
	// are immediately dropped. After a snapshot is deleted, a new one may be
	// created with the same name, but the new one has no association with the old
	// snapshot or its subscription, unless the same subscription is specified.
	DeleteSnapshot(context.Context, *DeleteSnapshotRequest) (*emptypb.Empty, error)
	// Seeks an existing subscription to a point in time or to a given snapshot,
	// whichever is provided in the request. Snapshots are used in [Seek]
	// (https://cloud.google.com/pubsub/docs/replay-overview) operations, which
	// allow you to manage message acknowledgments in bulk. That is, you can set
	// the acknowledgment state of messages in an existing subscription to the
	// state captured by a snapshot. Note that both the subscription and the
	// snapshot must be on the same topic.
	Seek(context.Context, *SeekRequest) (*SeekResponse, error)
}

SubscriberServer is the server API for Subscriber service.

type Subscriber_StreamingPullClient

type Subscriber_StreamingPullClient interface {
	Send(*StreamingPullRequest) error
	Recv() (*StreamingPullResponse, error)
	grpc.ClientStream
}

type Subscriber_StreamingPullServer

type Subscriber_StreamingPullServer interface {
	Send(*StreamingPullResponse) error
	Recv() (*StreamingPullRequest, error)
	grpc.ServerStream
}

type Subscription

type Subscription struct {

	// Required. The name of the subscription. It must have the format
	// `"projects/{project}/subscriptions/{subscription}"`. `{subscription}` must
	// start with a letter, and contain only letters (`[A-Za-z]`), numbers
	// (`[0-9]`), dashes (`-`), underscores (`_`), periods (`.`), tildes (`~`),
	// plus (`+`) or percent signs (`%`). It must be between 3 and 255 characters
	// in length, and it must not start with `"goog"`.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Required. The name of the topic from which this subscription is receiving
	// messages. Format is `projects/{project}/topics/{topic}`. The value of this
	// field will be `_deleted-topic_` if the topic has been deleted.
	Topic string `protobuf:"bytes,2,opt,name=topic,proto3" json:"topic,omitempty"`
	// Optional. If push delivery is used with this subscription, this field is
	// used to configure it.
	PushConfig *PushConfig `protobuf:"bytes,4,opt,name=push_config,json=pushConfig,proto3" json:"push_config,omitempty"`
	// Optional. If delivery to BigQuery is used with this subscription, this
	// field is used to configure it.
	BigqueryConfig *BigQueryConfig `protobuf:"bytes,18,opt,name=bigquery_config,json=bigqueryConfig,proto3" json:"bigquery_config,omitempty"`
	// Optional. If delivery to Google Cloud Storage is used with this
	// subscription, this field is used to configure it.
	CloudStorageConfig *CloudStorageConfig `protobuf:"bytes,22,opt,name=cloud_storage_config,json=cloudStorageConfig,proto3" json:"cloud_storage_config,omitempty"`
	// Optional. The approximate amount of time (on a best-effort basis) Pub/Sub
	// waits for the subscriber to acknowledge receipt before resending the
	// message. In the interval after the message is delivered and before it is
	// acknowledged, it is considered to be _outstanding_. During that time
	// period, the message will not be redelivered (on a best-effort basis).
	//
	// For pull subscriptions, this value is used as the initial value for the ack
	// deadline. To override this value for a given message, call
	// `ModifyAckDeadline` with the corresponding `ack_id` if using
	// non-streaming pull or send the `ack_id` in a
	// `StreamingModifyAckDeadlineRequest` if using streaming pull.
	// The minimum custom deadline you can specify is 10 seconds.
	// The maximum custom deadline you can specify is 600 seconds (10 minutes).
	// If this parameter is 0, a default value of 10 seconds is used.
	//
	// For push delivery, this value is also used to set the request timeout for
	// the call to the push endpoint.
	//
	// If the subscriber never acknowledges the message, the Pub/Sub
	// system will eventually redeliver the message.
	AckDeadlineSeconds int32 `protobuf:"varint,5,opt,name=ack_deadline_seconds,json=ackDeadlineSeconds,proto3" json:"ack_deadline_seconds,omitempty"`
	// Optional. Indicates whether to retain acknowledged messages. If true, then
	// messages are not expunged from the subscription's backlog, even if they are
	// acknowledged, until they fall out of the `message_retention_duration`
	// window. This must be true if you would like to [`Seek` to a timestamp]
	// (https://cloud.google.com/pubsub/docs/replay-overview#seek_to_a_time) in
	// the past to replay previously-acknowledged messages.
	RetainAckedMessages bool `protobuf:"varint,7,opt,name=retain_acked_messages,json=retainAckedMessages,proto3" json:"retain_acked_messages,omitempty"`
	// Optional. How long to retain unacknowledged messages in the subscription's
	// backlog, from the moment a message is published. If `retain_acked_messages`
	// is true, then this also configures the retention of acknowledged messages,
	// and thus configures how far back in time a `Seek` can be done. Defaults to
	// 7 days. Cannot be more than 7 days or less than 10 minutes.
	MessageRetentionDuration *durationpb.Duration `` /* 135-byte string literal not displayed */
	// Optional. See [Creating and managing
	// labels](https://cloud.google.com/pubsub/docs/labels).
	Labels map[string]string `` /* 153-byte string literal not displayed */
	// Optional. If true, messages published with the same `ordering_key` in
	// `PubsubMessage` will be delivered to the subscribers in the order in which
	// they are received by the Pub/Sub system. Otherwise, they may be delivered
	// in any order.
	EnableMessageOrdering bool `` /* 128-byte string literal not displayed */
	// Optional. A policy that specifies the conditions for this subscription's
	// expiration. A subscription is considered active as long as any connected
	// subscriber is successfully consuming messages from the subscription or is
	// issuing operations on the subscription. If `expiration_policy` is not set,
	// a *default policy* with `ttl` of 31 days will be used. The minimum allowed
	// value for `expiration_policy.ttl` is 1 day. If `expiration_policy` is set,
	// but `expiration_policy.ttl` is not set, the subscription never expires.
	ExpirationPolicy *ExpirationPolicy `protobuf:"bytes,11,opt,name=expiration_policy,json=expirationPolicy,proto3" json:"expiration_policy,omitempty"`
	// Optional. An expression written in the Pub/Sub [filter
	// language](https://cloud.google.com/pubsub/docs/filtering). If non-empty,
	// then only `PubsubMessage`s whose `attributes` field matches the filter are
	// delivered on this subscription. If empty, then no messages are filtered
	// out.
	Filter string `protobuf:"bytes,12,opt,name=filter,proto3" json:"filter,omitempty"`
	// Optional. A policy that specifies the conditions for dead lettering
	// messages in this subscription. If dead_letter_policy is not set, dead
	// lettering is disabled.
	//
	// The Pub/Sub service account associated with this subscriptions's
	// parent project (i.e.,
	// service-{project_number}@gcp-sa-pubsub.iam.gserviceaccount.com) must have
	// permission to Acknowledge() messages on this subscription.
	DeadLetterPolicy *DeadLetterPolicy `protobuf:"bytes,13,opt,name=dead_letter_policy,json=deadLetterPolicy,proto3" json:"dead_letter_policy,omitempty"`
	// Optional. A policy that specifies how Pub/Sub retries message delivery for
	// this subscription.
	//
	// If not set, the default retry policy is applied. This generally implies
	// that messages will be retried as soon as possible for healthy subscribers.
	// RetryPolicy will be triggered on NACKs or acknowledgement deadline
	// exceeded events for a given message.
	RetryPolicy *RetryPolicy `protobuf:"bytes,14,opt,name=retry_policy,json=retryPolicy,proto3" json:"retry_policy,omitempty"`
	// Optional. Indicates whether the subscription is detached from its topic.
	// Detached subscriptions don't receive messages from their topic and don't
	// retain any backlog. `Pull` and `StreamingPull` requests will return
	// FAILED_PRECONDITION. If the subscription is a push subscription, pushes to
	// the endpoint will not be made.
	Detached bool `protobuf:"varint,15,opt,name=detached,proto3" json:"detached,omitempty"`
	// Optional. If true, Pub/Sub provides the following guarantees for the
	// delivery of a message with a given value of `message_id` on this
	// subscription:
	//
	// * The message sent to a subscriber is guaranteed not to be resent
	// before the message's acknowledgement deadline expires.
	// * An acknowledged message will not be resent to a subscriber.
	//
	// Note that subscribers may still receive multiple copies of a message
	// when `enable_exactly_once_delivery` is true if the message was published
	// multiple times by a publisher client. These copies are  considered distinct
	// by Pub/Sub and have distinct `message_id` values.
	EnableExactlyOnceDelivery bool `` /* 142-byte string literal not displayed */
	// Output only. Indicates the minimum duration for which a message is retained
	// after it is published to the subscription's topic. If this field is set,
	// messages published to the subscription's topic in the last
	// `topic_message_retention_duration` are always available to subscribers. See
	// the `message_retention_duration` field in `Topic`. This field is set only
	// in responses from the server; it is ignored if it is set in any requests.
	TopicMessageRetentionDuration *durationpb.Duration `` /* 153-byte string literal not displayed */
	// Output only. An output-only field indicating whether or not the
	// subscription can receive messages.
	State Subscription_State `protobuf:"varint,19,opt,name=state,proto3,enum=google.pubsub.v1.Subscription_State" json:"state,omitempty"`
	// contains filtered or unexported fields
}

A subscription resource. If none of `push_config`, `bigquery_config`, or `cloud_storage_config` is set, then the subscriber will pull and ack messages using API methods. At most one of these fields may be set.

func (*Subscription) Descriptor deprecated

func (*Subscription) Descriptor() ([]byte, []int)

Deprecated: Use Subscription.ProtoReflect.Descriptor instead.

func (*Subscription) GetAckDeadlineSeconds

func (x *Subscription) GetAckDeadlineSeconds() int32

func (*Subscription) GetBigqueryConfig

func (x *Subscription) GetBigqueryConfig() *BigQueryConfig

func (*Subscription) GetCloudStorageConfig added in v1.31.0

func (x *Subscription) GetCloudStorageConfig() *CloudStorageConfig

func (*Subscription) GetDeadLetterPolicy

func (x *Subscription) GetDeadLetterPolicy() *DeadLetterPolicy

func (*Subscription) GetDetached

func (x *Subscription) GetDetached() bool

func (*Subscription) GetEnableExactlyOnceDelivery

func (x *Subscription) GetEnableExactlyOnceDelivery() bool

func (*Subscription) GetEnableMessageOrdering

func (x *Subscription) GetEnableMessageOrdering() bool

func (*Subscription) GetExpirationPolicy

func (x *Subscription) GetExpirationPolicy() *ExpirationPolicy

func (*Subscription) GetFilter

func (x *Subscription) GetFilter() string

func (*Subscription) GetLabels

func (x *Subscription) GetLabels() map[string]string

func (*Subscription) GetMessageRetentionDuration

func (x *Subscription) GetMessageRetentionDuration() *durationpb.Duration

func (*Subscription) GetName

func (x *Subscription) GetName() string

func (*Subscription) GetPushConfig

func (x *Subscription) GetPushConfig() *PushConfig

func (*Subscription) GetRetainAckedMessages

func (x *Subscription) GetRetainAckedMessages() bool

func (*Subscription) GetRetryPolicy

func (x *Subscription) GetRetryPolicy() *RetryPolicy

func (*Subscription) GetState

func (x *Subscription) GetState() Subscription_State

func (*Subscription) GetTopic

func (x *Subscription) GetTopic() string

func (*Subscription) GetTopicMessageRetentionDuration

func (x *Subscription) GetTopicMessageRetentionDuration() *durationpb.Duration

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_State

type Subscription_State int32

Possible states for a subscription.

const (
	// Default value. This value is unused.
	Subscription_STATE_UNSPECIFIED Subscription_State = 0
	// The subscription can actively receive messages
	Subscription_ACTIVE Subscription_State = 1
	// The subscription cannot receive messages because of an error with the
	// resource to which it pushes messages. See the more detailed error state
	// in the corresponding configuration.
	Subscription_RESOURCE_ERROR Subscription_State = 2
)

func (Subscription_State) Descriptor

func (Subscription_State) Enum

func (Subscription_State) EnumDescriptor deprecated

func (Subscription_State) EnumDescriptor() ([]byte, []int)

Deprecated: Use Subscription_State.Descriptor instead.

func (Subscription_State) Number

func (Subscription_State) String

func (x Subscription_State) String() string

func (Subscription_State) Type

type Topic

type Topic struct {

	// Required. The name of the topic. It must have the format
	// `"projects/{project}/topics/{topic}"`. `{topic}` must start with a letter,
	// and contain only letters (`[A-Za-z]`), numbers (`[0-9]`), dashes (`-`),
	// underscores (`_`), periods (`.`), tildes (`~`), plus (`+`) or percent
	// signs (`%`). It must be between 3 and 255 characters in length, and it
	// must not start with `"goog"`.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// Optional. See [Creating and managing labels]
	// (https://cloud.google.com/pubsub/docs/labels).
	Labels map[string]string `` /* 153-byte string literal not displayed */
	// Optional. Policy constraining the set of Google Cloud Platform regions
	// where messages published to the topic may be stored. If not present, then
	// no constraints are in effect.
	MessageStoragePolicy *MessageStoragePolicy `protobuf:"bytes,3,opt,name=message_storage_policy,json=messageStoragePolicy,proto3" json:"message_storage_policy,omitempty"`
	// Optional. The resource name of the Cloud KMS CryptoKey to be used to
	// protect access to messages published on this topic.
	//
	// The expected format is `projects/*/locations/*/keyRings/*/cryptoKeys/*`.
	KmsKeyName string `protobuf:"bytes,5,opt,name=kms_key_name,json=kmsKeyName,proto3" json:"kms_key_name,omitempty"`
	// Optional. Settings for validating messages published against a schema.
	SchemaSettings *SchemaSettings `protobuf:"bytes,6,opt,name=schema_settings,json=schemaSettings,proto3" json:"schema_settings,omitempty"`
	// Optional. Reserved for future use. This field is set only in responses from
	// the server; it is ignored if it is set in any requests.
	SatisfiesPzs bool `protobuf:"varint,7,opt,name=satisfies_pzs,json=satisfiesPzs,proto3" json:"satisfies_pzs,omitempty"`
	// Optional. Indicates the minimum duration to retain a message after it is
	// published to the topic. If this field is set, messages published to the
	// topic in the last `message_retention_duration` are always available to
	// subscribers. For instance, it allows any attached subscription to [seek to
	// a
	// timestamp](https://cloud.google.com/pubsub/docs/replay-overview#seek_to_a_time)
	// that is up to `message_retention_duration` in the past. If this field is
	// not set, message retention is controlled by settings on individual
	// subscriptions. Cannot be more than 31 days or less than 10 minutes.
	MessageRetentionDuration *durationpb.Duration `` /* 135-byte string literal not displayed */
	// Output only. An output-only field indicating the state of the topic.
	State Topic_State `protobuf:"varint,9,opt,name=state,proto3,enum=google.pubsub.v1.Topic_State" json:"state,omitempty"`
	// Optional. Settings for ingestion from a data source into this topic.
	IngestionDataSourceSettings *IngestionDataSourceSettings `` /* 147-byte string literal not displayed */
	// contains filtered or unexported fields
}

A topic resource.

func (*Topic) Descriptor deprecated

func (*Topic) Descriptor() ([]byte, []int)

Deprecated: Use Topic.ProtoReflect.Descriptor instead.

func (*Topic) GetIngestionDataSourceSettings added in v1.36.0

func (x *Topic) GetIngestionDataSourceSettings() *IngestionDataSourceSettings

func (*Topic) GetKmsKeyName

func (x *Topic) GetKmsKeyName() string

func (*Topic) GetLabels

func (x *Topic) GetLabels() map[string]string

func (*Topic) GetMessageRetentionDuration

func (x *Topic) GetMessageRetentionDuration() *durationpb.Duration

func (*Topic) GetMessageStoragePolicy

func (x *Topic) GetMessageStoragePolicy() *MessageStoragePolicy

func (*Topic) GetName

func (x *Topic) GetName() string

func (*Topic) GetSatisfiesPzs

func (x *Topic) GetSatisfiesPzs() bool

func (*Topic) GetSchemaSettings

func (x *Topic) GetSchemaSettings() *SchemaSettings

func (*Topic) GetState added in v1.36.0

func (x *Topic) GetState() Topic_State

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

func (x *Topic) String() string

type Topic_State added in v1.36.0

type Topic_State int32

The state of the topic.

const (
	// Default value. This value is unused.
	Topic_STATE_UNSPECIFIED Topic_State = 0
	// The topic does not have any persistent errors.
	Topic_ACTIVE Topic_State = 1
	// Ingestion from the data source has encountered a permanent error.
	// See the more detailed error state in the corresponding ingestion
	// source configuration.
	Topic_INGESTION_RESOURCE_ERROR Topic_State = 2
)

func (Topic_State) Descriptor added in v1.36.0

func (Topic_State) Enum added in v1.36.0

func (x Topic_State) Enum() *Topic_State

func (Topic_State) EnumDescriptor deprecated added in v1.36.0

func (Topic_State) EnumDescriptor() ([]byte, []int)

Deprecated: Use Topic_State.Descriptor instead.

func (Topic_State) Number added in v1.36.0

func (x Topic_State) Number() protoreflect.EnumNumber

func (Topic_State) String added in v1.36.0

func (x Topic_State) String() string

func (Topic_State) Type added in v1.36.0

type UnimplementedPublisherServer

type UnimplementedPublisherServer struct {
}

UnimplementedPublisherServer can be embedded to have forward compatible implementations.

func (*UnimplementedPublisherServer) CreateTopic

func (*UnimplementedPublisherServer) DeleteTopic

func (*UnimplementedPublisherServer) DetachSubscription

func (*UnimplementedPublisherServer) GetTopic

func (*UnimplementedPublisherServer) ListTopicSnapshots

func (*UnimplementedPublisherServer) ListTopics

func (*UnimplementedPublisherServer) Publish

func (*UnimplementedPublisherServer) UpdateTopic

type UnimplementedSchemaServiceServer

type UnimplementedSchemaServiceServer struct {
}

UnimplementedSchemaServiceServer can be embedded to have forward compatible implementations.

func (*UnimplementedSchemaServiceServer) CommitSchema added in v1.29.0

func (*UnimplementedSchemaServiceServer) CreateSchema

func (*UnimplementedSchemaServiceServer) DeleteSchema

func (*UnimplementedSchemaServiceServer) DeleteSchemaRevision added in v1.29.0

func (*UnimplementedSchemaServiceServer) GetSchema

func (*UnimplementedSchemaServiceServer) ListSchemaRevisions added in v1.29.0

func (*UnimplementedSchemaServiceServer) ListSchemas

func (*UnimplementedSchemaServiceServer) RollbackSchema added in v1.29.0

func (*UnimplementedSchemaServiceServer) ValidateMessage

func (*UnimplementedSchemaServiceServer) ValidateSchema

type UnimplementedSubscriberServer

type UnimplementedSubscriberServer struct {
}

UnimplementedSubscriberServer can be embedded to have forward compatible implementations.

func (*UnimplementedSubscriberServer) Acknowledge

func (*UnimplementedSubscriberServer) CreateSnapshot

func (*UnimplementedSubscriberServer) CreateSubscription

func (*UnimplementedSubscriberServer) DeleteSnapshot

func (*UnimplementedSubscriberServer) DeleteSubscription

func (*UnimplementedSubscriberServer) GetSnapshot

func (*UnimplementedSubscriberServer) GetSubscription

func (*UnimplementedSubscriberServer) ListSnapshots

func (*UnimplementedSubscriberServer) ListSubscriptions

func (*UnimplementedSubscriberServer) ModifyAckDeadline

func (*UnimplementedSubscriberServer) ModifyPushConfig

func (*UnimplementedSubscriberServer) Pull

func (*UnimplementedSubscriberServer) Seek

func (*UnimplementedSubscriberServer) StreamingPull

func (*UnimplementedSubscriberServer) UpdateSnapshot

func (*UnimplementedSubscriberServer) UpdateSubscription

type UpdateSnapshotRequest

type UpdateSnapshotRequest struct {

	// Required. The updated snapshot object.
	Snapshot *Snapshot `protobuf:"bytes,1,opt,name=snapshot,proto3" json:"snapshot,omitempty"`
	// Required. Indicates which fields in the provided snapshot to update.
	// Must be specified and non-empty.
	UpdateMask *fieldmaskpb.FieldMask `protobuf:"bytes,2,opt,name=update_mask,json=updateMask,proto3" json:"update_mask,omitempty"`
	// contains filtered or unexported fields
}

Request for the UpdateSnapshot method.

func (*UpdateSnapshotRequest) Descriptor deprecated

func (*UpdateSnapshotRequest) Descriptor() ([]byte, []int)

Deprecated: Use UpdateSnapshotRequest.ProtoReflect.Descriptor instead.

func (*UpdateSnapshotRequest) GetSnapshot

func (x *UpdateSnapshotRequest) GetSnapshot() *Snapshot

func (*UpdateSnapshotRequest) GetUpdateMask

func (x *UpdateSnapshotRequest) GetUpdateMask() *fieldmaskpb.FieldMask

func (*UpdateSnapshotRequest) ProtoMessage

func (*UpdateSnapshotRequest) ProtoMessage()

func (*UpdateSnapshotRequest) ProtoReflect

func (x *UpdateSnapshotRequest) ProtoReflect() protoreflect.Message

func (*UpdateSnapshotRequest) Reset

func (x *UpdateSnapshotRequest) Reset()

func (*UpdateSnapshotRequest) String

func (x *UpdateSnapshotRequest) String() string

type UpdateSubscriptionRequest

type UpdateSubscriptionRequest struct {

	// Required. The updated subscription object.
	Subscription *Subscription `protobuf:"bytes,1,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// Required. Indicates which fields in the provided subscription to update.
	// Must be specified and non-empty.
	UpdateMask *fieldmaskpb.FieldMask `protobuf:"bytes,2,opt,name=update_mask,json=updateMask,proto3" json:"update_mask,omitempty"`
	// contains filtered or unexported fields
}

Request for the UpdateSubscription method.

func (*UpdateSubscriptionRequest) Descriptor deprecated

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 (*UpdateSubscriptionRequest) Reset

func (x *UpdateSubscriptionRequest) Reset()

func (*UpdateSubscriptionRequest) String

func (x *UpdateSubscriptionRequest) String() string

type UpdateTopicRequest

type UpdateTopicRequest struct {

	// Required. The updated topic object.
	Topic *Topic `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"`
	// Required. Indicates which fields in the provided topic to update. Must be
	// specified and non-empty. Note that if `update_mask` contains
	// "message_storage_policy" but the `message_storage_policy` is not set in
	// the `topic` provided above, then the updated value is determined by the
	// policy configured at the project or organization level.
	UpdateMask *fieldmaskpb.FieldMask `protobuf:"bytes,2,opt,name=update_mask,json=updateMask,proto3" json:"update_mask,omitempty"`
	// contains filtered or unexported fields
}

Request for the UpdateTopic method.

func (*UpdateTopicRequest) Descriptor deprecated

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

type ValidateMessageRequest

type ValidateMessageRequest struct {

	// Required. The name of the project in which to validate schemas.
	// Format is `projects/{project-id}`.
	Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"`
	// Types that are assignable to SchemaSpec:
	//
	//	*ValidateMessageRequest_Name
	//	*ValidateMessageRequest_Schema
	SchemaSpec isValidateMessageRequest_SchemaSpec `protobuf_oneof:"schema_spec"`
	// Message to validate against the provided `schema_spec`.
	Message []byte `protobuf:"bytes,4,opt,name=message,proto3" json:"message,omitempty"`
	// The encoding expected for messages
	Encoding Encoding `protobuf:"varint,5,opt,name=encoding,proto3,enum=google.pubsub.v1.Encoding" json:"encoding,omitempty"`
	// contains filtered or unexported fields
}

Request for the `ValidateMessage` method.

func (*ValidateMessageRequest) Descriptor deprecated

func (*ValidateMessageRequest) Descriptor() ([]byte, []int)

Deprecated: Use ValidateMessageRequest.ProtoReflect.Descriptor instead.

func (*ValidateMessageRequest) GetEncoding

func (x *ValidateMessageRequest) GetEncoding() Encoding

func (*ValidateMessageRequest) GetMessage

func (x *ValidateMessageRequest) GetMessage() []byte

func (*ValidateMessageRequest) GetName

func (x *ValidateMessageRequest) GetName() string

func (*ValidateMessageRequest) GetParent

func (x *ValidateMessageRequest) GetParent() string

func (*ValidateMessageRequest) GetSchema

func (x *ValidateMessageRequest) GetSchema() *Schema

func (*ValidateMessageRequest) GetSchemaSpec

func (m *ValidateMessageRequest) GetSchemaSpec() isValidateMessageRequest_SchemaSpec

func (*ValidateMessageRequest) ProtoMessage

func (*ValidateMessageRequest) ProtoMessage()

func (*ValidateMessageRequest) ProtoReflect

func (x *ValidateMessageRequest) ProtoReflect() protoreflect.Message

func (*ValidateMessageRequest) Reset

func (x *ValidateMessageRequest) Reset()

func (*ValidateMessageRequest) String

func (x *ValidateMessageRequest) String() string

type ValidateMessageRequest_Name

type ValidateMessageRequest_Name struct {
	// Name of the schema against which to validate.
	//
	// Format is `projects/{project}/schemas/{schema}`.
	Name string `protobuf:"bytes,2,opt,name=name,proto3,oneof"`
}

type ValidateMessageRequest_Schema

type ValidateMessageRequest_Schema struct {
	// Ad-hoc schema against which to validate
	Schema *Schema `protobuf:"bytes,3,opt,name=schema,proto3,oneof"`
}

type ValidateMessageResponse

type ValidateMessageResponse struct {
	// contains filtered or unexported fields
}

Response for the `ValidateMessage` method. Empty for now.

func (*ValidateMessageResponse) Descriptor deprecated

func (*ValidateMessageResponse) Descriptor() ([]byte, []int)

Deprecated: Use ValidateMessageResponse.ProtoReflect.Descriptor instead.

func (*ValidateMessageResponse) ProtoMessage

func (*ValidateMessageResponse) ProtoMessage()

func (*ValidateMessageResponse) ProtoReflect

func (x *ValidateMessageResponse) ProtoReflect() protoreflect.Message

func (*ValidateMessageResponse) Reset

func (x *ValidateMessageResponse) Reset()

func (*ValidateMessageResponse) String

func (x *ValidateMessageResponse) String() string

type ValidateSchemaRequest

type ValidateSchemaRequest struct {

	// Required. The name of the project in which to validate schemas.
	// Format is `projects/{project-id}`.
	Parent string `protobuf:"bytes,1,opt,name=parent,proto3" json:"parent,omitempty"`
	// Required. The schema object to validate.
	Schema *Schema `protobuf:"bytes,2,opt,name=schema,proto3" json:"schema,omitempty"`
	// contains filtered or unexported fields
}

Request for the `ValidateSchema` method.

func (*ValidateSchemaRequest) Descriptor deprecated

func (*ValidateSchemaRequest) Descriptor() ([]byte, []int)

Deprecated: Use ValidateSchemaRequest.ProtoReflect.Descriptor instead.

func (*ValidateSchemaRequest) GetParent

func (x *ValidateSchemaRequest) GetParent() string

func (*ValidateSchemaRequest) GetSchema

func (x *ValidateSchemaRequest) GetSchema() *Schema

func (*ValidateSchemaRequest) ProtoMessage

func (*ValidateSchemaRequest) ProtoMessage()

func (*ValidateSchemaRequest) ProtoReflect

func (x *ValidateSchemaRequest) ProtoReflect() protoreflect.Message

func (*ValidateSchemaRequest) Reset

func (x *ValidateSchemaRequest) Reset()

func (*ValidateSchemaRequest) String

func (x *ValidateSchemaRequest) String() string

type ValidateSchemaResponse

type ValidateSchemaResponse struct {
	// contains filtered or unexported fields
}

Response for the `ValidateSchema` method. Empty for now.

func (*ValidateSchemaResponse) Descriptor deprecated

func (*ValidateSchemaResponse) Descriptor() ([]byte, []int)

Deprecated: Use ValidateSchemaResponse.ProtoReflect.Descriptor instead.

func (*ValidateSchemaResponse) ProtoMessage

func (*ValidateSchemaResponse) ProtoMessage()

func (*ValidateSchemaResponse) ProtoReflect

func (x *ValidateSchemaResponse) ProtoReflect() protoreflect.Message

func (*ValidateSchemaResponse) Reset

func (x *ValidateSchemaResponse) Reset()

func (*ValidateSchemaResponse) String

func (x *ValidateSchemaResponse) String() string

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL