mirror of
https://github.com/amir20/dozzle.git
synced 2025-12-21 13:23:07 +01:00
150 lines
3.6 KiB
Go
150 lines
3.6 KiB
Go
package docker
|
|
|
|
import (
|
|
"context"
|
|
"errors"
|
|
"io"
|
|
"sync"
|
|
"sync/atomic"
|
|
"time"
|
|
|
|
"github.com/puzpuzpuz/xsync/v3"
|
|
log "github.com/sirupsen/logrus"
|
|
)
|
|
|
|
type StatsCollector struct {
|
|
stream chan ContainerStat
|
|
subscribers *xsync.MapOf[context.Context, chan ContainerStat]
|
|
client Client
|
|
cancelers *xsync.MapOf[string, context.CancelFunc]
|
|
stopper context.CancelFunc
|
|
timer *time.Timer
|
|
mu sync.Mutex
|
|
totalStarted atomic.Int32
|
|
}
|
|
|
|
var timeToStop = 6 * time.Hour
|
|
|
|
func NewStatsCollector(client Client) *StatsCollector {
|
|
return &StatsCollector{
|
|
stream: make(chan ContainerStat),
|
|
subscribers: xsync.NewMapOf[context.Context, chan ContainerStat](),
|
|
client: client,
|
|
cancelers: xsync.NewMapOf[string, context.CancelFunc](),
|
|
}
|
|
}
|
|
|
|
func (c *StatsCollector) Subscribe(ctx context.Context, stats chan ContainerStat) {
|
|
c.subscribers.Store(ctx, stats)
|
|
}
|
|
|
|
func (c *StatsCollector) forceStop() {
|
|
c.mu.Lock()
|
|
defer c.mu.Unlock()
|
|
if c.stopper != nil {
|
|
c.stopper()
|
|
c.stopper = nil
|
|
log.Debug("stopping container stats collector")
|
|
}
|
|
}
|
|
|
|
func (c *StatsCollector) Stop() {
|
|
c.mu.Lock()
|
|
defer c.mu.Unlock()
|
|
if c.totalStarted.Add(-1) == 0 {
|
|
log.Debugf("scheduled to stop container stats collector %s", c.client.Host())
|
|
c.timer = time.AfterFunc(timeToStop, func() {
|
|
c.forceStop()
|
|
})
|
|
}
|
|
}
|
|
|
|
func (c *StatsCollector) reset() {
|
|
c.mu.Lock()
|
|
defer c.mu.Unlock()
|
|
log.Debugf("resetting timer for container stats collector %s", c.client.Host())
|
|
if c.timer != nil {
|
|
c.timer.Stop()
|
|
}
|
|
c.timer = nil
|
|
}
|
|
|
|
func streamStats(parent context.Context, sc *StatsCollector, id string) {
|
|
ctx, cancel := context.WithCancel(parent)
|
|
sc.cancelers.Store(id, cancel)
|
|
log.Debugf("starting to stream stats for: %s", id)
|
|
if err := sc.client.ContainerStats(ctx, id, sc.stream); err != nil {
|
|
log.Debugf("stopping to stream stats for: %s", id)
|
|
if !errors.Is(err, context.Canceled) && !errors.Is(err, io.EOF) {
|
|
log.Errorf("unexpected error when streaming container stats: %v", err)
|
|
}
|
|
}
|
|
}
|
|
|
|
// Start starts the stats collector and blocks until it's stopped. It returns true if the collector was stopped, false if it was already running
|
|
func (sc *StatsCollector) Start(parentCtx context.Context) bool {
|
|
sc.reset()
|
|
sc.totalStarted.Add(1)
|
|
|
|
var ctx context.Context
|
|
sc.mu.Lock()
|
|
if sc.stopper != nil {
|
|
sc.mu.Unlock()
|
|
return false
|
|
}
|
|
ctx, sc.stopper = context.WithCancel(parentCtx)
|
|
sc.mu.Unlock()
|
|
|
|
if containers, err := sc.client.ListContainers(); err == nil {
|
|
for _, c := range containers {
|
|
if c.State == "running" {
|
|
go streamStats(ctx, sc, c.ID)
|
|
}
|
|
}
|
|
} else {
|
|
log.Errorf("error while listing containers: %v", err)
|
|
}
|
|
|
|
events := make(chan ContainerEvent)
|
|
|
|
go func() {
|
|
log.Debugf("subscribing to docker events from stats collector %s", sc.client.Host())
|
|
err := sc.client.Events(context.Background(), events)
|
|
if !errors.Is(err, context.Canceled) {
|
|
log.Errorf("stats collector unexpectedly disconnected from docker events from %s with %v", sc.client.Host(), err)
|
|
}
|
|
sc.forceStop()
|
|
}()
|
|
|
|
go func() {
|
|
for event := range events {
|
|
switch event.Name {
|
|
case "start":
|
|
go streamStats(ctx, sc, event.ActorID)
|
|
|
|
case "die":
|
|
if cancel, ok := sc.cancelers.LoadAndDelete(event.ActorID); ok {
|
|
cancel()
|
|
}
|
|
}
|
|
}
|
|
}()
|
|
|
|
for {
|
|
select {
|
|
case <-ctx.Done():
|
|
log.Info("stopped collecting container stats")
|
|
return true
|
|
case stat := <-sc.stream:
|
|
sc.subscribers.Range(func(c context.Context, stats chan ContainerStat) bool {
|
|
select {
|
|
case stats <- stat:
|
|
case <-c.Done():
|
|
sc.subscribers.Delete(c)
|
|
}
|
|
return true
|
|
})
|
|
}
|
|
}
|
|
}
|