mirror of
https://github.com/prometheus/prometheus.git
synced 2024-11-10 07:34:04 -08:00
103f26d188
Signed-off-by: chentanjun <2799194073@qq.com>
226 lines
5.9 KiB
Go
226 lines
5.9 KiB
Go
// Copyright 2017 The Prometheus Authors
|
|
// Licensed under the Apache License, Version 2.0 (the "License");
|
|
// you may not use this file except in compliance with the License.
|
|
// You may obtain a copy of the License at
|
|
//
|
|
// http://www.apache.org/licenses/LICENSE-2.0
|
|
//
|
|
// Unless required by applicable law or agreed to in writing, software
|
|
// distributed under the License is distributed on an "AS IS" BASIS,
|
|
// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
|
|
// See the License for the specific language governing permissions and
|
|
// limitations under the License.
|
|
|
|
package remote
|
|
|
|
import (
|
|
"crypto/md5"
|
|
"encoding/json"
|
|
"sync"
|
|
"time"
|
|
|
|
"github.com/go-kit/kit/log"
|
|
"github.com/go-kit/kit/log/level"
|
|
"github.com/prometheus/client_golang/prometheus"
|
|
"github.com/prometheus/client_golang/prometheus/promauto"
|
|
"github.com/prometheus/prometheus/config"
|
|
"github.com/prometheus/prometheus/pkg/labels"
|
|
"github.com/prometheus/prometheus/storage"
|
|
)
|
|
|
|
var (
|
|
samplesIn = promauto.NewCounter(prometheus.CounterOpts{
|
|
Namespace: namespace,
|
|
Subsystem: subsystem,
|
|
Name: "samples_in_total",
|
|
Help: "Samples in to remote storage, compare to samples out for queue managers.",
|
|
})
|
|
highestTimestamp = maxGauge{
|
|
Gauge: promauto.NewGauge(prometheus.GaugeOpts{
|
|
Namespace: namespace,
|
|
Subsystem: subsystem,
|
|
Name: "highest_timestamp_in_seconds",
|
|
Help: "Highest timestamp that has come into the remote storage via the Appender interface, in seconds since epoch.",
|
|
}),
|
|
}
|
|
)
|
|
|
|
// WriteStorage represents all the remote write storage.
|
|
type WriteStorage struct {
|
|
logger log.Logger
|
|
mtx sync.Mutex
|
|
|
|
configHash [16]byte
|
|
externalLabelHash [16]byte
|
|
walDir string
|
|
queues []*QueueManager
|
|
hashes [][16]byte
|
|
samplesIn *ewmaRate
|
|
flushDeadline time.Duration
|
|
}
|
|
|
|
// NewWriteStorage creates and runs a WriteStorage.
|
|
func NewWriteStorage(logger log.Logger, walDir string, flushDeadline time.Duration) *WriteStorage {
|
|
if logger == nil {
|
|
logger = log.NewNopLogger()
|
|
}
|
|
rws := &WriteStorage{
|
|
logger: logger,
|
|
flushDeadline: flushDeadline,
|
|
samplesIn: newEWMARate(ewmaWeight, shardUpdateDuration),
|
|
walDir: walDir,
|
|
}
|
|
go rws.run()
|
|
return rws
|
|
}
|
|
|
|
func (rws *WriteStorage) run() {
|
|
ticker := time.NewTicker(shardUpdateDuration)
|
|
defer ticker.Stop()
|
|
for range ticker.C {
|
|
rws.samplesIn.tick()
|
|
}
|
|
}
|
|
|
|
// ApplyConfig updates the state as the new config requires.
|
|
// Only stop & create queues which have changes.
|
|
func (rws *WriteStorage) ApplyConfig(conf *config.Config) error {
|
|
rws.mtx.Lock()
|
|
defer rws.mtx.Unlock()
|
|
|
|
// Remote write queues only need to change if the remote write config or
|
|
// external labels change. Hash these together and only reload if the hash
|
|
// changes.
|
|
cfgBytes, err := json.Marshal(conf.RemoteWriteConfigs)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
externalLabelBytes, err := json.Marshal(conf.GlobalConfig.ExternalLabels)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
configHash := md5.Sum(cfgBytes)
|
|
externalLabelHash := md5.Sum(externalLabelBytes)
|
|
externalLabelUnchanged := externalLabelHash == rws.externalLabelHash
|
|
if configHash == rws.configHash && externalLabelUnchanged {
|
|
level.Debug(rws.logger).Log("msg", "remote write config has not changed, no need to restart QueueManagers")
|
|
return nil
|
|
}
|
|
|
|
rws.configHash = configHash
|
|
rws.externalLabelHash = externalLabelHash
|
|
|
|
// Update write queues
|
|
newQueues := []*QueueManager{}
|
|
newHashes := [][16]byte{}
|
|
newClientIndexes := []int{}
|
|
for i, rwConf := range conf.RemoteWriteConfigs {
|
|
b, err := json.Marshal(rwConf)
|
|
if err != nil {
|
|
return err
|
|
}
|
|
|
|
// Use RemoteWriteConfigs and its index to get hash. So if its index changed,
|
|
// the corresponding queue should also be restarted.
|
|
hash := md5.Sum(b)
|
|
if i < len(rws.queues) && rws.hashes[i] == hash && externalLabelUnchanged {
|
|
// The RemoteWriteConfig and index both not changed, keep the queue.
|
|
newQueues = append(newQueues, rws.queues[i])
|
|
newHashes = append(newHashes, hash)
|
|
rws.queues[i] = nil
|
|
continue
|
|
}
|
|
// Otherwise create a new queue.
|
|
c, err := NewClient(i, &ClientConfig{
|
|
URL: rwConf.URL,
|
|
Timeout: rwConf.RemoteTimeout,
|
|
HTTPClientConfig: rwConf.HTTPClientConfig,
|
|
})
|
|
if err != nil {
|
|
return err
|
|
}
|
|
newQueues = append(newQueues, NewQueueManager(
|
|
prometheus.DefaultRegisterer,
|
|
rws.logger,
|
|
rws.walDir,
|
|
rws.samplesIn,
|
|
rwConf.QueueConfig,
|
|
conf.GlobalConfig.ExternalLabels,
|
|
rwConf.WriteRelabelConfigs,
|
|
c,
|
|
rws.flushDeadline,
|
|
))
|
|
newHashes = append(newHashes, hash)
|
|
newClientIndexes = append(newClientIndexes, i)
|
|
}
|
|
|
|
for _, q := range rws.queues {
|
|
// A nil queue means that queue has been reused.
|
|
if q != nil {
|
|
q.Stop()
|
|
}
|
|
}
|
|
|
|
for _, index := range newClientIndexes {
|
|
newQueues[index].Start()
|
|
}
|
|
|
|
rws.queues = newQueues
|
|
rws.hashes = newHashes
|
|
|
|
return nil
|
|
}
|
|
|
|
// Appender implements storage.Storage.
|
|
func (rws *WriteStorage) Appender() (storage.Appender, error) {
|
|
return ×tampTracker{
|
|
writeStorage: rws,
|
|
}, nil
|
|
}
|
|
|
|
// Close closes the WriteStorage.
|
|
func (rws *WriteStorage) Close() error {
|
|
rws.mtx.Lock()
|
|
defer rws.mtx.Unlock()
|
|
for _, q := range rws.queues {
|
|
q.Stop()
|
|
}
|
|
return nil
|
|
}
|
|
|
|
type timestampTracker struct {
|
|
writeStorage *WriteStorage
|
|
samples int64
|
|
highestTimestamp int64
|
|
}
|
|
|
|
// Add implements storage.Appender.
|
|
func (t *timestampTracker) Add(_ labels.Labels, ts int64, v float64) (uint64, error) {
|
|
t.samples++
|
|
if ts > t.highestTimestamp {
|
|
t.highestTimestamp = ts
|
|
}
|
|
return 0, nil
|
|
}
|
|
|
|
// AddFast implements storage.Appender.
|
|
func (t *timestampTracker) AddFast(l labels.Labels, _ uint64, ts int64, v float64) error {
|
|
_, err := t.Add(l, ts, v)
|
|
return err
|
|
}
|
|
|
|
// Commit implements storage.Appender.
|
|
func (t *timestampTracker) Commit() error {
|
|
t.writeStorage.samplesIn.incr(t.samples)
|
|
|
|
samplesIn.Add(float64(t.samples))
|
|
highestTimestamp.Set(float64(t.highestTimestamp / 1000))
|
|
return nil
|
|
}
|
|
|
|
// Rollback implements storage.Appender.
|
|
func (*timestampTracker) Rollback() error {
|
|
return nil
|
|
}
|