prometheus/db.go

501 lines
10 KiB
Go
Raw Normal View History

2016-11-15 09:34:25 +00:00
// Package tsdb implements a time series storage for float64 sample data.
package tsdb
import (
"bytes"
2016-12-04 12:16:11 +00:00
"fmt"
"os"
"path/filepath"
"reflect"
2016-12-04 12:16:11 +00:00
"sort"
2016-12-15 07:31:26 +00:00
"strconv"
"sync"
2016-11-15 09:34:25 +00:00
"time"
"unsafe"
2016-11-15 09:34:25 +00:00
2016-12-15 07:31:26 +00:00
"golang.org/x/sync/errgroup"
2016-12-04 12:16:11 +00:00
"github.com/cespare/xxhash"
"github.com/fabxc/tsdb/chunks"
"github.com/go-kit/kit/log"
2016-11-15 09:34:25 +00:00
)
2016-12-09 09:00:14 +00:00
// DefaultOptions used for the DB. They are sane for setups using
// millisecond precision timestamps.
2016-11-15 09:34:25 +00:00
var DefaultOptions = &Options{
2016-12-09 09:00:14 +00:00
Retention: 15 * 24 * 3600 * 1000, // 15 days
2016-11-15 09:34:25 +00:00
}
// Options of the DB storage.
type Options struct {
2016-12-09 09:00:14 +00:00
Retention int64
2016-11-15 09:34:25 +00:00
}
// DB is a time series storage.
type DB struct {
logger log.Logger
opts *Options
path string
2016-11-15 09:34:25 +00:00
2016-12-15 07:36:09 +00:00
shards []*Shard
2016-11-15 09:34:25 +00:00
}
2016-12-04 12:16:11 +00:00
// TODO(fabxc): make configurable
const (
shardShift = 3
2016-12-15 07:36:09 +00:00
numShards = 1 << shardShift
maxChunkSize = 1024
2016-12-04 12:16:11 +00:00
)
2016-11-15 09:34:25 +00:00
// Open or create a new DB.
func Open(path string, l log.Logger, opts *Options) (*DB, error) {
if opts == nil {
opts = DefaultOptions
}
2016-12-04 12:16:11 +00:00
if err := os.MkdirAll(path, 0777); err != nil {
return nil, err
}
if l == nil {
l = log.NewLogfmtLogger(os.Stdout)
l = log.NewContext(l).With("ts", log.DefaultTimestampUTC, "caller", log.DefaultCaller)
}
2016-11-15 09:34:25 +00:00
c := &DB{
2016-12-04 12:16:11 +00:00
logger: l,
opts: opts,
path: path,
2016-11-15 09:34:25 +00:00
}
2016-12-04 12:16:11 +00:00
// Initialize vertical shards.
// TODO(fabxc): validate shard number to be power of 2, which is required
// for the bitshift-modulo when finding the right shard.
2016-12-15 07:36:09 +00:00
for i := 0; i < numShards; i++ {
l := log.NewContext(l).With("shard", i)
2016-12-15 07:31:26 +00:00
d := shardDir(path, i)
2016-12-15 07:36:09 +00:00
s, err := OpenShard(d, l)
2016-12-15 07:31:26 +00:00
if err != nil {
return nil, fmt.Errorf("initializing shard %q failed: %s", d, err)
}
c.shards = append(c.shards, s)
2016-12-04 12:16:11 +00:00
}
// TODO(fabxc): run background compaction + GC.
2016-11-15 09:34:25 +00:00
return c, nil
}
2016-12-15 07:31:26 +00:00
func shardDir(base string, i int) string {
return filepath.Join(base, strconv.Itoa(i))
}
2016-12-04 12:16:11 +00:00
// Close the database.
func (db *DB) Close() error {
2016-12-15 07:31:26 +00:00
var g errgroup.Group
2016-12-09 09:00:14 +00:00
2016-12-15 07:31:26 +00:00
for _, shard := range db.shards {
// Fix closure argument to goroutine.
shard := shard
g.Go(shard.Close)
}
2016-12-09 09:00:14 +00:00
2016-12-15 07:31:26 +00:00
return g.Wait()
2016-12-04 12:16:11 +00:00
}
// Appender allows committing batches of samples to a database.
// The data held by the appender is reset after Commit returns.
type Appender interface {
// AddSeries registers a new known series label set with the appender
// and returns a reference number used to add samples to it over the
// life time of the Appender.
// AddSeries(Labels) uint64
// Add adds a sample pair for the referenced series.
Add(lset Labels, t int64, v float64)
// Commit submits the collected samples and purges the batch.
Commit() error
}
// Appender returns a new appender against the database.
func (db *DB) Appender() Appender {
return &bucketAppender{
db: db,
buckets: make([][]hashedSample, numShards),
}
}
type bucketAppender struct {
db *DB
buckets [][]hashedSample
}
func (ba *bucketAppender) Add(lset Labels, t int64, v float64) {
h := lset.Hash()
s := h >> (64 - shardShift)
ba.buckets[s] = append(ba.buckets[s], hashedSample{
hash: h,
labels: lset,
t: t,
v: v,
})
}
func (ba *bucketAppender) reset() {
for i := range ba.buckets {
ba.buckets[i] = ba.buckets[i][:0]
2016-12-09 12:41:38 +00:00
}
}
func (ba *bucketAppender) Commit() error {
defer ba.reset()
2016-12-09 12:41:38 +00:00
var merr MultiError
// Spill buckets into shards.
for s, b := range ba.buckets {
merr.Add(ba.db.shards[s].appendBatch(b))
}
return merr.Err()
2016-12-09 12:41:38 +00:00
}
type hashedSample struct {
hash uint64
labels Labels
t int64
v float64
2016-12-09 15:54:38 +00:00
}
2016-12-09 09:00:14 +00:00
const sep = '\xff'
2016-12-15 07:36:09 +00:00
// Shard handles reads and writes of time series falling into
2016-12-09 09:00:14 +00:00
// a hashed shard of a series.
2016-12-15 07:36:09 +00:00
type Shard struct {
2016-12-09 12:41:38 +00:00
path string
persistCh chan struct{}
logger log.Logger
2016-12-09 09:00:14 +00:00
2016-12-15 07:31:26 +00:00
mtx sync.RWMutex
persisted persistedBlocks
head *HeadBlock
2016-12-09 09:00:14 +00:00
}
2016-12-15 07:36:09 +00:00
// OpenShard returns a new Shard.
func OpenShard(path string, logger log.Logger) (*Shard, error) {
2016-12-15 07:31:26 +00:00
// Create directory if shard is new.
if _, err := os.Stat(path); os.IsNotExist(err) {
if err := os.MkdirAll(path, 0777); err != nil {
return nil, err
}
}
// Initialize previously persisted blocks.
pbs, err := findPersistedBlocks(path)
if err != nil {
return nil, err
}
2016-12-15 07:36:09 +00:00
s := &Shard{
2016-12-09 12:41:38 +00:00
path: path,
persistCh: make(chan struct{}, 1),
logger: logger,
2016-12-15 07:31:26 +00:00
persisted: pbs,
2016-12-09 09:00:14 +00:00
// TODO(fabxc): restore from checkpoint.
}
2016-12-09 12:41:38 +00:00
// TODO(fabxc): get base time from pre-existing blocks. Otherwise
// it should come from a user defined start timestamp.
// Use actual time for now.
s.head = NewHeadBlock(time.Now().UnixNano() / int64(time.Millisecond))
2016-12-15 07:31:26 +00:00
return s, nil
2016-12-09 12:41:38 +00:00
}
2016-12-15 07:36:09 +00:00
// Close the shard.
func (s *Shard) Close() error {
2016-12-15 07:31:26 +00:00
var e MultiError
for _, pb := range s.persisted {
e.Add(pb.Close())
}
return e.Err()
2016-12-09 09:00:14 +00:00
}
func (s *Shard) appendBatch(samples []hashedSample) error {
2016-12-09 12:41:38 +00:00
s.mtx.Lock()
defer s.mtx.Unlock()
var merr MultiError
2016-12-09 12:41:38 +00:00
for _, sm := range samples {
merr.Add(s.head.append(sm.hash, sm.labels, sm.t, sm.v))
2016-12-09 12:41:38 +00:00
}
// TODO(fabxc): randomize over time
if s.head.stats.SampleCount/uint64(s.head.stats.ChunkCount) > 400 {
2016-12-09 12:41:38 +00:00
select {
case s.persistCh <- struct{}{}:
go func() {
if err := s.persist(); err != nil {
s.logger.Log("msg", "persistance error", "err", err)
}
}()
2016-12-09 12:41:38 +00:00
default:
}
}
return merr.Err()
2016-12-09 12:41:38 +00:00
}
func intervalOverlap(amin, amax, bmin, bmax int64) bool {
if bmin >= amin && bmin <= amax {
return true
}
if amin >= bmin && amin <= bmax {
return true
}
return false
}
func intervalContains(min, max, t int64) bool {
return t >= min && t <= max
}
2016-12-13 14:26:58 +00:00
// blocksForRange returns all blocks within the shard that may contain
// data for the given time range.
func (s *Shard) blocksForInterval(mint, maxt int64) []block {
var bs []block
for _, b := range s.persisted {
bmin, bmax := b.interval()
if intervalOverlap(mint, maxt, bmin, bmax) {
bs = append(bs, b)
}
}
hmin, hmax := s.head.interval()
if intervalOverlap(mint, maxt, hmin, hmax) {
bs = append(bs, s.head)
}
return bs
2016-12-13 14:26:58 +00:00
}
2016-12-09 12:41:38 +00:00
// TODO(fabxc): make configurable.
const shardGracePeriod = 60 * 1000 // 60 seconds for millisecond scale
2016-12-15 07:36:09 +00:00
func (s *Shard) persist() error {
2016-12-09 12:41:38 +00:00
s.mtx.Lock()
// Set new head block.
head := s.head
s.head = NewHeadBlock(head.stats.MaxTime)
2016-12-09 12:41:38 +00:00
s.mtx.Unlock()
// Only allow another persistence to be triggered after the current one
// has completed (successful or not.)
2016-12-09 12:41:38 +00:00
defer func() {
<-s.persistCh
}()
// TODO(fabxc): add grace period where we can still append to old head shard
// before actually persisting it.
p := filepath.Join(s.path, fmt.Sprintf("%d", head.stats.MinTime))
2016-12-09 12:41:38 +00:00
if err := os.MkdirAll(p, 0777); err != nil {
return err
}
2016-12-19 21:37:03 +00:00
n, err := head.persist(p)
2016-12-09 20:23:34 +00:00
if err != nil {
return err
}
2016-12-19 21:37:03 +00:00
sz := fmt.Sprintf("%.2fMiB", float64(n)/1024/1024)
s.logger.Log("size", sz, "samples", head.stats.SampleCount, "chunks", head.stats.ChunkCount, "msg", "persisted head")
2016-12-09 12:41:38 +00:00
// Reopen block as persisted block for querying.
pb, err := newPersistedBlock(p)
if err != nil {
return err
}
s.mtx.Lock()
s.persisted = append(s.persisted, pb)
s.mtx.Unlock()
2016-12-09 12:41:38 +00:00
return nil
}
2016-12-09 09:00:14 +00:00
// chunkDesc wraps a plain data chunk and provides cached meta data about it.
type chunkDesc struct {
lset Labels
chunk chunks.Chunk
// Caching fields.
firsTimestamp int64
2016-12-09 09:00:14 +00:00
lastTimestamp int64
lastValue float64
app chunks.Appender // Current appender for the chunks.
}
func (cd *chunkDesc) append(ts int64, v float64) (err error) {
if cd.app == nil {
cd.app, err = cd.chunk.Appender()
if err != nil {
return err
}
cd.firsTimestamp = ts
2016-12-09 09:00:14 +00:00
}
if err := cd.app.Append(ts, v); err != nil {
return err
}
cd.lastTimestamp = ts
cd.lastValue = v
return nil
}
2016-12-04 12:16:11 +00:00
// Label is a key/value pair of strings.
2016-12-02 16:49:05 +00:00
type Label struct {
Name, Value string
2016-11-15 09:34:25 +00:00
}
2016-12-04 12:16:11 +00:00
// Labels is a sorted set of labels. Order has to be guaranteed upon
2016-12-02 16:49:05 +00:00
// instantiation.
2016-12-04 12:16:11 +00:00
type Labels []Label
func (ls Labels) Len() int { return len(ls) }
func (ls Labels) Swap(i, j int) { ls[i], ls[j] = ls[j], ls[i] }
func (ls Labels) Less(i, j int) bool { return ls[i].Name < ls[j].Name }
// Hash returns a hash value for the label set.
func (ls Labels) Hash() uint64 {
2016-12-08 09:04:24 +00:00
b := make([]byte, 0, 1024)
2016-12-04 12:16:11 +00:00
for _, v := range ls {
b = append(b, v.Name...)
2016-12-05 20:25:20 +00:00
b = append(b, sep)
2016-12-04 12:16:11 +00:00
b = append(b, v.Value...)
2016-12-05 20:25:20 +00:00
b = append(b, sep)
2016-12-04 12:16:11 +00:00
}
return xxhash.Sum64(b)
}
// Get returns the value for the label with the given name.
// Returns an empty string if the label doesn't exist.
func (ls Labels) Get(name string) string {
for _, l := range ls {
if l.Name == name {
return l.Value
}
}
return ""
}
// Equals returns whether the two label sets are equal.
func (ls Labels) Equals(o Labels) bool {
if len(ls) != len(o) {
return false
}
for i, l := range ls {
if l.Name != o[i].Name || l.Value != o[i].Value {
return false
}
}
return true
}
2016-11-15 09:34:25 +00:00
2016-12-04 12:16:11 +00:00
// Map returns a string map of the labels.
func (ls Labels) Map() map[string]string {
m := make(map[string]string, len(ls))
for _, l := range ls {
m[l.Name] = l.Value
}
return m
}
2016-11-15 09:34:25 +00:00
2016-12-04 12:16:11 +00:00
// NewLabels returns a sorted Labels from the given labels.
2016-12-02 16:49:05 +00:00
// The caller has to guarantee that all label names are unique.
2016-12-04 12:16:11 +00:00
func NewLabels(ls ...Label) Labels {
set := make(Labels, 0, len(ls))
2016-12-02 16:49:05 +00:00
for _, l := range ls {
set = append(set, l)
2016-11-15 09:34:25 +00:00
}
2016-12-02 16:49:05 +00:00
sort.Sort(set)
2016-11-15 09:34:25 +00:00
2016-12-02 16:49:05 +00:00
return set
2016-11-15 09:34:25 +00:00
}
2016-12-04 12:16:11 +00:00
// LabelsFromMap returns new sorted Labels from the given map.
func LabelsFromMap(m map[string]string) Labels {
l := make([]Label, 0, len(m))
for k, v := range m {
l = append(l, Label{Name: k, Value: v})
}
return NewLabels(l...)
}
// The MultiError type implements the error interface, and contains the
// Errors used to construct it.
type MultiError []error
// Returns a concatenated string of the contained errors
func (es MultiError) Error() string {
var buf bytes.Buffer
if len(es) > 0 {
fmt.Fprintf(&buf, "%d errors: ", len(es))
2016-12-08 09:04:24 +00:00
}
for i, err := range es {
if i != 0 {
buf.WriteString("; ")
}
buf.WriteString(err.Error())
}
return buf.String()
2016-11-15 09:34:25 +00:00
}
2016-12-15 07:31:26 +00:00
// Add adds the error to the error list if it is not nil.
2016-12-15 07:31:26 +00:00
func (es MultiError) Add(err error) {
if err != nil {
es = append(es, err)
}
}
// Err returns the error list as an error or nil if it is empty.
2016-12-15 07:31:26 +00:00
func (es MultiError) Err() error {
if len(es) == 0 {
return nil
}
return es
}
func yoloString(b []byte) string {
h := reflect.StringHeader{
Data: uintptr(unsafe.Pointer(&b[0])),
Len: len(b),
}
return *((*string)(unsafe.Pointer(&h)))
}
func yoloBytes(s string) []byte {
sh := (*reflect.StringHeader)(unsafe.Pointer(&s))
h := reflect.SliceHeader{
Cap: sh.Len,
Len: sh.Len,
Data: sh.Data,
}
return *((*[]byte)(unsafe.Pointer(&h)))
}