Documentation ¶
Overview ¶
Code generated by gen-types.sh. DO NOT EDIT.
Package pubsubpb is a reverse proxy.
It translates gRPC into RESTful JSON APIs.
Code generated by gen-types.sh. DO NOT EDIT.
Package pubsubpb is a reverse proxy.
It translates gRPC into RESTful JSON APIs.
Index ¶
- Constants
- Variables
- func RegisterPublisherHandler(ctx context.Context, mux *runtime.ServeMux, conn *grpc.ClientConn) error
- func RegisterPublisherHandlerClient(ctx context.Context, mux *runtime.ServeMux, client PublisherClient) error
- func RegisterPublisherHandlerFromEndpoint(ctx context.Context, mux *runtime.ServeMux, endpoint string, ...) (err error)
- func RegisterPublisherHandlerServer(ctx context.Context, mux *runtime.ServeMux, server PublisherServer) error
- func RegisterPublisherServer(s grpc.ServiceRegistrar, srv PublisherServer)
- func RegisterSchemaServiceHandler(ctx context.Context, mux *runtime.ServeMux, conn *grpc.ClientConn) error
- func RegisterSchemaServiceHandlerClient(ctx context.Context, mux *runtime.ServeMux, client SchemaServiceClient) error
- func RegisterSchemaServiceHandlerFromEndpoint(ctx context.Context, mux *runtime.ServeMux, endpoint string, ...) (err error)
- func RegisterSchemaServiceHandlerServer(ctx context.Context, mux *runtime.ServeMux, server SchemaServiceServer) error
- func RegisterSchemaServiceServer(s grpc.ServiceRegistrar, srv SchemaServiceServer)
- func RegisterSubscriberHandler(ctx context.Context, mux *runtime.ServeMux, conn *grpc.ClientConn) error
- func RegisterSubscriberHandlerClient(ctx context.Context, mux *runtime.ServeMux, client SubscriberClient) error
- func RegisterSubscriberHandlerFromEndpoint(ctx context.Context, mux *runtime.ServeMux, endpoint string, ...) (err error)
- func RegisterSubscriberHandlerServer(ctx context.Context, mux *runtime.ServeMux, server SubscriberServer) error
- func RegisterSubscriberServer(s grpc.ServiceRegistrar, srv SubscriberServer)
- type AcknowledgeRequest
- type BigQueryConfig
- type BigQueryConfig_State
- type CloudStorageConfig
- type CloudStorageConfig_AvroConfig
- type CloudStorageConfig_AvroConfig_
- type CloudStorageConfig_State
- type CloudStorageConfig_TextConfig
- type CloudStorageConfig_TextConfig_
- type CommitSchemaRequest
- type CreateSchemaRequest
- type CreateSnapshotRequest
- type DeadLetterPolicy
- type DeleteSchemaRequest
- type DeleteSchemaRevisionRequest
- type DeleteSnapshotRequest
- type DeleteSubscriptionRequest
- type DeleteTopicRequest
- type DetachSubscriptionRequest
- type DetachSubscriptionResponse
- type Encoding
- type ExpirationPolicy
- type GetSchemaRequest
- type GetSnapshotRequest
- type GetSubscriptionRequest
- type GetTopicRequest
- type IngestionDataSourceSettings
- type IngestionDataSourceSettings_AwsKinesis
- type IngestionDataSourceSettings_AwsKinesis_
- type IngestionDataSourceSettings_AwsKinesis_State
- type IngestionDataSourceSettings_CloudStorage
- type IngestionDataSourceSettings_CloudStorage_
- type IngestionDataSourceSettings_CloudStorage_AvroFormat
- type IngestionDataSourceSettings_CloudStorage_AvroFormat_
- type IngestionDataSourceSettings_CloudStorage_PubSubAvroFormat
- type IngestionDataSourceSettings_CloudStorage_PubsubAvroFormat
- type IngestionDataSourceSettings_CloudStorage_State
- type IngestionDataSourceSettings_CloudStorage_TextFormat
- type IngestionDataSourceSettings_CloudStorage_TextFormat_
- type IngestionFailureEvent
- type IngestionFailureEvent_ApiViolationReason
- type IngestionFailureEvent_AvroFailureReason
- type IngestionFailureEvent_CloudStorageFailure
- type IngestionFailureEvent_CloudStorageFailure_
- type IngestionFailureEvent_CloudStorageFailure_ApiViolationReason
- type IngestionFailureEvent_CloudStorageFailure_AvroFailureReason
- type ListSchemaRevisionsRequest
- type ListSchemaRevisionsResponse
- type ListSchemasRequest
- type ListSchemasResponse
- type ListSnapshotsRequest
- type ListSnapshotsResponse
- type ListSubscriptionsRequest
- type ListSubscriptionsResponse
- type ListTopicSnapshotsRequest
- type ListTopicSnapshotsResponse
- type ListTopicSubscriptionsRequest
- type ListTopicSubscriptionsResponse
- type ListTopicsRequest
- type ListTopicsResponse
- type MessageStoragePolicy
- type ModifyAckDeadlineRequest
- type ModifyPushConfigRequest
- type PlatformLogsSettings
- type PlatformLogsSettings_Severity
- type PublishRequest
- type PublishResponse
- type PublisherClient
- type PublisherServer
- type PubsubMessage
- type PullRequest
- type PullResponse
- type PushConfig
- type PushConfig_NoWrapper
- type PushConfig_NoWrapper_
- type PushConfig_OidcToken
- type PushConfig_OidcToken_
- type PushConfig_PubsubWrapper
- type PushConfig_PubsubWrapper_
- type ReceivedMessage
- type RetryPolicy
- type RollbackSchemaRequest
- type Schema
- type SchemaServiceClient
- type SchemaServiceServer
- type SchemaSettings
- type SchemaView
- type Schema_Type
- type SeekRequest
- type SeekRequest_Snapshot
- type SeekRequest_Time
- type SeekResponse
- type Snapshot
- type StreamingPullRequest
- type StreamingPullResponse
- type StreamingPullResponse_AcknowledgeConfirmation
- type StreamingPullResponse_ModifyAckDeadlineConfirmation
- type StreamingPullResponse_SubscriptionProperties
- type SubscriberClient
- type SubscriberServer
- type Subscriber_StreamingPullClient
- type Subscriber_StreamingPullServer
- type Subscription
- type Subscription_AnalyticsHubSubscriptionInfo
- type Subscription_State
- type Topic
- type Topic_State
- type UnimplementedPublisherServer
- func (UnimplementedPublisherServer) CreateTopic(context.Context, *Topic) (*Topic, error)
- func (UnimplementedPublisherServer) DeleteTopic(context.Context, *DeleteTopicRequest) (*empty.Empty, error)
- func (UnimplementedPublisherServer) DetachSubscription(context.Context, *DetachSubscriptionRequest) (*DetachSubscriptionResponse, error)
- func (UnimplementedPublisherServer) GetTopic(context.Context, *GetTopicRequest) (*Topic, error)
- func (UnimplementedPublisherServer) ListTopicSnapshots(context.Context, *ListTopicSnapshotsRequest) (*ListTopicSnapshotsResponse, error)
- func (UnimplementedPublisherServer) ListTopicSubscriptions(context.Context, *ListTopicSubscriptionsRequest) (*ListTopicSubscriptionsResponse, error)
- func (UnimplementedPublisherServer) ListTopics(context.Context, *ListTopicsRequest) (*ListTopicsResponse, error)
- func (UnimplementedPublisherServer) Publish(context.Context, *PublishRequest) (*PublishResponse, error)
- func (UnimplementedPublisherServer) UpdateTopic(context.Context, *UpdateTopicRequest) (*Topic, error)
- type UnimplementedSchemaServiceServer
- func (UnimplementedSchemaServiceServer) CommitSchema(context.Context, *CommitSchemaRequest) (*Schema, error)
- func (UnimplementedSchemaServiceServer) CreateSchema(context.Context, *CreateSchemaRequest) (*Schema, error)
- func (UnimplementedSchemaServiceServer) DeleteSchema(context.Context, *DeleteSchemaRequest) (*empty.Empty, error)
- func (UnimplementedSchemaServiceServer) DeleteSchemaRevision(context.Context, *DeleteSchemaRevisionRequest) (*Schema, error)
- func (UnimplementedSchemaServiceServer) GetSchema(context.Context, *GetSchemaRequest) (*Schema, error)
- func (UnimplementedSchemaServiceServer) ListSchemaRevisions(context.Context, *ListSchemaRevisionsRequest) (*ListSchemaRevisionsResponse, error)
- func (UnimplementedSchemaServiceServer) ListSchemas(context.Context, *ListSchemasRequest) (*ListSchemasResponse, error)
- func (UnimplementedSchemaServiceServer) RollbackSchema(context.Context, *RollbackSchemaRequest) (*Schema, error)
- func (UnimplementedSchemaServiceServer) ValidateMessage(context.Context, *ValidateMessageRequest) (*ValidateMessageResponse, error)
- func (UnimplementedSchemaServiceServer) ValidateSchema(context.Context, *ValidateSchemaRequest) (*ValidateSchemaResponse, error)
- type UnimplementedSubscriberServer
- func (UnimplementedSubscriberServer) Acknowledge(context.Context, *AcknowledgeRequest) (*empty.Empty, error)
- func (UnimplementedSubscriberServer) CreateSnapshot(context.Context, *CreateSnapshotRequest) (*Snapshot, error)
- func (UnimplementedSubscriberServer) CreateSubscription(context.Context, *Subscription) (*Subscription, error)
- func (UnimplementedSubscriberServer) DeleteSnapshot(context.Context, *DeleteSnapshotRequest) (*empty.Empty, error)
- func (UnimplementedSubscriberServer) DeleteSubscription(context.Context, *DeleteSubscriptionRequest) (*empty.Empty, error)
- func (UnimplementedSubscriberServer) GetSnapshot(context.Context, *GetSnapshotRequest) (*Snapshot, error)
- func (UnimplementedSubscriberServer) GetSubscription(context.Context, *GetSubscriptionRequest) (*Subscription, error)
- func (UnimplementedSubscriberServer) ListSnapshots(context.Context, *ListSnapshotsRequest) (*ListSnapshotsResponse, error)
- func (UnimplementedSubscriberServer) ListSubscriptions(context.Context, *ListSubscriptionsRequest) (*ListSubscriptionsResponse, error)
- func (UnimplementedSubscriberServer) ModifyAckDeadline(context.Context, *ModifyAckDeadlineRequest) (*empty.Empty, error)
- func (UnimplementedSubscriberServer) ModifyPushConfig(context.Context, *ModifyPushConfigRequest) (*empty.Empty, error)
- func (UnimplementedSubscriberServer) Pull(context.Context, *PullRequest) (*PullResponse, error)
- func (UnimplementedSubscriberServer) Seek(context.Context, *SeekRequest) (*SeekResponse, error)
- func (UnimplementedSubscriberServer) StreamingPull(grpc.BidiStreamingServer[StreamingPullRequest, StreamingPullResponse]) error
- func (UnimplementedSubscriberServer) UpdateSnapshot(context.Context, *UpdateSnapshotRequest) (*Snapshot, error)
- func (UnimplementedSubscriberServer) UpdateSubscription(context.Context, *UpdateSubscriptionRequest) (*Subscription, error)
- type UnsafePublisherServer
- type UnsafeSchemaServiceServer
- type UnsafeSubscriberServer
- type UpdateSnapshotRequest
- type UpdateSubscriptionRequest
- type UpdateTopicRequest
- type ValidateMessageRequest
- type ValidateMessageRequest_Name
- type ValidateMessageRequest_Schema
- type ValidateMessageResponse
- type ValidateSchemaRequest
- type ValidateSchemaResponse
Constants ¶
const ( Publisher_CreateTopic_FullMethodName = "/google.pubsub.v1.Publisher/CreateTopic" Publisher_UpdateTopic_FullMethodName = "/google.pubsub.v1.Publisher/UpdateTopic" Publisher_Publish_FullMethodName = "/google.pubsub.v1.Publisher/Publish" Publisher_GetTopic_FullMethodName = "/google.pubsub.v1.Publisher/GetTopic" Publisher_ListTopics_FullMethodName = "/google.pubsub.v1.Publisher/ListTopics" Publisher_ListTopicSubscriptions_FullMethodName = "/google.pubsub.v1.Publisher/ListTopicSubscriptions" Publisher_ListTopicSnapshots_FullMethodName = "/google.pubsub.v1.Publisher/ListTopicSnapshots" Publisher_DeleteTopic_FullMethodName = "/google.pubsub.v1.Publisher/DeleteTopic" Publisher_DetachSubscription_FullMethodName = "/google.pubsub.v1.Publisher/DetachSubscription" )
const ( Subscriber_CreateSubscription_FullMethodName = "/google.pubsub.v1.Subscriber/CreateSubscription" Subscriber_GetSubscription_FullMethodName = "/google.pubsub.v1.Subscriber/GetSubscription" Subscriber_UpdateSubscription_FullMethodName = "/google.pubsub.v1.Subscriber/UpdateSubscription" Subscriber_ListSubscriptions_FullMethodName = "/google.pubsub.v1.Subscriber/ListSubscriptions" Subscriber_DeleteSubscription_FullMethodName = "/google.pubsub.v1.Subscriber/DeleteSubscription" Subscriber_ModifyAckDeadline_FullMethodName = "/google.pubsub.v1.Subscriber/ModifyAckDeadline" Subscriber_Acknowledge_FullMethodName = "/google.pubsub.v1.Subscriber/Acknowledge" Subscriber_Pull_FullMethodName = "/google.pubsub.v1.Subscriber/Pull" Subscriber_StreamingPull_FullMethodName = "/google.pubsub.v1.Subscriber/StreamingPull" Subscriber_ModifyPushConfig_FullMethodName = "/google.pubsub.v1.Subscriber/ModifyPushConfig" Subscriber_GetSnapshot_FullMethodName = "/google.pubsub.v1.Subscriber/GetSnapshot" Subscriber_ListSnapshots_FullMethodName = "/google.pubsub.v1.Subscriber/ListSnapshots" Subscriber_CreateSnapshot_FullMethodName = "/google.pubsub.v1.Subscriber/CreateSnapshot" Subscriber_UpdateSnapshot_FullMethodName = "/google.pubsub.v1.Subscriber/UpdateSnapshot" Subscriber_DeleteSnapshot_FullMethodName = "/google.pubsub.v1.Subscriber/DeleteSnapshot" Subscriber_Seek_FullMethodName = "/google.pubsub.v1.Subscriber/Seek" )
const ( SchemaService_CreateSchema_FullMethodName = "/google.pubsub.v1.SchemaService/CreateSchema" SchemaService_GetSchema_FullMethodName = "/google.pubsub.v1.SchemaService/GetSchema" SchemaService_ListSchemas_FullMethodName = "/google.pubsub.v1.SchemaService/ListSchemas" SchemaService_ListSchemaRevisions_FullMethodName = "/google.pubsub.v1.SchemaService/ListSchemaRevisions" SchemaService_CommitSchema_FullMethodName = "/google.pubsub.v1.SchemaService/CommitSchema" SchemaService_RollbackSchema_FullMethodName = "/google.pubsub.v1.SchemaService/RollbackSchema" SchemaService_DeleteSchemaRevision_FullMethodName = "/google.pubsub.v1.SchemaService/DeleteSchemaRevision" SchemaService_DeleteSchema_FullMethodName = "/google.pubsub.v1.SchemaService/DeleteSchema" SchemaService_ValidateSchema_FullMethodName = "/google.pubsub.v1.SchemaService/ValidateSchema" SchemaService_ValidateMessage_FullMethodName = "/google.pubsub.v1.SchemaService/ValidateMessage" )
Variables ¶
var Publisher_ServiceDesc = grpc.ServiceDesc{ ServiceName: "google.pubsub.v1.Publisher", HandlerType: (*PublisherServer)(nil), Methods: []grpc.MethodDesc{ { MethodName: "CreateTopic", Handler: _Publisher_CreateTopic_Handler, }, { MethodName: "UpdateTopic", Handler: _Publisher_UpdateTopic_Handler, }, { MethodName: "Publish", Handler: _Publisher_Publish_Handler, }, { MethodName: "GetTopic", Handler: _Publisher_GetTopic_Handler, }, { MethodName: "ListTopics", Handler: _Publisher_ListTopics_Handler, }, { MethodName: "ListTopicSubscriptions", Handler: _Publisher_ListTopicSubscriptions_Handler, }, { MethodName: "ListTopicSnapshots", Handler: _Publisher_ListTopicSnapshots_Handler, }, { MethodName: "DeleteTopic", Handler: _Publisher_DeleteTopic_Handler, }, { MethodName: "DetachSubscription", Handler: _Publisher_DetachSubscription_Handler, }, }, Streams: []grpc.StreamDesc{}, Metadata: "google/pubsub/v1/pubsub.proto", }
Publisher_ServiceDesc is the grpc.ServiceDesc for Publisher service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)
var SchemaService_ServiceDesc = grpc.ServiceDesc{ ServiceName: "google.pubsub.v1.SchemaService", HandlerType: (*SchemaServiceServer)(nil), Methods: []grpc.MethodDesc{ { MethodName: "CreateSchema", Handler: _SchemaService_CreateSchema_Handler, }, { MethodName: "GetSchema", Handler: _SchemaService_GetSchema_Handler, }, { MethodName: "ListSchemas", Handler: _SchemaService_ListSchemas_Handler, }, { MethodName: "ListSchemaRevisions", Handler: _SchemaService_ListSchemaRevisions_Handler, }, { MethodName: "CommitSchema", Handler: _SchemaService_CommitSchema_Handler, }, { MethodName: "RollbackSchema", Handler: _SchemaService_RollbackSchema_Handler, }, { MethodName: "DeleteSchemaRevision", Handler: _SchemaService_DeleteSchemaRevision_Handler, }, { MethodName: "DeleteSchema", Handler: _SchemaService_DeleteSchema_Handler, }, { MethodName: "ValidateSchema", Handler: _SchemaService_ValidateSchema_Handler, }, { MethodName: "ValidateMessage", Handler: _SchemaService_ValidateMessage_Handler, }, }, Streams: []grpc.StreamDesc{}, Metadata: "google/pubsub/v1/schema.proto", }
SchemaService_ServiceDesc is the grpc.ServiceDesc for SchemaService service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)
var Subscriber_ServiceDesc = grpc.ServiceDesc{ ServiceName: "google.pubsub.v1.Subscriber", HandlerType: (*SubscriberServer)(nil), Methods: []grpc.MethodDesc{ { MethodName: "CreateSubscription", Handler: _Subscriber_CreateSubscription_Handler, }, { MethodName: "GetSubscription", Handler: _Subscriber_GetSubscription_Handler, }, { MethodName: "UpdateSubscription", Handler: _Subscriber_UpdateSubscription_Handler, }, { MethodName: "ListSubscriptions", Handler: _Subscriber_ListSubscriptions_Handler, }, { MethodName: "DeleteSubscription", Handler: _Subscriber_DeleteSubscription_Handler, }, { MethodName: "ModifyAckDeadline", Handler: _Subscriber_ModifyAckDeadline_Handler, }, { MethodName: "Acknowledge", Handler: _Subscriber_Acknowledge_Handler, }, { MethodName: "Pull", Handler: _Subscriber_Pull_Handler, }, { MethodName: "ModifyPushConfig", Handler: _Subscriber_ModifyPushConfig_Handler, }, { MethodName: "GetSnapshot", Handler: _Subscriber_GetSnapshot_Handler, }, { MethodName: "ListSnapshots", Handler: _Subscriber_ListSnapshots_Handler, }, { MethodName: "CreateSnapshot", Handler: _Subscriber_CreateSnapshot_Handler, }, { MethodName: "UpdateSnapshot", Handler: _Subscriber_UpdateSnapshot_Handler, }, { MethodName: "DeleteSnapshot", Handler: _Subscriber_DeleteSnapshot_Handler, }, { MethodName: "Seek", Handler: _Subscriber_Seek_Handler, }, }, Streams: []grpc.StreamDesc{ { StreamName: "StreamingPull", Handler: _Subscriber_StreamingPull_Handler, ServerStreams: true, ClientStreams: true, }, }, Metadata: "google/pubsub/v1/pubsub.proto", }
Subscriber_ServiceDesc is the grpc.ServiceDesc for Subscriber service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)
Functions ¶
func RegisterPublisherHandler ¶
func RegisterPublisherHandler(ctx context.Context, mux *runtime.ServeMux, conn *grpc.ClientConn) error
RegisterPublisherHandler registers the http handlers for service Publisher to "mux". The handlers forward requests to the grpc endpoint over "conn".
func RegisterPublisherHandlerClient ¶
func RegisterPublisherHandlerClient(ctx context.Context, mux *runtime.ServeMux, client PublisherClient) error
RegisterPublisherHandlerClient registers the http handlers for service Publisher to "mux". The handlers forward requests to the grpc endpoint over the given implementation of "PublisherClient". Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "PublisherClient" doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in "PublisherClient" to call the correct interceptors. This client ignores the HTTP middlewares.
func RegisterPublisherHandlerFromEndpoint ¶
func RegisterPublisherHandlerFromEndpoint(ctx context.Context, mux *runtime.ServeMux, endpoint string, opts []grpc.DialOption) (err error)
RegisterPublisherHandlerFromEndpoint is same as RegisterPublisherHandler but automatically dials to "endpoint" and closes the connection when "ctx" gets done.
func RegisterPublisherHandlerServer ¶
func RegisterPublisherHandlerServer(ctx context.Context, mux *runtime.ServeMux, server PublisherServer) error
RegisterPublisherHandlerServer registers the http handlers for service Publisher to "mux". UnaryRPC :call PublisherServer directly. StreamingRPC :currently unsupported pending https://github.com/grpc/grpc-go/issues/906. Note that using this registration option will cause many gRPC library features to stop working. Consider using RegisterPublisherHandlerFromEndpoint instead. GRPC interceptors will not work for this type of registration. To use interceptors, you must use the "runtime.WithMiddlewares" option in the "runtime.NewServeMux" call.
func RegisterPublisherServer ¶
func RegisterPublisherServer(s grpc.ServiceRegistrar, srv PublisherServer)
func RegisterSchemaServiceHandler ¶
func RegisterSchemaServiceHandler(ctx context.Context, mux *runtime.ServeMux, conn *grpc.ClientConn) error
RegisterSchemaServiceHandler registers the http handlers for service SchemaService to "mux". The handlers forward requests to the grpc endpoint over "conn".
func RegisterSchemaServiceHandlerClient ¶
func RegisterSchemaServiceHandlerClient(ctx context.Context, mux *runtime.ServeMux, client SchemaServiceClient) error
RegisterSchemaServiceHandlerClient registers the http handlers for service SchemaService to "mux". The handlers forward requests to the grpc endpoint over the given implementation of "SchemaServiceClient". Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "SchemaServiceClient" doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in "SchemaServiceClient" to call the correct interceptors. This client ignores the HTTP middlewares.
func RegisterSchemaServiceHandlerFromEndpoint ¶
func RegisterSchemaServiceHandlerFromEndpoint(ctx context.Context, mux *runtime.ServeMux, endpoint string, opts []grpc.DialOption) (err error)
RegisterSchemaServiceHandlerFromEndpoint is same as RegisterSchemaServiceHandler but automatically dials to "endpoint" and closes the connection when "ctx" gets done.
func RegisterSchemaServiceHandlerServer ¶
func RegisterSchemaServiceHandlerServer(ctx context.Context, mux *runtime.ServeMux, server SchemaServiceServer) error
RegisterSchemaServiceHandlerServer registers the http handlers for service SchemaService to "mux". UnaryRPC :call SchemaServiceServer directly. StreamingRPC :currently unsupported pending https://github.com/grpc/grpc-go/issues/906. Note that using this registration option will cause many gRPC library features to stop working. Consider using RegisterSchemaServiceHandlerFromEndpoint instead. GRPC interceptors will not work for this type of registration. To use interceptors, you must use the "runtime.WithMiddlewares" option in the "runtime.NewServeMux" call.
func RegisterSchemaServiceServer ¶
func RegisterSchemaServiceServer(s grpc.ServiceRegistrar, srv SchemaServiceServer)
func RegisterSubscriberHandler ¶
func RegisterSubscriberHandler(ctx context.Context, mux *runtime.ServeMux, conn *grpc.ClientConn) error
RegisterSubscriberHandler registers the http handlers for service Subscriber to "mux". The handlers forward requests to the grpc endpoint over "conn".
func RegisterSubscriberHandlerClient ¶
func RegisterSubscriberHandlerClient(ctx context.Context, mux *runtime.ServeMux, client SubscriberClient) error
RegisterSubscriberHandlerClient registers the http handlers for service Subscriber to "mux". The handlers forward requests to the grpc endpoint over the given implementation of "SubscriberClient". Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "SubscriberClient" doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in "SubscriberClient" to call the correct interceptors. This client ignores the HTTP middlewares.
func RegisterSubscriberHandlerFromEndpoint ¶
func RegisterSubscriberHandlerFromEndpoint(ctx context.Context, mux *runtime.ServeMux, endpoint string, opts []grpc.DialOption) (err error)
RegisterSubscriberHandlerFromEndpoint is same as RegisterSubscriberHandler but automatically dials to "endpoint" and closes the connection when "ctx" gets done.
func RegisterSubscriberHandlerServer ¶
func RegisterSubscriberHandlerServer(ctx context.Context, mux *runtime.ServeMux, server SubscriberServer) error
RegisterSubscriberHandlerServer registers the http handlers for service Subscriber to "mux". UnaryRPC :call SubscriberServer directly. StreamingRPC :currently unsupported pending https://github.com/grpc/grpc-go/issues/906. Note that using this registration option will cause many gRPC library features to stop working. Consider using RegisterSubscriberHandlerFromEndpoint instead. GRPC interceptors will not work for this type of registration. To use interceptors, you must use the "runtime.WithMiddlewares" option in the "runtime.NewServeMux" call.
func RegisterSubscriberServer ¶
func RegisterSubscriberServer(s grpc.ServiceRegistrar, srv SubscriberServer)
Types ¶
type AcknowledgeRequest ¶
type AcknowledgeRequest = upstream.AcknowledgeRequest
type BigQueryConfig ¶
type BigQueryConfig = upstream.BigQueryConfig
type BigQueryConfig_State ¶
type BigQueryConfig_State = upstream.BigQueryConfig_State
type CloudStorageConfig ¶
type CloudStorageConfig = upstream.CloudStorageConfig
type CloudStorageConfig_AvroConfig ¶
type CloudStorageConfig_AvroConfig = upstream.CloudStorageConfig_AvroConfig
type CloudStorageConfig_AvroConfig_ ¶
type CloudStorageConfig_AvroConfig_ = upstream.CloudStorageConfig_AvroConfig_
type CloudStorageConfig_State ¶
type CloudStorageConfig_State = upstream.CloudStorageConfig_State
type CloudStorageConfig_TextConfig ¶
type CloudStorageConfig_TextConfig = upstream.CloudStorageConfig_TextConfig
type CloudStorageConfig_TextConfig_ ¶
type CloudStorageConfig_TextConfig_ = upstream.CloudStorageConfig_TextConfig_
type CommitSchemaRequest ¶
type CommitSchemaRequest = upstream.CommitSchemaRequest
type CreateSchemaRequest ¶
type CreateSchemaRequest = upstream.CreateSchemaRequest
type CreateSnapshotRequest ¶
type CreateSnapshotRequest = upstream.CreateSnapshotRequest
type DeadLetterPolicy ¶
type DeadLetterPolicy = upstream.DeadLetterPolicy
type DeleteSchemaRequest ¶
type DeleteSchemaRequest = upstream.DeleteSchemaRequest
type DeleteSchemaRevisionRequest ¶
type DeleteSchemaRevisionRequest = upstream.DeleteSchemaRevisionRequest
type DeleteSnapshotRequest ¶
type DeleteSnapshotRequest = upstream.DeleteSnapshotRequest
type DeleteSubscriptionRequest ¶
type DeleteSubscriptionRequest = upstream.DeleteSubscriptionRequest
type DeleteTopicRequest ¶
type DeleteTopicRequest = upstream.DeleteTopicRequest
type DetachSubscriptionRequest ¶
type DetachSubscriptionRequest = upstream.DetachSubscriptionRequest
type DetachSubscriptionResponse ¶
type DetachSubscriptionResponse = upstream.DetachSubscriptionResponse
type ExpirationPolicy ¶
type ExpirationPolicy = upstream.ExpirationPolicy
type GetSchemaRequest ¶
type GetSchemaRequest = upstream.GetSchemaRequest
type GetSnapshotRequest ¶
type GetSnapshotRequest = upstream.GetSnapshotRequest
type GetSubscriptionRequest ¶
type GetSubscriptionRequest = upstream.GetSubscriptionRequest
type GetTopicRequest ¶
type GetTopicRequest = upstream.GetTopicRequest
type IngestionDataSourceSettings ¶
type IngestionDataSourceSettings = upstream.IngestionDataSourceSettings
type IngestionDataSourceSettings_AwsKinesis ¶
type IngestionDataSourceSettings_AwsKinesis = upstream.IngestionDataSourceSettings_AwsKinesis
type IngestionDataSourceSettings_AwsKinesis_ ¶
type IngestionDataSourceSettings_AwsKinesis_ = upstream.IngestionDataSourceSettings_AwsKinesis_
type IngestionDataSourceSettings_AwsKinesis_State ¶
type IngestionDataSourceSettings_AwsKinesis_State = upstream.IngestionDataSourceSettings_AwsKinesis_State
type IngestionDataSourceSettings_CloudStorage ¶
type IngestionDataSourceSettings_CloudStorage = upstream.IngestionDataSourceSettings_CloudStorage
type IngestionDataSourceSettings_CloudStorage_ ¶
type IngestionDataSourceSettings_CloudStorage_ = upstream.IngestionDataSourceSettings_CloudStorage_
type IngestionDataSourceSettings_CloudStorage_AvroFormat ¶
type IngestionDataSourceSettings_CloudStorage_AvroFormat = upstream.IngestionDataSourceSettings_CloudStorage_AvroFormat
type IngestionDataSourceSettings_CloudStorage_AvroFormat_ ¶
type IngestionDataSourceSettings_CloudStorage_AvroFormat_ = upstream.IngestionDataSourceSettings_CloudStorage_AvroFormat_
type IngestionDataSourceSettings_CloudStorage_PubSubAvroFormat ¶
type IngestionDataSourceSettings_CloudStorage_PubSubAvroFormat = upstream.IngestionDataSourceSettings_CloudStorage_PubSubAvroFormat
type IngestionDataSourceSettings_CloudStorage_PubsubAvroFormat ¶
type IngestionDataSourceSettings_CloudStorage_PubsubAvroFormat = upstream.IngestionDataSourceSettings_CloudStorage_PubsubAvroFormat
type IngestionDataSourceSettings_CloudStorage_State ¶
type IngestionDataSourceSettings_CloudStorage_State = upstream.IngestionDataSourceSettings_CloudStorage_State
type IngestionDataSourceSettings_CloudStorage_TextFormat ¶
type IngestionDataSourceSettings_CloudStorage_TextFormat = upstream.IngestionDataSourceSettings_CloudStorage_TextFormat
type IngestionDataSourceSettings_CloudStorage_TextFormat_ ¶
type IngestionDataSourceSettings_CloudStorage_TextFormat_ = upstream.IngestionDataSourceSettings_CloudStorage_TextFormat_
type IngestionFailureEvent ¶
type IngestionFailureEvent = upstream.IngestionFailureEvent
type IngestionFailureEvent_ApiViolationReason ¶
type IngestionFailureEvent_ApiViolationReason = upstream.IngestionFailureEvent_ApiViolationReason
type IngestionFailureEvent_AvroFailureReason ¶
type IngestionFailureEvent_AvroFailureReason = upstream.IngestionFailureEvent_AvroFailureReason
type IngestionFailureEvent_CloudStorageFailure ¶
type IngestionFailureEvent_CloudStorageFailure = upstream.IngestionFailureEvent_CloudStorageFailure
type IngestionFailureEvent_CloudStorageFailure_ ¶
type IngestionFailureEvent_CloudStorageFailure_ = upstream.IngestionFailureEvent_CloudStorageFailure_
type IngestionFailureEvent_CloudStorageFailure_ApiViolationReason ¶
type IngestionFailureEvent_CloudStorageFailure_ApiViolationReason = upstream.IngestionFailureEvent_CloudStorageFailure_ApiViolationReason
type IngestionFailureEvent_CloudStorageFailure_AvroFailureReason ¶
type IngestionFailureEvent_CloudStorageFailure_AvroFailureReason = upstream.IngestionFailureEvent_CloudStorageFailure_AvroFailureReason
type ListSchemaRevisionsRequest ¶
type ListSchemaRevisionsRequest = upstream.ListSchemaRevisionsRequest
type ListSchemaRevisionsResponse ¶
type ListSchemaRevisionsResponse = upstream.ListSchemaRevisionsResponse
type ListSchemasRequest ¶
type ListSchemasRequest = upstream.ListSchemasRequest
type ListSchemasResponse ¶
type ListSchemasResponse = upstream.ListSchemasResponse
type ListSnapshotsRequest ¶
type ListSnapshotsRequest = upstream.ListSnapshotsRequest
type ListSnapshotsResponse ¶
type ListSnapshotsResponse = upstream.ListSnapshotsResponse
type ListSubscriptionsRequest ¶
type ListSubscriptionsRequest = upstream.ListSubscriptionsRequest
type ListSubscriptionsResponse ¶
type ListSubscriptionsResponse = upstream.ListSubscriptionsResponse
type ListTopicSnapshotsRequest ¶
type ListTopicSnapshotsRequest = upstream.ListTopicSnapshotsRequest
type ListTopicSnapshotsResponse ¶
type ListTopicSnapshotsResponse = upstream.ListTopicSnapshotsResponse
type ListTopicSubscriptionsRequest ¶
type ListTopicSubscriptionsRequest = upstream.ListTopicSubscriptionsRequest
type ListTopicSubscriptionsResponse ¶
type ListTopicSubscriptionsResponse = upstream.ListTopicSubscriptionsResponse
type ListTopicsRequest ¶
type ListTopicsRequest = upstream.ListTopicsRequest
type ListTopicsResponse ¶
type ListTopicsResponse = upstream.ListTopicsResponse
type MessageStoragePolicy ¶
type MessageStoragePolicy = upstream.MessageStoragePolicy
type ModifyAckDeadlineRequest ¶
type ModifyAckDeadlineRequest = upstream.ModifyAckDeadlineRequest
type ModifyPushConfigRequest ¶
type ModifyPushConfigRequest = upstream.ModifyPushConfigRequest
type PlatformLogsSettings ¶
type PlatformLogsSettings = upstream.PlatformLogsSettings
type PlatformLogsSettings_Severity ¶
type PlatformLogsSettings_Severity = upstream.PlatformLogsSettings_Severity
type PublishRequest ¶
type PublishRequest = upstream.PublishRequest
type PublishResponse ¶
type PublishResponse = upstream.PublishResponse
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) (*empty.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://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream.
The service that an application uses to manipulate topics, and to send messages to a topic.
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) (*empty.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) // contains filtered or unexported methods }
PublisherServer is the server API for Publisher service. All implementations must embed UnimplementedPublisherServer for forward compatibility.
The service that an application uses to manipulate topics, and to send messages to a topic.
type PubsubMessage ¶
type PubsubMessage = upstream.PubsubMessage
type PullRequest ¶
type PullRequest = upstream.PullRequest
type PullResponse ¶
type PullResponse = upstream.PullResponse
type PushConfig ¶
type PushConfig = upstream.PushConfig
type PushConfig_NoWrapper ¶
type PushConfig_NoWrapper = upstream.PushConfig_NoWrapper
type PushConfig_NoWrapper_ ¶
type PushConfig_NoWrapper_ = upstream.PushConfig_NoWrapper_
type PushConfig_OidcToken ¶
type PushConfig_OidcToken = upstream.PushConfig_OidcToken
type PushConfig_OidcToken_ ¶
type PushConfig_OidcToken_ = upstream.PushConfig_OidcToken_
type PushConfig_PubsubWrapper ¶
type PushConfig_PubsubWrapper = upstream.PushConfig_PubsubWrapper
type PushConfig_PubsubWrapper_ ¶
type PushConfig_PubsubWrapper_ = upstream.PushConfig_PubsubWrapper_
type ReceivedMessage ¶
type ReceivedMessage = upstream.ReceivedMessage
type RetryPolicy ¶
type RetryPolicy = upstream.RetryPolicy
type RollbackSchemaRequest ¶
type RollbackSchemaRequest = upstream.RollbackSchemaRequest
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) (*empty.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://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream.
Service for doing schema-related operations.
func NewSchemaServiceClient ¶
func NewSchemaServiceClient(cc grpc.ClientConnInterface) SchemaServiceClient
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) (*empty.Empty, error) // Validates a schema. ValidateSchema(context.Context, *ValidateSchemaRequest) (*ValidateSchemaResponse, error) // Validates a message against a schema. ValidateMessage(context.Context, *ValidateMessageRequest) (*ValidateMessageResponse, error) // contains filtered or unexported methods }
SchemaServiceServer is the server API for SchemaService service. All implementations must embed UnimplementedSchemaServiceServer for forward compatibility.
Service for doing schema-related operations.
type SchemaSettings ¶
type SchemaSettings = upstream.SchemaSettings
type SchemaView ¶
type SchemaView = upstream.SchemaView
type Schema_Type ¶
type Schema_Type = upstream.Schema_Type
type SeekRequest ¶
type SeekRequest = upstream.SeekRequest
type SeekRequest_Snapshot ¶
type SeekRequest_Snapshot = upstream.SeekRequest_Snapshot
type SeekRequest_Time ¶
type SeekRequest_Time = upstream.SeekRequest_Time
type SeekResponse ¶
type SeekResponse = upstream.SeekResponse
type StreamingPullRequest ¶
type StreamingPullRequest = upstream.StreamingPullRequest
type StreamingPullResponse ¶
type StreamingPullResponse = upstream.StreamingPullResponse
type StreamingPullResponse_AcknowledgeConfirmation ¶
type StreamingPullResponse_AcknowledgeConfirmation = upstream.StreamingPullResponse_AcknowledgeConfirmation
type StreamingPullResponse_ModifyAckDeadlineConfirmation ¶
type StreamingPullResponse_ModifyAckDeadlineConfirmation = upstream.StreamingPullResponse_ModifyAckDeadlineConfirmation
type StreamingPullResponse_SubscriptionProperties ¶
type StreamingPullResponse_SubscriptionProperties = upstream.StreamingPullResponse_SubscriptionProperties
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) (*empty.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) (*empty.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) (*empty.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) (grpc.BidiStreamingClient[StreamingPullRequest, StreamingPullResponse], 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) (*empty.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) (*empty.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://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream.
The service that an application uses to manipulate subscriptions and to consume messages from a subscription via the `Pull` method or by establishing a bi-directional stream using the `StreamingPull` method.
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) (*empty.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) (*empty.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) (*empty.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(grpc.BidiStreamingServer[StreamingPullRequest, StreamingPullResponse]) 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) (*empty.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) (*empty.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) // contains filtered or unexported methods }
SubscriberServer is the server API for Subscriber service. All implementations must embed UnimplementedSubscriberServer for forward compatibility.
The service that an application uses to manipulate subscriptions and to consume messages from a subscription via the `Pull` method or by establishing a bi-directional stream using the `StreamingPull` method.
type Subscriber_StreamingPullClient ¶
type Subscriber_StreamingPullClient = grpc.BidiStreamingClient[StreamingPullRequest, StreamingPullResponse]
This type alias is provided for backwards compatibility with existing code that references the prior non-generic stream type by name.
type Subscriber_StreamingPullServer ¶
type Subscriber_StreamingPullServer = grpc.BidiStreamingServer[StreamingPullRequest, StreamingPullResponse]
This type alias is provided for backwards compatibility with existing code that references the prior non-generic stream type by name.
type Subscription ¶
type Subscription = upstream.Subscription
type Subscription_AnalyticsHubSubscriptionInfo ¶
type Subscription_AnalyticsHubSubscriptionInfo = upstream.Subscription_AnalyticsHubSubscriptionInfo
type Subscription_State ¶
type Subscription_State = upstream.Subscription_State
type Topic_State ¶
type Topic_State = upstream.Topic_State
type UnimplementedPublisherServer ¶
type UnimplementedPublisherServer struct{}
UnimplementedPublisherServer must be embedded to have forward compatible implementations.
NOTE: this should be embedded by value instead of pointer to avoid a nil pointer dereference when methods are called.
func (UnimplementedPublisherServer) CreateTopic ¶
func (UnimplementedPublisherServer) DeleteTopic ¶
func (UnimplementedPublisherServer) DeleteTopic(context.Context, *DeleteTopicRequest) (*empty.Empty, error)
func (UnimplementedPublisherServer) DetachSubscription ¶
func (UnimplementedPublisherServer) DetachSubscription(context.Context, *DetachSubscriptionRequest) (*DetachSubscriptionResponse, error)
func (UnimplementedPublisherServer) GetTopic ¶
func (UnimplementedPublisherServer) GetTopic(context.Context, *GetTopicRequest) (*Topic, error)
func (UnimplementedPublisherServer) ListTopicSnapshots ¶
func (UnimplementedPublisherServer) ListTopicSnapshots(context.Context, *ListTopicSnapshotsRequest) (*ListTopicSnapshotsResponse, error)
func (UnimplementedPublisherServer) ListTopicSubscriptions ¶
func (UnimplementedPublisherServer) ListTopicSubscriptions(context.Context, *ListTopicSubscriptionsRequest) (*ListTopicSubscriptionsResponse, error)
func (UnimplementedPublisherServer) ListTopics ¶
func (UnimplementedPublisherServer) ListTopics(context.Context, *ListTopicsRequest) (*ListTopicsResponse, error)
func (UnimplementedPublisherServer) Publish ¶
func (UnimplementedPublisherServer) Publish(context.Context, *PublishRequest) (*PublishResponse, error)
func (UnimplementedPublisherServer) UpdateTopic ¶
func (UnimplementedPublisherServer) UpdateTopic(context.Context, *UpdateTopicRequest) (*Topic, error)
type UnimplementedSchemaServiceServer ¶
type UnimplementedSchemaServiceServer struct{}
UnimplementedSchemaServiceServer must be embedded to have forward compatible implementations.
NOTE: this should be embedded by value instead of pointer to avoid a nil pointer dereference when methods are called.
func (UnimplementedSchemaServiceServer) CommitSchema ¶
func (UnimplementedSchemaServiceServer) CommitSchema(context.Context, *CommitSchemaRequest) (*Schema, error)
func (UnimplementedSchemaServiceServer) CreateSchema ¶
func (UnimplementedSchemaServiceServer) CreateSchema(context.Context, *CreateSchemaRequest) (*Schema, error)
func (UnimplementedSchemaServiceServer) DeleteSchema ¶
func (UnimplementedSchemaServiceServer) DeleteSchema(context.Context, *DeleteSchemaRequest) (*empty.Empty, error)
func (UnimplementedSchemaServiceServer) DeleteSchemaRevision ¶
func (UnimplementedSchemaServiceServer) DeleteSchemaRevision(context.Context, *DeleteSchemaRevisionRequest) (*Schema, error)
func (UnimplementedSchemaServiceServer) GetSchema ¶
func (UnimplementedSchemaServiceServer) GetSchema(context.Context, *GetSchemaRequest) (*Schema, error)
func (UnimplementedSchemaServiceServer) ListSchemaRevisions ¶
func (UnimplementedSchemaServiceServer) ListSchemaRevisions(context.Context, *ListSchemaRevisionsRequest) (*ListSchemaRevisionsResponse, error)
func (UnimplementedSchemaServiceServer) ListSchemas ¶
func (UnimplementedSchemaServiceServer) ListSchemas(context.Context, *ListSchemasRequest) (*ListSchemasResponse, error)
func (UnimplementedSchemaServiceServer) RollbackSchema ¶
func (UnimplementedSchemaServiceServer) RollbackSchema(context.Context, *RollbackSchemaRequest) (*Schema, error)
func (UnimplementedSchemaServiceServer) ValidateMessage ¶
func (UnimplementedSchemaServiceServer) ValidateMessage(context.Context, *ValidateMessageRequest) (*ValidateMessageResponse, error)
func (UnimplementedSchemaServiceServer) ValidateSchema ¶
func (UnimplementedSchemaServiceServer) ValidateSchema(context.Context, *ValidateSchemaRequest) (*ValidateSchemaResponse, error)
type UnimplementedSubscriberServer ¶
type UnimplementedSubscriberServer struct{}
UnimplementedSubscriberServer must be embedded to have forward compatible implementations.
NOTE: this should be embedded by value instead of pointer to avoid a nil pointer dereference when methods are called.
func (UnimplementedSubscriberServer) Acknowledge ¶
func (UnimplementedSubscriberServer) Acknowledge(context.Context, *AcknowledgeRequest) (*empty.Empty, error)
func (UnimplementedSubscriberServer) CreateSnapshot ¶
func (UnimplementedSubscriberServer) CreateSnapshot(context.Context, *CreateSnapshotRequest) (*Snapshot, error)
func (UnimplementedSubscriberServer) CreateSubscription ¶
func (UnimplementedSubscriberServer) CreateSubscription(context.Context, *Subscription) (*Subscription, error)
func (UnimplementedSubscriberServer) DeleteSnapshot ¶
func (UnimplementedSubscriberServer) DeleteSnapshot(context.Context, *DeleteSnapshotRequest) (*empty.Empty, error)
func (UnimplementedSubscriberServer) DeleteSubscription ¶
func (UnimplementedSubscriberServer) DeleteSubscription(context.Context, *DeleteSubscriptionRequest) (*empty.Empty, error)
func (UnimplementedSubscriberServer) GetSnapshot ¶
func (UnimplementedSubscriberServer) GetSnapshot(context.Context, *GetSnapshotRequest) (*Snapshot, error)
func (UnimplementedSubscriberServer) GetSubscription ¶
func (UnimplementedSubscriberServer) GetSubscription(context.Context, *GetSubscriptionRequest) (*Subscription, error)
func (UnimplementedSubscriberServer) ListSnapshots ¶
func (UnimplementedSubscriberServer) ListSnapshots(context.Context, *ListSnapshotsRequest) (*ListSnapshotsResponse, error)
func (UnimplementedSubscriberServer) ListSubscriptions ¶
func (UnimplementedSubscriberServer) ListSubscriptions(context.Context, *ListSubscriptionsRequest) (*ListSubscriptionsResponse, error)
func (UnimplementedSubscriberServer) ModifyAckDeadline ¶
func (UnimplementedSubscriberServer) ModifyAckDeadline(context.Context, *ModifyAckDeadlineRequest) (*empty.Empty, error)
func (UnimplementedSubscriberServer) ModifyPushConfig ¶
func (UnimplementedSubscriberServer) ModifyPushConfig(context.Context, *ModifyPushConfigRequest) (*empty.Empty, error)
func (UnimplementedSubscriberServer) Pull ¶
func (UnimplementedSubscriberServer) Pull(context.Context, *PullRequest) (*PullResponse, error)
func (UnimplementedSubscriberServer) Seek ¶
func (UnimplementedSubscriberServer) Seek(context.Context, *SeekRequest) (*SeekResponse, error)
func (UnimplementedSubscriberServer) StreamingPull ¶
func (UnimplementedSubscriberServer) StreamingPull(grpc.BidiStreamingServer[StreamingPullRequest, StreamingPullResponse]) error
func (UnimplementedSubscriberServer) UpdateSnapshot ¶
func (UnimplementedSubscriberServer) UpdateSnapshot(context.Context, *UpdateSnapshotRequest) (*Snapshot, error)
func (UnimplementedSubscriberServer) UpdateSubscription ¶
func (UnimplementedSubscriberServer) UpdateSubscription(context.Context, *UpdateSubscriptionRequest) (*Subscription, error)
type UnsafePublisherServer ¶
type UnsafePublisherServer interface {
// contains filtered or unexported methods
}
UnsafePublisherServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to PublisherServer will result in compilation errors.
type UnsafeSchemaServiceServer ¶
type UnsafeSchemaServiceServer interface {
// contains filtered or unexported methods
}
UnsafeSchemaServiceServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to SchemaServiceServer will result in compilation errors.
type UnsafeSubscriberServer ¶
type UnsafeSubscriberServer interface {
// contains filtered or unexported methods
}
UnsafeSubscriberServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to SubscriberServer will result in compilation errors.
type UpdateSnapshotRequest ¶
type UpdateSnapshotRequest = upstream.UpdateSnapshotRequest
type UpdateSubscriptionRequest ¶
type UpdateSubscriptionRequest = upstream.UpdateSubscriptionRequest
type UpdateTopicRequest ¶
type UpdateTopicRequest = upstream.UpdateTopicRequest
type ValidateMessageRequest ¶
type ValidateMessageRequest = upstream.ValidateMessageRequest
type ValidateMessageRequest_Name ¶
type ValidateMessageRequest_Name = upstream.ValidateMessageRequest_Name
type ValidateMessageRequest_Schema ¶
type ValidateMessageRequest_Schema = upstream.ValidateMessageRequest_Schema
type ValidateMessageResponse ¶
type ValidateMessageResponse = upstream.ValidateMessageResponse
type ValidateSchemaRequest ¶
type ValidateSchemaRequest = upstream.ValidateSchemaRequest
type ValidateSchemaResponse ¶
type ValidateSchemaResponse = upstream.ValidateSchemaResponse