alertmanager/dispatch.go

299 lines
6.8 KiB
Go
Raw Normal View History

2015-09-25 16:14:46 +00:00
package main
import (
2015-09-26 09:12:47 +00:00
"fmt"
"sync"
"time"
2015-09-28 10:12:27 +00:00
"github.com/prometheus/common/log"
"github.com/prometheus/common/model"
"golang.org/x/net/context"
2015-09-25 11:12:51 +00:00
2015-09-25 16:14:46 +00:00
"github.com/prometheus/alertmanager/config"
2015-09-29 13:12:31 +00:00
"github.com/prometheus/alertmanager/notify"
2015-09-25 11:12:51 +00:00
"github.com/prometheus/alertmanager/provider"
2015-09-25 12:38:57 +00:00
"github.com/prometheus/alertmanager/types"
)
2015-10-07 14:18:55 +00:00
const ResolveTimeout = 5 * time.Minute
// Dispatcher sorts incoming alerts into aggregation groups and
// assigns the correct notifiers to each.
type Dispatcher struct {
routes Routes
alerts provider.Alerts
2015-09-29 13:12:31 +00:00
notifier notify.Notifier
aggrGroups map[model.Fingerprint]*aggrGroup
mtx sync.RWMutex
done chan struct{}
ctx context.Context
cancel func()
2015-09-29 09:58:30 +00:00
log log.Logger
}
// NewDispatcher returns a new Dispatcher.
2015-09-29 13:12:31 +00:00
func NewDispatcher(ap provider.Alerts, n notify.Notifier) *Dispatcher {
return &Dispatcher{
alerts: ap,
notifier: n,
2015-09-29 09:58:30 +00:00
log: log.With("component", "dispatcher"),
}
}
// ApplyConfig updates the dispatcher to match the new configuration.
2015-09-29 10:22:13 +00:00
func (d *Dispatcher) ApplyConfig(conf *config.Config) bool {
d.mtx.Lock()
defer d.mtx.Unlock()
2015-09-25 16:14:46 +00:00
// If a cancelation function is set, the dispatcher is running.
if d.cancel != nil {
d.Stop()
defer func() { go d.Run() }()
}
d.routes = NewRoutes(conf.Routes, nil)
2015-09-29 10:22:13 +00:00
return true
}
// Run starts dispatching alerts incoming via the updates channel.
func (d *Dispatcher) Run() {
d.done = make(chan struct{})
d.aggrGroups = map[model.Fingerprint]*aggrGroup{}
d.ctx, d.cancel = context.WithCancel(context.Background())
d.run(d.alerts.Subscribe())
}
func (d *Dispatcher) run(it provider.AlertIterator) {
cleanup := time.NewTicker(15 * time.Second)
defer cleanup.Stop()
defer it.Close()
for {
select {
case alert := <-it.Next():
2015-09-29 09:58:30 +00:00
d.log.With("alert", alert).Debug("Received alert")
// Log errors but keep trying
if err := it.Err(); err != nil {
log.Errorf("Error on alert update: %s", err)
continue
}
d.mtx.RLock()
routes := d.routes.Match(alert.Labels)
d.mtx.RUnlock()
for _, r := range routes {
d.processAlert(alert, r)
}
case <-cleanup.C:
for _, ag := range d.aggrGroups {
if ag.empty() {
ag.stop()
delete(d.aggrGroups, ag.fingerprint())
}
}
case <-d.ctx.Done():
return
}
}
}
// Stop the dispatcher.
func (d *Dispatcher) Stop() {
d.cancel()
2015-09-25 16:14:46 +00:00
d.cancel = nil
2015-09-26 09:12:47 +00:00
<-d.done
}
// notifyFunc is a function that performs notifcation for the alert
// with the given fingerprint. It aborts on context cancelation.
2015-09-26 16:12:56 +00:00
// Returns false iff notifying failed.
type notifyFunc func(context.Context, ...*types.Alert) bool
// processAlert determins in which aggregation group the alert falls
// and insert it.
2015-09-25 12:38:57 +00:00
func (d *Dispatcher) processAlert(alert *types.Alert, opts *RouteOpts) {
group := model.LabelSet{}
for ln, lv := range alert.Labels {
if _, ok := opts.GroupBy[ln]; ok {
group[ln] = lv
}
}
fp := group.Fingerprint()
// If the group does not exist, create it.
ag, ok := d.aggrGroups[fp]
if !ok {
2015-09-25 16:14:46 +00:00
ag = newAggrGroup(d.ctx, group, opts)
d.aggrGroups[fp] = ag
ag.log = log.With("aggrGroup", ag)
go ag.run(func(ctx context.Context, alerts ...*types.Alert) bool {
if err := d.notifier.Notify(ctx, alerts...); err != nil {
log.Errorf("Notify for %d alerts failed: %s", len(alerts), err)
return false
}
return true
})
}
ag.insert(alert)
}
// aggrGroup aggregates alert fingerprints into groups to which a
// common set of routing options applies.
// It emits notifications in the specified intervals.
type aggrGroup struct {
labels model.LabelSet
opts *RouteOpts
log log.Logger
ctx context.Context
cancel func()
done chan struct{}
2015-09-25 16:14:46 +00:00
next *time.Timer
mtx sync.RWMutex
2015-09-25 16:14:46 +00:00
alerts map[model.Fingerprint]*types.Alert
hasSent bool
}
// newAggrGroup returns a new aggregation group.
func newAggrGroup(ctx context.Context, labels model.LabelSet, opts *RouteOpts) *aggrGroup {
ag := &aggrGroup{
labels: labels,
opts: opts,
2015-09-25 16:14:46 +00:00
alerts: map[model.Fingerprint]*types.Alert{},
}
ag.ctx, ag.cancel = context.WithCancel(ctx)
2015-10-07 14:18:55 +00:00
// Set an initial one-time wait before flushing
// the first batch of notifications.
ag.next = time.NewTimer(ag.opts.GroupWait)
return ag
}
func (ag *aggrGroup) String() string {
return fmt.Sprintf("%v", ag.fingerprint())
}
2015-09-29 13:12:31 +00:00
func (ag *aggrGroup) run(nf notifyFunc) {
ag.done = make(chan struct{})
defer close(ag.done)
defer ag.next.Stop()
for {
select {
case now := <-ag.next.C:
// Give the notifcations time until the next flush to
// finish before terminating them.
ctx, _ := context.WithTimeout(ag.ctx, ag.opts.GroupInterval)
// The now time we retrieve from the ticker is the only reliable
// point of time reference for the subsequent notification pipeline.
// Calculating the current time directly is prone to avoid flaky behavior,
// which usually only becomes apparent in tests.
ctx = notify.WithNow(ctx, now)
// Populate context with information needed along the pipeline.
ctx = notify.WithDestination(ctx, ag.opts.SendTo)
ctx = notify.WithGroup(ctx, ag.String())
ctx = notify.WithRepeatInterval(ctx, ag.opts.RepeatInterval)
ctx = notify.WithSendResolved(ctx, ag.opts.SendResolved)
// Wait the configured interval before calling flush again.
ag.next.Reset(ag.opts.GroupInterval)
ag.flush(func(alerts ...*types.Alert) bool {
2015-09-29 13:12:31 +00:00
return nf(ctx, alerts...)
})
case <-ag.ctx.Done():
return
}
}
}
func (ag *aggrGroup) stop() {
// Calling cancel will terminate all in-process notifications
// and the run() loop.
ag.cancel()
<-ag.done
}
func (ag *aggrGroup) fingerprint() model.Fingerprint {
return ag.labels.Fingerprint()
}
// insert the alert into the aggregation group. If the aggregation group
// is empty afterwards, true is returned.
2015-09-25 16:14:46 +00:00
func (ag *aggrGroup) insert(alert *types.Alert) {
ag.mtx.Lock()
defer ag.mtx.Unlock()
2015-09-25 16:14:46 +00:00
ag.alerts[alert.Fingerprint()] = alert
// Immediately trigger a flush if the wait duration for this
// alert is already over.
2015-09-29 15:26:44 +00:00
if !ag.hasSent && alert.UpdatedAt.Add(ag.opts.GroupWait).Before(time.Now()) {
ag.next.Reset(0)
}
}
func (ag *aggrGroup) empty() bool {
ag.mtx.RLock()
defer ag.mtx.RUnlock()
return len(ag.alerts) == 0
}
// flush sends notifications for all new alerts.
func (ag *aggrGroup) flush(notify func(...*types.Alert) bool) {
2015-09-27 17:50:41 +00:00
if ag.empty() {
return
}
ag.mtx.Lock()
var (
alerts = make(map[model.Fingerprint]*types.Alert, len(ag.alerts))
alertsSlice = make([]*types.Alert, 0, len(ag.alerts))
)
2015-09-25 16:14:46 +00:00
for fp, alert := range ag.alerts {
alerts[fp] = alert
alertsSlice = append(alertsSlice, alert)
}
ag.mtx.Unlock()
ag.log.Debugln("flushing", alertsSlice)
if notify(alertsSlice...) {
ag.mtx.Lock()
for fp, a := range alerts {
// Only delete if the fingerprint has not been inserted
// again since we notified about it.
if a.Resolved() && ag.alerts[fp] == a {
delete(ag.alerts, fp)
}
}
ag.mtx.Unlock()
2015-07-10 17:25:56 +00:00
}
ag.hasSent = true
}