Documentation ¶
Index ¶
- type AsyncCallListener
- type Scheduler
- type Service
- func (s *Service) AsyncCallDidCommit(ctx context.Context, origin async.AsyncOriginPubSub)
- func (s *Service) CreateSubscribers(ctx context.Context, key model.DeploymentKey, module *schema.Module) error
- func (s *Service) CreateSubscriptions(ctx context.Context, key model.DeploymentKey, module *schema.Module) error
- func (s *Service) OnCallCompletion(ctx context.Context, tx libdal.Connection, origin async.AsyncOriginPubSub, ...) error
- func (s *Service) PublishEventForTopic(ctx context.Context, module, topic, caller string, payload []byte) error
- func (s *Service) RemoveSubscriptionsAndSubscribers(ctx context.Context, key model.DeploymentKey) error
- func (s *Service) ResetSubscription(ctx context.Context, module, name string) (err error)
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
This section is empty.
Types ¶
type AsyncCallListener ¶ added in v0.244.0
type Scheduler ¶ added in v0.244.0
type Scheduler interface { Singleton(name string, retry backoff.Backoff, job scheduledtask.Job) Parallel(name string, retry backoff.Backoff, job scheduledtask.Job) }
type Service ¶ added in v0.370.0
type Service struct {
// contains filtered or unexported fields
}
func New ¶
func New(ctx context.Context, conn libdal.Connection, encryption *encryption.Service, asyncCallListener optional.Option[AsyncCallListener]) *Service
func (*Service) AsyncCallDidCommit ¶ added in v0.370.0
func (s *Service) AsyncCallDidCommit(ctx context.Context, origin async.AsyncOriginPubSub)
AsyncCallDidCommit is called after a subscription's async call has been completed and committed to the database.
func (*Service) CreateSubscribers ¶ added in v0.370.0
func (*Service) CreateSubscriptions ¶ added in v0.370.0
func (*Service) OnCallCompletion ¶ added in v0.370.0
func (s *Service) OnCallCompletion(ctx context.Context, tx libdal.Connection, origin async.AsyncOriginPubSub, failed bool, isFinalResult bool) error
OnCallCompletion is called within a transaction after an async call has completed to allow the subscription state to be updated.
func (*Service) PublishEventForTopic ¶ added in v0.370.0
func (*Service) RemoveSubscriptionsAndSubscribers ¶ added in v0.370.0
Click to show internal directories.
Click to hide internal directories.