2017-04-19 12:43:09 +00:00
|
|
|
// 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.
|
|
|
|
|
2016-12-25 00:40:28 +00:00
|
|
|
package tsdb
|
|
|
|
|
|
|
|
import (
|
2017-10-04 19:04:15 +00:00
|
|
|
"context"
|
2017-09-18 10:32:17 +00:00
|
|
|
"sync"
|
2017-02-01 14:59:37 +00:00
|
|
|
"time"
|
2016-12-25 00:40:28 +00:00
|
|
|
"unsafe"
|
|
|
|
|
2017-08-11 18:45:52 +00:00
|
|
|
"github.com/go-kit/kit/log"
|
2017-05-22 09:53:08 +00:00
|
|
|
"github.com/pkg/errors"
|
2017-02-28 08:33:14 +00:00
|
|
|
"github.com/prometheus/client_golang/prometheus"
|
2017-06-16 13:07:34 +00:00
|
|
|
"github.com/prometheus/common/model"
|
2016-12-25 00:40:28 +00:00
|
|
|
"github.com/prometheus/prometheus/pkg/labels"
|
2016-12-25 10:12:57 +00:00
|
|
|
"github.com/prometheus/prometheus/storage"
|
2017-04-04 09:33:51 +00:00
|
|
|
"github.com/prometheus/tsdb"
|
|
|
|
tsdbLabels "github.com/prometheus/tsdb/labels"
|
2016-12-25 00:40:28 +00:00
|
|
|
)
|
|
|
|
|
2017-09-18 10:32:17 +00:00
|
|
|
// ErrNotReady is returned if the underlying storage is not ready yet.
|
|
|
|
var ErrNotReady = errors.New("TSDB not ready")
|
|
|
|
|
|
|
|
// ReadyStorage implements the Storage interface while allowing to set the actual
|
|
|
|
// storage at a later point in time.
|
|
|
|
type ReadyStorage struct {
|
|
|
|
mtx sync.RWMutex
|
|
|
|
a *adapter
|
|
|
|
}
|
|
|
|
|
|
|
|
// Set the storage.
|
2017-10-18 11:08:14 +00:00
|
|
|
func (s *ReadyStorage) Set(db *tsdb.DB, startTimeMargin int64) {
|
2017-09-18 10:32:17 +00:00
|
|
|
s.mtx.Lock()
|
|
|
|
defer s.mtx.Unlock()
|
|
|
|
|
2017-10-18 11:08:14 +00:00
|
|
|
s.a = &adapter{db: db, startTimeMargin: startTimeMargin}
|
2017-09-18 10:32:17 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// Get the storage.
|
|
|
|
func (s *ReadyStorage) Get() *tsdb.DB {
|
|
|
|
if x := s.get(); x != nil {
|
|
|
|
return x.db
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (s *ReadyStorage) get() *adapter {
|
|
|
|
s.mtx.RLock()
|
|
|
|
x := s.a
|
|
|
|
s.mtx.RUnlock()
|
|
|
|
return x
|
|
|
|
}
|
|
|
|
|
2017-10-18 11:08:14 +00:00
|
|
|
// StartTime implements the Storage interface.
|
|
|
|
func (s *ReadyStorage) StartTime() (int64, error) {
|
|
|
|
if x := s.get(); x != nil {
|
|
|
|
return x.StartTime()
|
|
|
|
}
|
|
|
|
return int64(model.Latest), ErrNotReady
|
|
|
|
}
|
|
|
|
|
2017-09-18 10:32:17 +00:00
|
|
|
// Querier implements the Storage interface.
|
2017-10-04 19:04:15 +00:00
|
|
|
func (s *ReadyStorage) Querier(ctx context.Context, mint, maxt int64) (storage.Querier, error) {
|
2017-09-18 10:32:17 +00:00
|
|
|
if x := s.get(); x != nil {
|
2017-10-04 19:04:15 +00:00
|
|
|
return x.Querier(ctx, mint, maxt)
|
2017-09-18 10:32:17 +00:00
|
|
|
}
|
|
|
|
return nil, ErrNotReady
|
|
|
|
}
|
|
|
|
|
|
|
|
// Appender implements the Storage interface.
|
|
|
|
func (s *ReadyStorage) Appender() (storage.Appender, error) {
|
|
|
|
if x := s.get(); x != nil {
|
|
|
|
return x.Appender()
|
|
|
|
}
|
|
|
|
return nil, ErrNotReady
|
|
|
|
}
|
|
|
|
|
|
|
|
// Close implements the Storage interface.
|
|
|
|
func (s *ReadyStorage) Close() error {
|
|
|
|
if x := s.Get(); x != nil {
|
|
|
|
return x.Close()
|
|
|
|
}
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2017-10-18 11:08:14 +00:00
|
|
|
// Adapter return an adapter as storage.Storage.
|
|
|
|
func Adapter(db *tsdb.DB, startTimeMargin int64) storage.Storage {
|
|
|
|
return &adapter{db: db, startTimeMargin: startTimeMargin}
|
2017-07-06 12:38:40 +00:00
|
|
|
}
|
|
|
|
|
2016-12-25 10:34:22 +00:00
|
|
|
// adapter implements a storage.Storage around TSDB.
|
|
|
|
type adapter struct {
|
2017-10-18 11:08:14 +00:00
|
|
|
db *tsdb.DB
|
|
|
|
startTimeMargin int64
|
2016-12-25 00:40:28 +00:00
|
|
|
}
|
|
|
|
|
2017-02-01 14:59:37 +00:00
|
|
|
// Options of the DB storage.
|
|
|
|
type Options struct {
|
|
|
|
// The interval at which the write ahead log is flushed to disc.
|
|
|
|
WALFlushInterval time.Duration
|
|
|
|
|
|
|
|
// The timestamp range of head blocks after which they get persisted.
|
|
|
|
// It's the minimum duration of any persisted block.
|
2017-06-16 13:07:34 +00:00
|
|
|
MinBlockDuration model.Duration
|
2017-02-01 14:59:37 +00:00
|
|
|
|
|
|
|
// The maximum timestamp range of compacted blocks.
|
2017-06-16 13:07:34 +00:00
|
|
|
MaxBlockDuration model.Duration
|
2017-02-01 14:59:37 +00:00
|
|
|
|
2017-03-17 15:06:04 +00:00
|
|
|
// Duration for how long to retain data.
|
2017-06-16 13:07:34 +00:00
|
|
|
Retention model.Duration
|
2017-05-09 10:56:51 +00:00
|
|
|
|
|
|
|
// Disable creation and consideration of lockfile.
|
|
|
|
NoLockfile bool
|
2017-02-01 14:59:37 +00:00
|
|
|
}
|
|
|
|
|
2017-07-06 12:38:40 +00:00
|
|
|
// Open returns a new storage backed by a TSDB database that is configured for Prometheus.
|
2017-08-11 18:45:52 +00:00
|
|
|
func Open(path string, l log.Logger, r prometheus.Registerer, opts *Options) (*tsdb.DB, error) {
|
2017-10-26 00:24:49 +00:00
|
|
|
if opts.MinBlockDuration > opts.MaxBlockDuration {
|
2017-10-30 11:09:56 +00:00
|
|
|
opts.MaxBlockDuration = opts.MinBlockDuration
|
2017-10-26 00:24:49 +00:00
|
|
|
}
|
2017-08-10 12:51:02 +00:00
|
|
|
// Start with smallest block duration and create exponential buckets until the exceed the
|
|
|
|
// configured maximum block duration.
|
2017-08-24 10:36:07 +00:00
|
|
|
rngs := tsdb.ExponentialBlockRanges(int64(time.Duration(opts.MinBlockDuration).Seconds()*1000), 10, 3)
|
2017-08-10 12:51:02 +00:00
|
|
|
|
|
|
|
for i, v := range rngs {
|
|
|
|
if v > int64(time.Duration(opts.MaxBlockDuration).Seconds()*1000) {
|
|
|
|
rngs = rngs[:i]
|
|
|
|
break
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2017-08-11 18:45:52 +00:00
|
|
|
db, err := tsdb.Open(path, l, r, &tsdb.Options{
|
2017-03-17 15:06:04 +00:00
|
|
|
WALFlushInterval: 10 * time.Second,
|
2017-06-16 13:07:34 +00:00
|
|
|
RetentionDuration: uint64(time.Duration(opts.Retention).Seconds() * 1000),
|
2017-08-10 12:51:02 +00:00
|
|
|
BlockRanges: rngs,
|
2017-05-09 10:56:51 +00:00
|
|
|
NoLockfile: opts.NoLockfile,
|
2017-02-01 14:59:37 +00:00
|
|
|
})
|
2016-12-25 00:40:28 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2017-07-06 12:38:40 +00:00
|
|
|
return db, nil
|
2016-12-25 00:40:28 +00:00
|
|
|
}
|
|
|
|
|
2017-10-18 11:08:14 +00:00
|
|
|
// StartTime implements the Storage interface.
|
|
|
|
func (a adapter) StartTime() (int64, error) {
|
2017-10-24 14:30:39 +00:00
|
|
|
var startTime int64
|
2017-10-18 11:08:14 +00:00
|
|
|
|
|
|
|
if len(a.db.Blocks()) > 0 {
|
2017-10-24 14:30:39 +00:00
|
|
|
startTime = a.db.Blocks()[0].Meta().MinTime
|
2017-10-18 11:08:14 +00:00
|
|
|
} else {
|
2017-10-24 14:30:39 +00:00
|
|
|
startTime = int64(time.Now().Unix() * 1000)
|
2017-10-18 11:08:14 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// Add a safety margin as it may take a few minutes for everything to spin up.
|
|
|
|
return startTime + a.startTimeMargin, nil
|
|
|
|
}
|
|
|
|
|
2017-10-04 19:04:15 +00:00
|
|
|
func (a adapter) Querier(_ context.Context, mint, maxt int64) (storage.Querier, error) {
|
2017-10-16 13:27:09 +00:00
|
|
|
q, err := a.db.Querier(mint, maxt)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
return querier{q: q}, nil
|
2016-12-25 00:40:28 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// Appender returns a new appender against the storage.
|
2016-12-25 10:34:22 +00:00
|
|
|
func (a adapter) Appender() (storage.Appender, error) {
|
|
|
|
return appender{a: a.db.Appender()}, nil
|
2016-12-25 00:40:28 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
// Close closes the storage and all its underlying resources.
|
2016-12-25 10:34:22 +00:00
|
|
|
func (a adapter) Close() error {
|
|
|
|
return a.db.Close()
|
2016-12-25 00:40:28 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
type querier struct {
|
|
|
|
q tsdb.Querier
|
|
|
|
}
|
|
|
|
|
2016-12-25 10:34:22 +00:00
|
|
|
func (q querier) Select(oms ...*labels.Matcher) storage.SeriesSet {
|
2016-12-25 00:40:28 +00:00
|
|
|
ms := make([]tsdbLabels.Matcher, 0, len(oms))
|
|
|
|
|
|
|
|
for _, om := range oms {
|
|
|
|
ms = append(ms, convertMatcher(om))
|
|
|
|
}
|
|
|
|
|
2016-12-28 08:16:48 +00:00
|
|
|
return seriesSet{set: q.q.Select(ms...)}
|
2016-12-25 00:40:28 +00:00
|
|
|
}
|
|
|
|
|
2016-12-25 10:34:22 +00:00
|
|
|
func (q querier) LabelValues(name string) ([]string, error) { return q.q.LabelValues(name) }
|
|
|
|
func (q querier) Close() error { return q.q.Close() }
|
2016-12-25 00:40:28 +00:00
|
|
|
|
|
|
|
type seriesSet struct {
|
|
|
|
set tsdb.SeriesSet
|
|
|
|
}
|
|
|
|
|
2017-01-02 12:33:37 +00:00
|
|
|
func (s seriesSet) Next() bool { return s.set.Next() }
|
|
|
|
func (s seriesSet) Err() error { return s.set.Err() }
|
|
|
|
func (s seriesSet) At() storage.Series { return series{s: s.set.At()} }
|
2016-12-25 00:40:28 +00:00
|
|
|
|
|
|
|
type series struct {
|
|
|
|
s tsdb.Series
|
|
|
|
}
|
|
|
|
|
2016-12-25 10:34:22 +00:00
|
|
|
func (s series) Labels() labels.Labels { return toLabels(s.s.Labels()) }
|
|
|
|
func (s series) Iterator() storage.SeriesIterator { return storage.SeriesIterator(s.s.Iterator()) }
|
2016-12-25 00:40:28 +00:00
|
|
|
|
|
|
|
type appender struct {
|
|
|
|
a tsdb.Appender
|
|
|
|
}
|
|
|
|
|
2017-09-07 12:14:41 +00:00
|
|
|
func (a appender) Add(lset labels.Labels, t int64, v float64) (uint64, error) {
|
2017-02-01 14:59:37 +00:00
|
|
|
ref, err := a.a.Add(toTSDBLabels(lset), t, v)
|
|
|
|
|
2017-05-22 09:53:08 +00:00
|
|
|
switch errors.Cause(err) {
|
2017-02-01 14:59:37 +00:00
|
|
|
case tsdb.ErrNotFound:
|
2017-09-07 12:14:41 +00:00
|
|
|
return 0, storage.ErrNotFound
|
2017-02-01 14:59:37 +00:00
|
|
|
case tsdb.ErrOutOfOrderSample:
|
2017-09-07 12:14:41 +00:00
|
|
|
return 0, storage.ErrOutOfOrderSample
|
2017-02-01 14:59:37 +00:00
|
|
|
case tsdb.ErrAmendSample:
|
2017-09-07 12:14:41 +00:00
|
|
|
return 0, storage.ErrDuplicateSampleForTimestamp
|
2017-07-06 12:18:31 +00:00
|
|
|
case tsdb.ErrOutOfBounds:
|
2017-09-07 12:14:41 +00:00
|
|
|
return 0, storage.ErrOutOfBounds
|
2017-02-01 14:59:37 +00:00
|
|
|
}
|
|
|
|
return ref, err
|
2016-12-28 08:16:48 +00:00
|
|
|
}
|
2017-01-02 12:33:37 +00:00
|
|
|
|
2017-09-07 12:14:41 +00:00
|
|
|
func (a appender) AddFast(_ labels.Labels, ref uint64, t int64, v float64) error {
|
2017-02-01 14:59:37 +00:00
|
|
|
err := a.a.AddFast(ref, t, v)
|
2017-01-15 16:33:07 +00:00
|
|
|
|
2017-05-22 09:53:08 +00:00
|
|
|
switch errors.Cause(err) {
|
2017-01-15 16:33:07 +00:00
|
|
|
case tsdb.ErrNotFound:
|
|
|
|
return storage.ErrNotFound
|
|
|
|
case tsdb.ErrOutOfOrderSample:
|
|
|
|
return storage.ErrOutOfOrderSample
|
|
|
|
case tsdb.ErrAmendSample:
|
|
|
|
return storage.ErrDuplicateSampleForTimestamp
|
2017-07-06 12:18:31 +00:00
|
|
|
case tsdb.ErrOutOfBounds:
|
|
|
|
return storage.ErrOutOfBounds
|
2017-01-15 16:33:07 +00:00
|
|
|
}
|
|
|
|
return err
|
2017-01-13 13:48:01 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
func (a appender) Commit() error { return a.a.Commit() }
|
|
|
|
func (a appender) Rollback() error { return a.a.Rollback() }
|
2016-12-25 00:40:28 +00:00
|
|
|
|
2016-12-25 10:12:57 +00:00
|
|
|
func convertMatcher(m *labels.Matcher) tsdbLabels.Matcher {
|
2016-12-25 00:40:28 +00:00
|
|
|
switch m.Type {
|
2016-12-25 10:34:22 +00:00
|
|
|
case labels.MatchEqual:
|
2016-12-25 00:40:28 +00:00
|
|
|
return tsdbLabels.NewEqualMatcher(m.Name, m.Value)
|
|
|
|
|
2016-12-25 10:34:22 +00:00
|
|
|
case labels.MatchNotEqual:
|
2016-12-25 00:40:28 +00:00
|
|
|
return tsdbLabels.Not(tsdbLabels.NewEqualMatcher(m.Name, m.Value))
|
|
|
|
|
2016-12-25 10:34:22 +00:00
|
|
|
case labels.MatchRegexp:
|
2017-10-10 17:10:21 +00:00
|
|
|
res, err := tsdbLabels.NewRegexpMatcher(m.Name, "^(?:"+m.Value+")$")
|
2016-12-25 00:40:28 +00:00
|
|
|
if err != nil {
|
|
|
|
panic(err)
|
|
|
|
}
|
|
|
|
return res
|
|
|
|
|
2016-12-25 10:34:22 +00:00
|
|
|
case labels.MatchNotRegexp:
|
2017-10-10 17:10:21 +00:00
|
|
|
res, err := tsdbLabels.NewRegexpMatcher(m.Name, "^(?:"+m.Value+")$")
|
2016-12-25 00:40:28 +00:00
|
|
|
if err != nil {
|
|
|
|
panic(err)
|
|
|
|
}
|
|
|
|
return tsdbLabels.Not(res)
|
|
|
|
}
|
2016-12-25 10:12:57 +00:00
|
|
|
panic("storage.convertMatcher: invalid matcher type")
|
2016-12-25 00:40:28 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
func toTSDBLabels(l labels.Labels) tsdbLabels.Labels {
|
|
|
|
return *(*tsdbLabels.Labels)(unsafe.Pointer(&l))
|
|
|
|
}
|
|
|
|
|
|
|
|
func toLabels(l tsdbLabels.Labels) labels.Labels {
|
|
|
|
return *(*labels.Labels)(unsafe.Pointer(&l))
|
|
|
|
}
|