Documentation ¶
Index ¶
- func New() (queue.QueueService, error)
- func NewWithClient(client ifaces_pubsub.PubsubClient) queue.QueueService
- func NewWithClients(client ifaces_pubsub.PubsubClient, ...) queue.QueueService
- type PubsubQueueService
- func (s *PubsubQueueService) Complete(q string, leaseId string) error
- func (s *PubsubQueueService) Receive(options queue.ReceiveOptions) ([]queue.NitricTask, error)
- func (s *PubsubQueueService) Send(queue string, task queue.NitricTask) error
- func (s *PubsubQueueService) SendBatch(q string, tasks []queue.NitricTask) (*queue.SendBatchResponse, error)
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
func New ¶
func New() (queue.QueueService, error)
New - Constructs a new GCP pubsub client with defaults
func NewWithClient ¶
func NewWithClient(client ifaces_pubsub.PubsubClient) queue.QueueService
func NewWithClients ¶
func NewWithClients(client ifaces_pubsub.PubsubClient, subscriberClientGenerator func(ctx context.Context, opts ...option.ClientOption) (ifaces_pubsub.SubscriberClient, error)) queue.QueueService
*pubsubbase.SubscriberClient
Types ¶
type PubsubQueueService ¶
type PubsubQueueService struct { queue.UnimplementedQueuePlugin // contains filtered or unexported fields }
func (*PubsubQueueService) Complete ¶
func (s *PubsubQueueService) Complete(q string, leaseId string) error
Completes a previously popped queue item
func (*PubsubQueueService) Receive ¶
func (s *PubsubQueueService) Receive(options queue.ReceiveOptions) ([]queue.NitricTask, error)
Receives a collection of tasks off a given queue.
func (*PubsubQueueService) Send ¶
func (s *PubsubQueueService) Send(queue string, task queue.NitricTask) error
func (*PubsubQueueService) SendBatch ¶
func (s *PubsubQueueService) SendBatch(q string, tasks []queue.NitricTask) (*queue.SendBatchResponse, error)
Click to show internal directories.
Click to hide internal directories.