Versions in this module Expand all Collapse all v1 v1.0.0 Feb 21, 2024 Changes in this version + func JoinTopicConsumer(topic apmqueue.Topic, consumer string) string + func SplitTopicConsumer(subscriptionName string) (topic apmqueue.Topic, consumer string, err error) + type CommonConfig struct + ClientOptions []option.ClientOption + DisableTelemetry bool + Logger *zap.Logger + MeterProvider metric.MeterProvider + Namespace string + Project string + Region string + TracerProvider trace.TracerProvider + type Consumer struct + func NewConsumer(ctx context.Context, cfg ConsumerConfig) (*Consumer, error) + func (c *Consumer) Close() error + func (c *Consumer) Healthy(ctx context.Context) error + func (c *Consumer) Run(ctx context.Context) error + type ConsumerConfig struct + ConsumerName string + Delivery apmqueue.DeliveryType + Processor apmqueue.Processor + Topics []apmqueue.Topic + type Manager struct + func NewManager(cfg ManagerConfig) (*Manager, error) + func (m *Manager) Close() error + func (m *Manager) CreateReservation(ctx context.Context, name string, throughputCapacity int) error + func (m *Manager) CreateSubscription(ctx context.Context, name, topic string, deliverImmediately bool) error + func (m *Manager) DeleteReservation(ctx context.Context, reservation string) error + func (m *Manager) DeleteSubscription(ctx context.Context, subscription string) error + func (m *Manager) DeleteTopic(ctx context.Context, topic string) error + func (m *Manager) ListReservationTopics(ctx context.Context, reservation string) ([]string, error) + func (m *Manager) ListReservations(ctx context.Context) ([]string, error) + func (m *Manager) ListTopicSubscriptions(ctx context.Context, topic string) ([]string, error) + func (m *Manager) MonitorConsumerLag(topicConsumers []apmqueue.TopicConsumer) (metric.Registration, error) + func (m *Manager) NewTopicCreator(cfg TopicCreatorConfig) (*TopicCreator, error) + type ManagerConfig struct + type Producer struct + func NewProducer(cfg ProducerConfig) (*Producer, error) + func (p *Producer) Close() error + func (p *Producer) Healthy(ctx context.Context) error + func (p *Producer) Produce(ctx context.Context, rs ...apmqueue.Record) error + type ProducerConfig struct + Sync bool + type TopicCreator struct + func (c *TopicCreator) CreateTopics(ctx context.Context, topics ...apmqueue.Topic) error + type TopicCreatorConfig struct + PartitionCount int + PerPartitionBytes int64 + PublishCapacityMiBPerSec int + Reservation string + RetentionDuration time.Duration + SubscribeCapacityMiBPerSec int Other modules containing this package github.com/elastic/apm-queue/v2