2017-04-10 11:59:45 -07: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-11-15 01:34:25 -08:00
|
|
|
// Package tsdb implements a time series storage for float64 sample data.
|
|
|
|
package tsdb
|
|
|
|
|
|
|
|
import (
|
2018-12-05 08:34:42 -08:00
|
|
|
"context"
|
2016-12-04 04:16:11 -08:00
|
|
|
"fmt"
|
2017-02-27 01:46:15 -08:00
|
|
|
"io"
|
2017-01-06 00:26:39 -08:00
|
|
|
"io/ioutil"
|
2018-04-05 05:51:33 -07:00
|
|
|
"math"
|
2016-12-04 04:16:11 -08:00
|
|
|
"os"
|
2016-12-08 08:43:10 -08:00
|
|
|
"path/filepath"
|
2017-09-08 06:09:24 -07:00
|
|
|
"runtime"
|
2017-05-18 07:09:30 -07:00
|
|
|
"sort"
|
2016-12-14 23:31:26 -08:00
|
|
|
"strconv"
|
2018-04-05 05:51:33 -07:00
|
|
|
"strings"
|
2016-12-08 08:43:10 -08:00
|
|
|
"sync"
|
2017-01-06 06:18:06 -08:00
|
|
|
"time"
|
2016-12-14 23:31:26 -08:00
|
|
|
|
2016-12-14 09:38:46 -08:00
|
|
|
"github.com/go-kit/kit/log"
|
2017-09-28 00:19:34 -07:00
|
|
|
"github.com/go-kit/kit/log/level"
|
2017-05-18 07:09:30 -07:00
|
|
|
"github.com/oklog/ulid"
|
2017-01-03 06:43:26 -08:00
|
|
|
"github.com/pkg/errors"
|
2016-12-31 00:48:49 -08:00
|
|
|
"github.com/prometheus/client_golang/prometheus"
|
2019-11-18 11:53:33 -08:00
|
|
|
"github.com/prometheus/prometheus/pkg/labels"
|
2020-02-06 07:58:38 -08:00
|
|
|
"github.com/prometheus/prometheus/storage"
|
2019-08-13 01:34:14 -07:00
|
|
|
"github.com/prometheus/prometheus/tsdb/chunkenc"
|
|
|
|
tsdb_errors "github.com/prometheus/prometheus/tsdb/errors"
|
|
|
|
"github.com/prometheus/prometheus/tsdb/fileutil"
|
|
|
|
_ "github.com/prometheus/prometheus/tsdb/goversion"
|
|
|
|
"github.com/prometheus/prometheus/tsdb/wal"
|
2018-04-05 05:51:33 -07:00
|
|
|
"golang.org/x/sync/errgroup"
|
2016-11-15 01:34:25 -08:00
|
|
|
)
|
|
|
|
|
2019-11-21 04:10:25 -08:00
|
|
|
const (
|
2020-02-11 08:34:09 -08:00
|
|
|
// Default duration of a block in milliseconds.
|
|
|
|
DefaultBlockDuration = int64(2 * time.Hour / time.Millisecond)
|
2020-02-06 07:58:38 -08:00
|
|
|
)
|
|
|
|
|
|
|
|
var (
|
|
|
|
// ErrNotReady is returned if the underlying storage is not ready yet.
|
|
|
|
ErrNotReady = errors.New("TSDB not ready")
|
2019-11-21 04:10:25 -08:00
|
|
|
)
|
|
|
|
|
2016-12-09 01:00:14 -08:00
|
|
|
// DefaultOptions used for the DB. They are sane for setups using
|
2018-03-02 03:12:32 -08:00
|
|
|
// millisecond precision timestamps.
|
2020-02-06 07:58:38 -08:00
|
|
|
func DefaultOptions() *Options {
|
|
|
|
return &Options{
|
|
|
|
WALSegmentSize: wal.DefaultSegmentSize,
|
2020-02-11 08:34:09 -08:00
|
|
|
RetentionDuration: int64(15 * 24 * time.Hour / time.Millisecond),
|
|
|
|
MinBlockDuration: DefaultBlockDuration,
|
|
|
|
MaxBlockDuration: DefaultBlockDuration,
|
2020-02-06 07:58:38 -08:00
|
|
|
NoLockfile: false,
|
|
|
|
AllowOverlappingBlocks: false,
|
|
|
|
WALCompression: false,
|
|
|
|
StripeSize: DefaultStripeSize,
|
|
|
|
}
|
2016-11-15 01:34:25 -08:00
|
|
|
}
|
|
|
|
|
|
|
|
// Options of the DB storage.
|
|
|
|
type Options struct {
|
2019-03-25 16:38:12 -07:00
|
|
|
// Segments (wal files) max size.
|
|
|
|
// WALSegmentSize = 0, segment size is default size.
|
|
|
|
// WALSegmentSize > 0, segment size is WALSegmentSize.
|
|
|
|
// WALSegmentSize < 0, wal is disabled.
|
2020-02-11 08:34:09 -08:00
|
|
|
WALSegmentSize int
|
2017-01-28 23:11:47 -08:00
|
|
|
|
2017-02-09 17:54:26 -08:00
|
|
|
// Duration of persisted data to keep.
|
2020-02-11 08:34:09 -08:00
|
|
|
// Unit agnostic as long as unit is consistent with MinBlockDuration and MaxBlockDuration.
|
|
|
|
// Typically it is in milliseconds.
|
|
|
|
RetentionDuration int64
|
2017-02-09 17:54:26 -08:00
|
|
|
|
2019-01-16 02:03:52 -08:00
|
|
|
// Maximum number of bytes in blocks to be retained.
|
|
|
|
// 0 or less means disabled.
|
|
|
|
// NOTE: For proper storage calculations need to consider
|
|
|
|
// the size of the WAL folder which is not added when calculating
|
|
|
|
// the current size of the database.
|
2020-02-11 08:34:09 -08:00
|
|
|
MaxBytes int64
|
2017-01-28 23:11:47 -08:00
|
|
|
|
2017-05-09 03:52:47 -07:00
|
|
|
// NoLockfile disables creation and consideration of a lock file.
|
|
|
|
NoLockfile bool
|
2019-02-26 11:50:37 -08:00
|
|
|
|
2019-03-02 05:54:49 -08:00
|
|
|
// Overlapping blocks are allowed if AllowOverlappingBlocks is true.
|
2019-02-26 11:50:37 -08:00
|
|
|
// This in-turn enables vertical compaction and vertical query merge.
|
2019-03-02 05:54:49 -08:00
|
|
|
AllowOverlappingBlocks bool
|
2019-06-19 06:46:24 -07:00
|
|
|
|
|
|
|
// WALCompression will turn on Snappy compression for records on the WAL.
|
|
|
|
WALCompression bool
|
2020-01-29 23:12:43 -08:00
|
|
|
|
2020-02-17 03:45:11 -08:00
|
|
|
// StripeSize is the size in entries of the series hash map. Reducing the size will save memory but impact performance.
|
2020-01-29 23:12:43 -08:00
|
|
|
StripeSize int
|
2016-11-15 01:34:25 -08:00
|
|
|
|
2020-02-06 07:58:38 -08:00
|
|
|
// The timestamp range of head blocks after which they get persisted.
|
|
|
|
// It's the minimum duration of any persisted block.
|
2020-02-11 08:34:09 -08:00
|
|
|
// Unit agnostic as long as unit is consistent with RetentionDuration and MaxBlockDuration.
|
|
|
|
// Typically it is in milliseconds.
|
|
|
|
MinBlockDuration int64
|
2020-02-06 07:58:38 -08:00
|
|
|
|
|
|
|
// The maximum timestamp range of compacted blocks.
|
2020-02-11 08:34:09 -08:00
|
|
|
// Unit agnostic as long as unit is consistent with MinBlockDuration and RetentionDuration.
|
|
|
|
// Typically it is in milliseconds.
|
|
|
|
MaxBlockDuration int64
|
2016-12-10 09:08:50 -08:00
|
|
|
}
|
|
|
|
|
2017-01-06 02:40:09 -08:00
|
|
|
// DB handles reads and writes of time series falling into
|
|
|
|
// a hashed partition of a seriedb.
|
|
|
|
type DB struct {
|
2017-03-04 07:50:48 -08:00
|
|
|
dir string
|
2018-05-29 11:35:48 -07:00
|
|
|
lockf fileutil.Releaser
|
2017-03-04 07:50:48 -08:00
|
|
|
|
2017-08-30 09:34:54 -07:00
|
|
|
logger log.Logger
|
|
|
|
metrics *dbMetrics
|
|
|
|
opts *Options
|
2017-11-30 06:34:49 -08:00
|
|
|
chunkPool chunkenc.Pool
|
2017-08-30 09:34:54 -07:00
|
|
|
compactor Compactor
|
2016-12-09 01:00:14 -08:00
|
|
|
|
2017-07-14 00:00:22 -07:00
|
|
|
// Mutex for that must be held when modifying the general block layout.
|
2017-03-20 00:41:56 -07:00
|
|
|
mtx sync.RWMutex
|
2017-10-09 06:21:46 -07:00
|
|
|
blocks []*Block
|
2017-03-04 07:50:48 -08:00
|
|
|
|
2017-08-28 15:39:17 -07:00
|
|
|
head *Head
|
2017-01-06 03:37:28 -08:00
|
|
|
|
|
|
|
compactc chan struct{}
|
|
|
|
donec chan struct{}
|
|
|
|
stopc chan struct{}
|
2017-05-20 00:51:10 -07:00
|
|
|
|
2018-11-20 02:34:26 -08:00
|
|
|
// cmtx ensures that compactions and deletions don't run simultaneously.
|
|
|
|
cmtx sync.Mutex
|
|
|
|
|
|
|
|
// autoCompactMtx ensures that no compaction gets triggered while
|
|
|
|
// changing the autoCompact var.
|
|
|
|
autoCompactMtx sync.Mutex
|
|
|
|
autoCompact bool
|
2018-12-05 08:34:42 -08:00
|
|
|
|
|
|
|
// Cancel a running compaction when a shutdown is initiated.
|
2019-02-06 04:07:35 -08:00
|
|
|
compactCancel context.CancelFunc
|
2016-12-09 01:00:14 -08:00
|
|
|
}
|
|
|
|
|
2017-01-06 02:40:09 -08:00
|
|
|
type dbMetrics struct {
|
2017-08-30 09:34:54 -07:00
|
|
|
loadedBlocks prometheus.GaugeFunc
|
2018-09-08 11:28:36 -07:00
|
|
|
symbolTableSize prometheus.GaugeFunc
|
2017-08-30 09:34:54 -07:00
|
|
|
reloads prometheus.Counter
|
|
|
|
reloadsFailed prometheus.Counter
|
2019-05-30 04:57:28 -07:00
|
|
|
compactionsFailed prometheus.Counter
|
2020-01-13 14:15:45 -08:00
|
|
|
compactionsTriggered prometheus.Counter
|
2018-11-20 02:34:26 -08:00
|
|
|
compactionsSkipped prometheus.Counter
|
2020-01-13 14:15:45 -08:00
|
|
|
sizeRetentionCount prometheus.Counter
|
|
|
|
timeRetentionCount prometheus.Counter
|
2018-09-14 05:07:45 -07:00
|
|
|
startTime prometheus.GaugeFunc
|
2017-11-22 04:34:50 -08:00
|
|
|
tombCleanTimer prometheus.Histogram
|
2019-01-16 02:03:52 -08:00
|
|
|
blocksBytes prometheus.Gauge
|
2019-07-27 01:52:25 -07:00
|
|
|
maxBytes prometheus.Gauge
|
2016-12-31 00:48:49 -08:00
|
|
|
}
|
|
|
|
|
2020-02-14 10:48:55 -08:00
|
|
|
func newDBMetrics(db *DB, r prometheus.Registerer) *dbMetrics {
|
2017-01-06 02:40:09 -08:00
|
|
|
m := &dbMetrics{}
|
2017-01-03 06:43:26 -08:00
|
|
|
|
2017-05-26 06:13:03 -07:00
|
|
|
m.loadedBlocks = prometheus.NewGaugeFunc(prometheus.GaugeOpts{
|
2018-09-18 10:17:41 -07:00
|
|
|
Name: "prometheus_tsdb_blocks_loaded",
|
2017-05-26 06:13:03 -07:00
|
|
|
Help: "Number of currently loaded data blocks",
|
|
|
|
}, func() float64 {
|
|
|
|
db.mtx.RLock()
|
|
|
|
defer db.mtx.RUnlock()
|
|
|
|
return float64(len(db.blocks))
|
|
|
|
})
|
2018-09-08 11:28:36 -07:00
|
|
|
m.symbolTableSize = prometheus.NewGaugeFunc(prometheus.GaugeOpts{
|
2018-09-18 10:17:41 -07:00
|
|
|
Name: "prometheus_tsdb_symbol_table_size_bytes",
|
2018-09-08 11:28:36 -07:00
|
|
|
Help: "Size of symbol table on disk (in bytes)",
|
|
|
|
}, func() float64 {
|
|
|
|
db.mtx.RLock()
|
|
|
|
blocks := db.blocks[:]
|
|
|
|
db.mtx.RUnlock()
|
2018-09-12 02:09:02 -07:00
|
|
|
symTblSize := uint64(0)
|
2018-09-08 11:28:36 -07:00
|
|
|
for _, b := range blocks {
|
2018-09-12 02:09:02 -07:00
|
|
|
symTblSize += b.GetSymbolTableSize()
|
2018-09-08 11:28:36 -07:00
|
|
|
}
|
2018-09-12 02:09:02 -07:00
|
|
|
return float64(symTblSize)
|
2018-09-08 11:28:36 -07:00
|
|
|
})
|
2017-05-26 06:13:03 -07:00
|
|
|
m.reloads = prometheus.NewCounter(prometheus.CounterOpts{
|
2018-09-18 10:17:41 -07:00
|
|
|
Name: "prometheus_tsdb_reloads_total",
|
2017-05-26 06:13:03 -07:00
|
|
|
Help: "Number of times the database reloaded block data from disk.",
|
|
|
|
})
|
|
|
|
m.reloadsFailed = prometheus.NewCounter(prometheus.CounterOpts{
|
2018-09-18 10:17:41 -07:00
|
|
|
Name: "prometheus_tsdb_reloads_failures_total",
|
2017-11-09 05:25:27 -08:00
|
|
|
Help: "Number of times the database failed to reload block data from disk.",
|
2017-05-26 06:13:03 -07:00
|
|
|
})
|
2017-01-06 03:37:28 -08:00
|
|
|
m.compactionsTriggered = prometheus.NewCounter(prometheus.CounterOpts{
|
2018-09-18 10:17:41 -07:00
|
|
|
Name: "prometheus_tsdb_compactions_triggered_total",
|
2017-01-06 03:37:28 -08:00
|
|
|
Help: "Total number of triggered compactions for the partition.",
|
|
|
|
})
|
2019-05-30 04:57:28 -07:00
|
|
|
m.compactionsFailed = prometheus.NewCounter(prometheus.CounterOpts{
|
|
|
|
Name: "prometheus_tsdb_compactions_failed_total",
|
|
|
|
Help: "Total number of compactions that failed for the partition.",
|
|
|
|
})
|
2019-01-16 02:03:52 -08:00
|
|
|
m.timeRetentionCount = prometheus.NewCounter(prometheus.CounterOpts{
|
|
|
|
Name: "prometheus_tsdb_time_retentions_total",
|
|
|
|
Help: "The number of times that blocks were deleted because the maximum time limit was exceeded.",
|
|
|
|
})
|
2018-11-20 02:34:26 -08:00
|
|
|
m.compactionsSkipped = prometheus.NewCounter(prometheus.CounterOpts{
|
|
|
|
Name: "prometheus_tsdb_compactions_skipped_total",
|
|
|
|
Help: "Total number of skipped compactions due to disabled auto compaction.",
|
|
|
|
})
|
2018-09-14 05:07:45 -07:00
|
|
|
m.startTime = prometheus.NewGaugeFunc(prometheus.GaugeOpts{
|
2018-09-18 10:17:41 -07:00
|
|
|
Name: "prometheus_tsdb_lowest_timestamp",
|
2018-11-30 10:18:12 -08:00
|
|
|
Help: "Lowest timestamp value stored in the database. The unit is decided by the library consumer.",
|
2018-09-14 05:07:45 -07:00
|
|
|
}, func() float64 {
|
|
|
|
db.mtx.RLock()
|
|
|
|
defer db.mtx.RUnlock()
|
|
|
|
if len(db.blocks) == 0 {
|
2019-10-09 08:41:46 -07:00
|
|
|
return float64(db.head.MinTime())
|
2018-09-14 05:07:45 -07:00
|
|
|
}
|
|
|
|
return float64(db.blocks[0].meta.MinTime)
|
|
|
|
})
|
2017-11-22 04:34:50 -08:00
|
|
|
m.tombCleanTimer = prometheus.NewHistogram(prometheus.HistogramOpts{
|
2018-09-18 10:17:41 -07:00
|
|
|
Name: "prometheus_tsdb_tombstone_cleanup_seconds",
|
2017-11-22 04:34:50 -08:00
|
|
|
Help: "The time taken to recompact blocks to remove tombstones.",
|
|
|
|
})
|
2019-01-16 02:03:52 -08:00
|
|
|
m.blocksBytes = prometheus.NewGauge(prometheus.GaugeOpts{
|
2019-01-23 05:46:58 -08:00
|
|
|
Name: "prometheus_tsdb_storage_blocks_bytes",
|
2019-01-16 02:03:52 -08:00
|
|
|
Help: "The number of bytes that are currently used for local storage by all blocks.",
|
|
|
|
})
|
2019-07-27 01:52:25 -07:00
|
|
|
m.maxBytes = prometheus.NewGauge(prometheus.GaugeOpts{
|
|
|
|
Name: "prometheus_tsdb_retention_limit_bytes",
|
|
|
|
Help: "Max number of bytes to be retained in the tsdb blocks, configured 0 means disabled",
|
|
|
|
})
|
2019-01-16 02:03:52 -08:00
|
|
|
m.sizeRetentionCount = prometheus.NewCounter(prometheus.CounterOpts{
|
|
|
|
Name: "prometheus_tsdb_size_retentions_total",
|
|
|
|
Help: "The number of times that blocks were deleted because the maximum number of bytes was exceeded.",
|
|
|
|
})
|
2020-02-11 08:34:09 -08:00
|
|
|
|
2016-12-31 00:48:49 -08:00
|
|
|
if r != nil {
|
|
|
|
r.MustRegister(
|
2017-05-26 06:13:03 -07:00
|
|
|
m.loadedBlocks,
|
2018-09-08 11:28:36 -07:00
|
|
|
m.symbolTableSize,
|
2017-05-26 06:13:03 -07:00
|
|
|
m.reloads,
|
|
|
|
m.reloadsFailed,
|
2019-05-30 04:57:28 -07:00
|
|
|
m.compactionsFailed,
|
2020-01-13 14:15:45 -08:00
|
|
|
m.compactionsTriggered,
|
|
|
|
m.compactionsSkipped,
|
|
|
|
m.sizeRetentionCount,
|
|
|
|
m.timeRetentionCount,
|
2018-09-14 05:07:45 -07:00
|
|
|
m.startTime,
|
2017-11-22 04:34:50 -08:00
|
|
|
m.tombCleanTimer,
|
2019-01-16 02:03:52 -08:00
|
|
|
m.blocksBytes,
|
2019-07-27 01:52:25 -07:00
|
|
|
m.maxBytes,
|
2016-12-31 00:48:49 -08:00
|
|
|
)
|
|
|
|
}
|
|
|
|
return m
|
|
|
|
}
|
|
|
|
|
2019-07-23 01:04:48 -07:00
|
|
|
// ErrClosed is returned when the db is closed.
|
|
|
|
var ErrClosed = errors.New("db already closed")
|
|
|
|
|
|
|
|
// DBReadOnly provides APIs for read only operations on a database.
|
2019-09-30 08:54:55 -07:00
|
|
|
// Current implementation doesn't support concurrency so
|
2019-07-23 01:04:48 -07:00
|
|
|
// all API calls should happen in the same go routine.
|
|
|
|
type DBReadOnly struct {
|
|
|
|
logger log.Logger
|
|
|
|
dir string
|
|
|
|
closers []io.Closer
|
|
|
|
closed chan struct{}
|
|
|
|
}
|
|
|
|
|
|
|
|
// OpenDBReadOnly opens DB in the given directory for read only operations.
|
|
|
|
func OpenDBReadOnly(dir string, l log.Logger) (*DBReadOnly, error) {
|
|
|
|
if _, err := os.Stat(dir); err != nil {
|
2019-09-30 08:54:55 -07:00
|
|
|
return nil, errors.Wrap(err, "opening the db dir")
|
2019-07-23 01:04:48 -07:00
|
|
|
}
|
|
|
|
|
|
|
|
if l == nil {
|
|
|
|
l = log.NewNopLogger()
|
|
|
|
}
|
|
|
|
|
|
|
|
return &DBReadOnly{
|
|
|
|
logger: l,
|
|
|
|
dir: dir,
|
|
|
|
closed: make(chan struct{}),
|
|
|
|
}, nil
|
|
|
|
}
|
|
|
|
|
2019-09-13 03:25:21 -07:00
|
|
|
// FlushWAL creates a new block containing all data that's currently in the memory buffer/WAL.
|
|
|
|
// Samples that are in existing blocks will not be written to the new block.
|
|
|
|
// Note that if the read only database is running concurrently with a
|
|
|
|
// writable database then writing the WAL to the database directory can race.
|
|
|
|
func (db *DBReadOnly) FlushWAL(dir string) error {
|
|
|
|
blockReaders, err := db.Blocks()
|
|
|
|
if err != nil {
|
|
|
|
return errors.Wrap(err, "read blocks")
|
|
|
|
}
|
|
|
|
maxBlockTime := int64(math.MinInt64)
|
|
|
|
if len(blockReaders) > 0 {
|
|
|
|
maxBlockTime = blockReaders[len(blockReaders)-1].Meta().MaxTime
|
|
|
|
}
|
2020-03-09 22:31:47 -07:00
|
|
|
w, err := wal.Open(db.logger, filepath.Join(db.dir, "wal"))
|
2019-09-13 03:25:21 -07:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
2020-01-29 23:12:43 -08:00
|
|
|
head, err := NewHead(nil, db.logger, w, 1, DefaultStripeSize)
|
2019-09-13 03:25:21 -07:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
// Set the min valid time for the ingested wal samples
|
|
|
|
// to be no lower than the maxt of the last block.
|
|
|
|
if err := head.Init(maxBlockTime); err != nil {
|
|
|
|
return errors.Wrap(err, "read WAL")
|
|
|
|
}
|
|
|
|
mint := head.MinTime()
|
|
|
|
maxt := head.MaxTime()
|
2020-02-14 01:50:24 -08:00
|
|
|
rh := &RangeHead{
|
2019-09-13 03:25:21 -07:00
|
|
|
head: head,
|
|
|
|
mint: mint,
|
|
|
|
maxt: maxt,
|
|
|
|
}
|
2020-02-06 07:58:38 -08:00
|
|
|
compactor, err := NewLeveledCompactor(
|
|
|
|
context.Background(),
|
|
|
|
nil,
|
|
|
|
db.logger,
|
2020-02-11 08:34:09 -08:00
|
|
|
ExponentialBlockRanges(DefaultOptions().MinBlockDuration, 3, 5),
|
2020-02-07 08:24:17 -08:00
|
|
|
chunkenc.NewPool(),
|
2020-02-06 07:58:38 -08:00
|
|
|
)
|
2019-09-13 03:25:21 -07:00
|
|
|
if err != nil {
|
|
|
|
return errors.Wrap(err, "create leveled compactor")
|
|
|
|
}
|
|
|
|
// Add +1 millisecond to block maxt because block intervals are half-open: [b.MinTime, b.MaxTime).
|
|
|
|
// Because of this block intervals are always +1 than the total samples it includes.
|
|
|
|
_, err = compactor.Write(dir, rh, mint, maxt+1, nil)
|
|
|
|
return errors.Wrap(err, "writing WAL")
|
|
|
|
}
|
|
|
|
|
2019-07-23 01:04:48 -07:00
|
|
|
// Querier loads the wal and returns a new querier over the data partition for the given time range.
|
|
|
|
// Current implementation doesn't support multiple Queriers.
|
2020-02-07 08:24:17 -08:00
|
|
|
func (db *DBReadOnly) Querier(ctx context.Context, mint, maxt int64) (storage.Querier, error) {
|
2019-07-23 01:04:48 -07:00
|
|
|
select {
|
|
|
|
case <-db.closed:
|
|
|
|
return nil, ErrClosed
|
|
|
|
default:
|
|
|
|
}
|
2019-09-13 03:25:21 -07:00
|
|
|
blockReaders, err := db.Blocks()
|
2019-07-23 01:04:48 -07:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2019-09-13 03:25:21 -07:00
|
|
|
blocks := make([]*Block, len(blockReaders))
|
|
|
|
for i, b := range blockReaders {
|
2019-07-23 01:04:48 -07:00
|
|
|
b, ok := b.(*Block)
|
|
|
|
if !ok {
|
|
|
|
return nil, errors.New("unable to convert a read only block to a normal block")
|
|
|
|
}
|
|
|
|
blocks[i] = b
|
|
|
|
}
|
|
|
|
|
2020-01-29 23:12:43 -08:00
|
|
|
head, err := NewHead(nil, db.logger, nil, 1, DefaultStripeSize)
|
2019-07-23 01:04:48 -07:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
maxBlockTime := int64(math.MinInt64)
|
|
|
|
if len(blocks) > 0 {
|
|
|
|
maxBlockTime = blocks[len(blocks)-1].Meta().MaxTime
|
|
|
|
}
|
|
|
|
|
2019-09-30 08:54:55 -07:00
|
|
|
// Also add the WAL if the current blocks don't cover the requests time range.
|
2019-07-23 01:04:48 -07:00
|
|
|
if maxBlockTime <= maxt {
|
2020-03-09 22:31:47 -07:00
|
|
|
w, err := wal.Open(db.logger, filepath.Join(db.dir, "wal"))
|
2019-07-23 01:04:48 -07:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2020-01-29 23:12:43 -08:00
|
|
|
head, err = NewHead(nil, db.logger, w, 1, DefaultStripeSize)
|
2019-07-23 01:04:48 -07:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
// Set the min valid time for the ingested wal samples
|
|
|
|
// to be no lower than the maxt of the last block.
|
|
|
|
if err := head.Init(maxBlockTime); err != nil {
|
|
|
|
return nil, errors.Wrap(err, "read WAL")
|
|
|
|
}
|
|
|
|
// Set the wal to nil to disable all wal operations.
|
|
|
|
// This is mainly to avoid blocking when closing the head.
|
|
|
|
head.wal = nil
|
|
|
|
|
|
|
|
db.closers = append(db.closers, head)
|
|
|
|
}
|
|
|
|
|
|
|
|
// TODO: Refactor so that it is possible to obtain a Querier without initializing a writable DB instance.
|
|
|
|
// Option 1: refactor DB to have the Querier implementation using the DBReadOnly.Querier implementation not the opposite.
|
|
|
|
// Option 2: refactor Querier to use another independent func which
|
|
|
|
// can than be used by a read only and writable db instances without any code duplication.
|
|
|
|
dbWritable := &DB{
|
|
|
|
dir: db.dir,
|
|
|
|
logger: db.logger,
|
|
|
|
blocks: blocks,
|
|
|
|
head: head,
|
|
|
|
}
|
|
|
|
|
2020-02-07 08:24:17 -08:00
|
|
|
return dbWritable.Querier(ctx, mint, maxt)
|
2019-07-23 01:04:48 -07:00
|
|
|
}
|
|
|
|
|
|
|
|
// Blocks returns a slice of block readers for persisted blocks.
|
|
|
|
func (db *DBReadOnly) Blocks() ([]BlockReader, error) {
|
|
|
|
select {
|
|
|
|
case <-db.closed:
|
|
|
|
return nil, ErrClosed
|
|
|
|
default:
|
|
|
|
}
|
|
|
|
loadable, corrupted, err := openBlocks(db.logger, db.dir, nil, nil)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Corrupted blocks that have been superseded by a loadable block can be safely ignored.
|
|
|
|
for _, block := range loadable {
|
|
|
|
for _, b := range block.Meta().Compaction.Parents {
|
|
|
|
delete(corrupted, b.ULID)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
if len(corrupted) > 0 {
|
|
|
|
for _, b := range loadable {
|
|
|
|
if err := b.Close(); err != nil {
|
|
|
|
level.Warn(db.logger).Log("msg", "closing a block", err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return nil, errors.Errorf("unexpected corrupted block:%v", corrupted)
|
|
|
|
}
|
|
|
|
|
|
|
|
if len(loadable) == 0 {
|
2019-09-13 03:25:21 -07:00
|
|
|
return nil, nil
|
2019-07-23 01:04:48 -07:00
|
|
|
}
|
|
|
|
|
|
|
|
sort.Slice(loadable, func(i, j int) bool {
|
|
|
|
return loadable[i].Meta().MinTime < loadable[j].Meta().MinTime
|
|
|
|
})
|
|
|
|
|
|
|
|
blockMetas := make([]BlockMeta, 0, len(loadable))
|
|
|
|
for _, b := range loadable {
|
|
|
|
blockMetas = append(blockMetas, b.Meta())
|
|
|
|
}
|
|
|
|
if overlaps := OverlappingBlocks(blockMetas); len(overlaps) > 0 {
|
|
|
|
level.Warn(db.logger).Log("msg", "overlapping blocks found during opening", "detail", overlaps.String())
|
|
|
|
}
|
|
|
|
|
|
|
|
// Close all previously open readers and add the new ones to the cache.
|
|
|
|
for _, closer := range db.closers {
|
|
|
|
closer.Close()
|
|
|
|
}
|
|
|
|
|
|
|
|
blockClosers := make([]io.Closer, len(loadable))
|
|
|
|
blockReaders := make([]BlockReader, len(loadable))
|
|
|
|
for i, b := range loadable {
|
|
|
|
blockClosers[i] = b
|
|
|
|
blockReaders[i] = b
|
|
|
|
}
|
|
|
|
db.closers = blockClosers
|
|
|
|
|
|
|
|
return blockReaders, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// Close all block readers.
|
|
|
|
func (db *DBReadOnly) Close() error {
|
|
|
|
select {
|
|
|
|
case <-db.closed:
|
|
|
|
return ErrClosed
|
|
|
|
default:
|
|
|
|
}
|
|
|
|
close(db.closed)
|
|
|
|
|
|
|
|
var merr tsdb_errors.MultiError
|
|
|
|
|
|
|
|
for _, b := range db.closers {
|
|
|
|
merr.Add(b.Close())
|
|
|
|
}
|
|
|
|
return merr.Err()
|
|
|
|
}
|
|
|
|
|
2020-02-07 08:24:17 -08:00
|
|
|
// Open returns a new DB in the given directory. If options are empty, DefaultOptions will be used.
|
2017-02-27 22:17:01 -08:00
|
|
|
func Open(dir string, l log.Logger, r prometheus.Registerer, opts *Options) (db *DB, err error) {
|
2020-02-06 07:58:38 -08:00
|
|
|
var rngs []int64
|
|
|
|
opts, rngs = validateOpts(opts, nil)
|
|
|
|
return open(dir, l, r, opts, rngs)
|
|
|
|
}
|
|
|
|
|
|
|
|
func validateOpts(opts *Options, rngs []int64) (*Options, []int64) {
|
|
|
|
if opts == nil {
|
|
|
|
opts = DefaultOptions()
|
|
|
|
}
|
|
|
|
if opts.StripeSize <= 0 {
|
|
|
|
opts.StripeSize = DefaultStripeSize
|
|
|
|
}
|
|
|
|
|
|
|
|
if opts.MinBlockDuration <= 0 {
|
2020-02-11 08:34:09 -08:00
|
|
|
opts.MinBlockDuration = DefaultBlockDuration
|
2020-02-06 07:58:38 -08:00
|
|
|
}
|
|
|
|
if opts.MinBlockDuration > opts.MaxBlockDuration {
|
|
|
|
opts.MaxBlockDuration = opts.MinBlockDuration
|
|
|
|
}
|
|
|
|
|
|
|
|
if len(rngs) == 0 {
|
|
|
|
// Start with smallest block duration and create exponential buckets until the exceed the
|
|
|
|
// configured maximum block duration.
|
2020-02-11 08:34:09 -08:00
|
|
|
rngs = ExponentialBlockRanges(opts.MinBlockDuration, 10, 3)
|
2020-02-06 07:58:38 -08:00
|
|
|
}
|
|
|
|
return opts, rngs
|
|
|
|
}
|
|
|
|
|
|
|
|
func open(dir string, l log.Logger, r prometheus.Registerer, opts *Options, rngs []int64) (db *DB, err error) {
|
2017-02-19 04:01:19 -08:00
|
|
|
if err := os.MkdirAll(dir, 0777); err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2017-02-19 07:04:37 -08:00
|
|
|
if l == nil {
|
2017-09-13 01:17:20 -07:00
|
|
|
l = log.NewNopLogger()
|
2017-02-19 07:04:37 -08:00
|
|
|
}
|
2020-02-06 07:58:38 -08:00
|
|
|
|
|
|
|
for i, v := range rngs {
|
2020-02-11 08:34:09 -08:00
|
|
|
if v > opts.MaxBlockDuration {
|
2020-02-06 07:58:38 -08:00
|
|
|
rngs = rngs[:i]
|
|
|
|
break
|
|
|
|
}
|
2020-01-29 23:12:43 -08:00
|
|
|
}
|
2020-02-06 07:58:38 -08:00
|
|
|
|
2018-02-12 02:40:12 -08:00
|
|
|
// Fixup bad format written by Prometheus 2.1.
|
2018-02-09 04:37:10 -08:00
|
|
|
if err := repairBadIndexVersion(l, dir); err != nil {
|
2018-02-09 04:11:03 -08:00
|
|
|
return nil, err
|
|
|
|
}
|
2018-09-17 09:30:56 -07:00
|
|
|
// Migrate old WAL if one exists.
|
2018-05-27 10:05:11 -07:00
|
|
|
if err := MigrateWAL(l, filepath.Join(dir, "wal")); err != nil {
|
|
|
|
return nil, errors.Wrap(err, "migrate WAL")
|
|
|
|
}
|
2017-01-17 21:18:32 -08:00
|
|
|
|
2017-01-06 03:37:28 -08:00
|
|
|
db = &DB{
|
2018-11-20 02:34:26 -08:00
|
|
|
dir: dir,
|
|
|
|
logger: l,
|
|
|
|
opts: opts,
|
|
|
|
compactc: make(chan struct{}, 1),
|
|
|
|
donec: make(chan struct{}),
|
|
|
|
stopc: make(chan struct{}),
|
|
|
|
autoCompact: true,
|
|
|
|
chunkPool: chunkenc.NewPool(),
|
2017-01-06 00:26:39 -08:00
|
|
|
}
|
2020-02-14 10:48:55 -08:00
|
|
|
db.metrics = newDBMetrics(db, r)
|
2017-05-26 06:13:03 -07:00
|
|
|
|
2019-07-27 01:52:25 -07:00
|
|
|
maxBytes := opts.MaxBytes
|
|
|
|
if maxBytes < 0 {
|
|
|
|
maxBytes = 0
|
|
|
|
}
|
|
|
|
db.metrics.maxBytes.Set(float64(maxBytes))
|
|
|
|
|
2017-05-09 03:52:47 -07:00
|
|
|
if !opts.NoLockfile {
|
2017-05-18 07:09:30 -07:00
|
|
|
absdir, err := filepath.Abs(dir)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2018-05-29 11:35:48 -07:00
|
|
|
lockf, _, err := fileutil.Flock(filepath.Join(absdir, "lock"))
|
2017-05-09 03:52:47 -07:00
|
|
|
if err != nil {
|
2018-05-29 11:35:48 -07:00
|
|
|
return nil, errors.Wrap(err, "lock DB directory")
|
2017-05-09 03:52:47 -07:00
|
|
|
}
|
2018-05-29 11:35:48 -07:00
|
|
|
db.lockf = lockf
|
2017-05-09 03:52:47 -07:00
|
|
|
}
|
|
|
|
|
2019-02-06 04:07:35 -08:00
|
|
|
ctx, cancel := context.WithCancel(context.Background())
|
2020-02-06 07:58:38 -08:00
|
|
|
db.compactor, err = NewLeveledCompactor(ctx, r, l, rngs, db.chunkPool)
|
2017-09-01 02:46:46 -07:00
|
|
|
if err != nil {
|
2019-02-06 04:07:35 -08:00
|
|
|
cancel()
|
2017-09-01 02:46:46 -07:00
|
|
|
return nil, errors.Wrap(err, "create leveled compactor")
|
2017-07-07 04:46:41 -07:00
|
|
|
}
|
2019-02-06 04:07:35 -08:00
|
|
|
db.compactCancel = cancel
|
2017-07-07 04:46:41 -07:00
|
|
|
|
2019-03-25 16:38:12 -07:00
|
|
|
var wlog *wal.WAL
|
2018-12-18 10:56:51 -08:00
|
|
|
segmentSize := wal.DefaultSegmentSize
|
2019-03-25 16:38:12 -07:00
|
|
|
// Wal is enabled.
|
|
|
|
if opts.WALSegmentSize >= 0 {
|
|
|
|
// Wal is set to a custom size.
|
|
|
|
if opts.WALSegmentSize > 0 {
|
2020-02-11 08:34:09 -08:00
|
|
|
segmentSize = opts.WALSegmentSize
|
2019-03-25 16:38:12 -07:00
|
|
|
}
|
2019-06-19 06:46:24 -07:00
|
|
|
wlog, err = wal.NewSize(l, r, filepath.Join(dir, "wal"), segmentSize, opts.WALCompression)
|
2019-03-25 16:38:12 -07:00
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2017-08-28 15:39:17 -07:00
|
|
|
}
|
2019-03-25 16:38:12 -07:00
|
|
|
|
2020-02-06 07:58:38 -08:00
|
|
|
db.head, err = NewHead(r, l, wlog, rngs[0], opts.StripeSize)
|
2017-08-30 09:34:54 -07:00
|
|
|
if err != nil {
|
2017-08-30 08:38:25 -07:00
|
|
|
return nil, err
|
|
|
|
}
|
2018-12-04 02:30:49 -08:00
|
|
|
|
2018-11-28 01:23:50 -08:00
|
|
|
if err := db.reload(); err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
2018-12-04 02:30:49 -08:00
|
|
|
// Set the min valid time for the ingested samples
|
|
|
|
// to be no lower than the maxt of the last block.
|
|
|
|
blocks := db.Blocks()
|
|
|
|
minValidTime := int64(math.MinInt64)
|
|
|
|
if len(blocks) > 0 {
|
|
|
|
minValidTime = blocks[len(blocks)-1].Meta().MaxTime
|
|
|
|
}
|
|
|
|
|
2019-06-14 08:39:22 -07:00
|
|
|
if initErr := db.head.Init(minValidTime); initErr != nil {
|
|
|
|
db.head.metrics.walCorruptionsTotal.Inc()
|
2020-01-13 14:15:45 -08:00
|
|
|
level.Warn(db.logger).Log("msg", "encountered WAL read error, attempting repair", "err", initErr)
|
2019-06-14 08:39:22 -07:00
|
|
|
if err := wlog.Repair(initErr); err != nil {
|
|
|
|
return nil, errors.Wrap(err, "repair corrupted WAL")
|
|
|
|
}
|
2018-12-04 02:30:49 -08:00
|
|
|
}
|
2017-08-28 15:39:17 -07:00
|
|
|
|
2017-01-06 03:37:28 -08:00
|
|
|
go db.run()
|
|
|
|
|
|
|
|
return db, nil
|
|
|
|
}
|
|
|
|
|
2020-02-06 07:58:38 -08:00
|
|
|
// StartTime implements the Storage interface.
|
|
|
|
func (db *DB) StartTime() (int64, error) {
|
|
|
|
db.mtx.RLock()
|
|
|
|
defer db.mtx.RUnlock()
|
|
|
|
|
|
|
|
if len(db.blocks) > 0 {
|
|
|
|
return db.blocks[0].Meta().MinTime, nil
|
|
|
|
}
|
|
|
|
return db.head.MinTime(), nil
|
|
|
|
}
|
|
|
|
|
2017-06-08 03:14:13 -07:00
|
|
|
// Dir returns the directory of the database.
|
|
|
|
func (db *DB) Dir() string {
|
|
|
|
return db.dir
|
|
|
|
}
|
|
|
|
|
2017-01-06 03:37:28 -08:00
|
|
|
func (db *DB) run() {
|
|
|
|
defer close(db.donec)
|
|
|
|
|
2017-08-28 15:39:17 -07:00
|
|
|
backoff := time.Duration(0)
|
2017-02-28 06:08:52 -08:00
|
|
|
|
2017-01-19 22:58:19 -08:00
|
|
|
for {
|
|
|
|
select {
|
2017-08-28 15:39:17 -07:00
|
|
|
case <-db.stopc:
|
2017-08-30 09:34:54 -07:00
|
|
|
return
|
2017-08-28 15:39:17 -07:00
|
|
|
case <-time.After(backoff):
|
|
|
|
}
|
|
|
|
|
|
|
|
select {
|
|
|
|
case <-time.After(1 * time.Minute):
|
2017-02-28 06:08:52 -08:00
|
|
|
select {
|
|
|
|
case db.compactc <- struct{}{}:
|
|
|
|
default:
|
|
|
|
}
|
2017-01-06 03:37:28 -08:00
|
|
|
case <-db.compactc:
|
|
|
|
db.metrics.compactionsTriggered.Inc()
|
|
|
|
|
2018-11-20 02:34:26 -08:00
|
|
|
db.autoCompactMtx.Lock()
|
|
|
|
if db.autoCompact {
|
2020-01-19 23:29:49 -08:00
|
|
|
if err := db.Compact(); err != nil {
|
2018-11-20 02:34:26 -08:00
|
|
|
level.Error(db.logger).Log("msg", "compaction failed", "err", err)
|
|
|
|
backoff = exponential(backoff, 1*time.Second, 1*time.Minute)
|
|
|
|
} else {
|
|
|
|
backoff = 0
|
|
|
|
}
|
2017-08-30 09:34:54 -07:00
|
|
|
} else {
|
2018-11-20 02:34:26 -08:00
|
|
|
db.metrics.compactionsSkipped.Inc()
|
2017-01-06 03:37:28 -08:00
|
|
|
}
|
2018-11-20 02:34:26 -08:00
|
|
|
db.autoCompactMtx.Unlock()
|
2017-01-06 03:37:28 -08:00
|
|
|
case <-db.stopc:
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2017-08-30 09:34:54 -07:00
|
|
|
// Appender opens a new appender against the database.
|
2020-02-06 07:58:38 -08:00
|
|
|
func (db *DB) Appender() storage.Appender {
|
2017-08-30 09:34:54 -07:00
|
|
|
return dbAppender{db: db, Appender: db.head.Appender()}
|
|
|
|
}
|
|
|
|
|
|
|
|
// dbAppender wraps the DB's head appender and triggers compactions on commit
|
|
|
|
// if necessary.
|
|
|
|
type dbAppender struct {
|
2020-02-06 07:58:38 -08:00
|
|
|
storage.Appender
|
2017-08-30 09:34:54 -07:00
|
|
|
db *DB
|
|
|
|
}
|
|
|
|
|
|
|
|
func (a dbAppender) Commit() error {
|
|
|
|
err := a.Appender.Commit()
|
|
|
|
|
2017-09-04 06:07:30 -07:00
|
|
|
// We could just run this check every few minutes practically. But for benchmarks
|
|
|
|
// and high frequency use cases this is the safer way.
|
2019-04-01 01:19:06 -07:00
|
|
|
if a.db.head.compactable() {
|
2017-08-30 09:34:54 -07:00
|
|
|
select {
|
|
|
|
case a.db.compactc <- struct{}{}:
|
|
|
|
default:
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
2018-06-27 09:05:21 -07:00
|
|
|
// Compact data if possible. After successful compaction blocks are reloaded
|
|
|
|
// which will also trigger blocks to be deleted that fall out of the retention
|
|
|
|
// window.
|
|
|
|
// If no blocks are compacted, the retention window state doesn't change. Thus,
|
|
|
|
// this is sufficient to reliably delete old data.
|
|
|
|
// Old blocks are only deleted on reload based on the new block's parent information.
|
|
|
|
// See DB.reload documentation for further information.
|
2020-01-19 23:29:49 -08:00
|
|
|
func (db *DB) Compact() (err error) {
|
2017-07-13 07:15:13 -07:00
|
|
|
db.cmtx.Lock()
|
|
|
|
defer db.cmtx.Unlock()
|
2019-05-30 04:57:28 -07:00
|
|
|
defer func() {
|
|
|
|
if err != nil {
|
|
|
|
db.metrics.compactionsFailed.Inc()
|
|
|
|
}
|
|
|
|
}()
|
2017-07-13 07:15:13 -07:00
|
|
|
// Check whether we have pending head blocks that are ready to be persisted.
|
|
|
|
// They have the highest priority.
|
2017-08-28 15:39:17 -07:00
|
|
|
for {
|
2017-03-04 07:50:48 -08:00
|
|
|
select {
|
|
|
|
case <-db.stopc:
|
2018-09-20 23:24:01 -07:00
|
|
|
return nil
|
2017-03-04 07:50:48 -08:00
|
|
|
default:
|
2017-02-02 00:32:06 -08:00
|
|
|
}
|
2019-04-01 01:19:06 -07:00
|
|
|
if !db.head.compactable() {
|
2017-08-28 15:39:17 -07:00
|
|
|
break
|
|
|
|
}
|
2018-12-04 02:30:49 -08:00
|
|
|
mint := db.head.MinTime()
|
2019-04-01 01:19:06 -07:00
|
|
|
maxt := rangeForTimestamp(mint, db.head.chunkRange)
|
2017-02-02 00:32:06 -08:00
|
|
|
|
2017-08-28 15:39:17 -07:00
|
|
|
// Wrap head into a range that bounds all reads to it.
|
2020-02-14 01:50:24 -08:00
|
|
|
// We remove 1 millisecond from maxt because block
|
|
|
|
// intervals are half-open: [b.MinTime, b.MaxTime). But
|
|
|
|
// chunk intervals are closed: [c.MinTime, c.MaxTime];
|
|
|
|
// so in order to make sure that overlaps are evaluated
|
|
|
|
// consistently, we explicitly remove the last value
|
|
|
|
// from the block interval here.
|
|
|
|
head := NewRangeHead(db.head, mint, maxt-1)
|
|
|
|
if err := db.compactHead(head, mint, maxt); err != nil {
|
|
|
|
return err
|
2017-03-04 07:50:48 -08:00
|
|
|
}
|
2020-02-14 01:50:24 -08:00
|
|
|
}
|
2017-08-09 02:10:29 -07:00
|
|
|
|
2020-02-14 01:50:24 -08:00
|
|
|
return db.compactBlocks()
|
|
|
|
}
|
2017-09-08 06:09:24 -07:00
|
|
|
|
2020-02-14 01:50:24 -08:00
|
|
|
// CompactHead compacts the given the RangeHead.
|
|
|
|
func (db *DB) CompactHead(head *RangeHead, mint, maxt int64) (err error) {
|
|
|
|
db.cmtx.Lock()
|
|
|
|
defer db.cmtx.Unlock()
|
|
|
|
|
|
|
|
return db.compactHead(head, mint, maxt)
|
|
|
|
}
|
|
|
|
|
|
|
|
// compactHead compacts the given the RangeHead.
|
|
|
|
// The compaction mutex should be held before calling this method.
|
|
|
|
func (db *DB) compactHead(head *RangeHead, mint, maxt int64) (err error) {
|
|
|
|
uid, err := db.compactor.Write(db.dir, head, mint, maxt, nil)
|
|
|
|
if err != nil {
|
|
|
|
return errors.Wrap(err, "persist head block")
|
|
|
|
}
|
|
|
|
|
|
|
|
runtime.GC()
|
|
|
|
|
|
|
|
if err := db.reload(); err != nil {
|
|
|
|
if err := os.RemoveAll(filepath.Join(db.dir, uid.String())); err != nil {
|
|
|
|
return errors.Wrapf(err, "delete persisted head block after failed db reload:%s", uid)
|
2017-08-09 02:10:29 -07:00
|
|
|
}
|
2020-02-14 01:50:24 -08:00
|
|
|
return errors.Wrap(err, "reload blocks")
|
|
|
|
}
|
|
|
|
if (uid == ulid.ULID{}) {
|
|
|
|
// Compaction resulted in an empty block.
|
|
|
|
// Head truncating during db.reload() depends on the persisted blocks and
|
|
|
|
// in this case no new block will be persisted so manually truncate the head.
|
|
|
|
if err = db.head.Truncate(maxt); err != nil {
|
|
|
|
return errors.Wrap(err, "head truncate failed (in compact)")
|
2019-01-18 00:35:16 -08:00
|
|
|
}
|
2017-03-04 07:50:48 -08:00
|
|
|
}
|
2020-02-14 01:50:24 -08:00
|
|
|
runtime.GC()
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
2017-01-06 03:37:28 -08:00
|
|
|
|
2020-02-14 01:50:24 -08:00
|
|
|
// compactBlocks compacts all the eligible on-disk blocks.
|
|
|
|
// The compaction mutex should be held before calling this method.
|
|
|
|
func (db *DB) compactBlocks() (err error) {
|
2017-03-02 00:13:29 -08:00
|
|
|
// Check for compactions of multiple blocks.
|
|
|
|
for {
|
2017-08-09 02:10:29 -07:00
|
|
|
plan, err := db.compactor.Plan(db.dir)
|
2017-03-02 00:13:29 -08:00
|
|
|
if err != nil {
|
2018-09-20 23:24:01 -07:00
|
|
|
return errors.Wrap(err, "plan compaction")
|
2017-03-02 00:13:29 -08:00
|
|
|
}
|
2017-08-09 02:10:29 -07:00
|
|
|
if len(plan) == 0 {
|
2017-03-21 04:21:02 -07:00
|
|
|
break
|
|
|
|
}
|
2017-01-06 03:37:28 -08:00
|
|
|
|
2017-03-02 00:13:29 -08:00
|
|
|
select {
|
|
|
|
case <-db.stopc:
|
2018-09-20 23:24:01 -07:00
|
|
|
return nil
|
2017-03-02 00:13:29 -08:00
|
|
|
default:
|
|
|
|
}
|
2017-03-20 02:41:43 -07:00
|
|
|
|
2019-01-29 00:26:01 -08:00
|
|
|
uid, err := db.compactor.Compact(db.dir, plan, db.blocks)
|
|
|
|
if err != nil {
|
2018-09-20 23:24:01 -07:00
|
|
|
return errors.Wrapf(err, "compact %s", plan)
|
2017-08-09 02:10:29 -07:00
|
|
|
}
|
2017-09-08 06:09:24 -07:00
|
|
|
runtime.GC()
|
2017-08-28 15:39:17 -07:00
|
|
|
|
2018-06-27 06:47:11 -07:00
|
|
|
if err := db.reload(); err != nil {
|
2019-01-29 00:26:01 -08:00
|
|
|
if err := os.RemoveAll(filepath.Join(db.dir, uid.String())); err != nil {
|
2019-01-30 01:40:55 -08:00
|
|
|
return errors.Wrapf(err, "delete compacted block after failed db reload:%s", uid)
|
2019-01-29 00:26:01 -08:00
|
|
|
}
|
2018-09-20 23:24:01 -07:00
|
|
|
return errors.Wrap(err, "reload blocks")
|
2017-08-28 15:39:17 -07:00
|
|
|
}
|
2017-09-08 06:09:24 -07:00
|
|
|
runtime.GC()
|
2017-02-23 01:50:22 -08:00
|
|
|
}
|
|
|
|
|
2018-09-20 23:24:01 -07:00
|
|
|
return nil
|
2017-02-09 17:54:26 -08:00
|
|
|
}
|
|
|
|
|
2019-07-23 01:04:48 -07:00
|
|
|
// getBlock iterates a given block range to find a block by a given id.
|
|
|
|
// If found it returns the block itself and a boolean to indicate that it was found.
|
|
|
|
func getBlock(allBlocks []*Block, id ulid.ULID) (*Block, bool) {
|
|
|
|
for _, b := range allBlocks {
|
2017-05-18 07:09:30 -07:00
|
|
|
if b.Meta().ULID == id {
|
2017-03-20 00:41:56 -07:00
|
|
|
return b, true
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return nil, false
|
|
|
|
}
|
|
|
|
|
2019-01-16 02:03:52 -08:00
|
|
|
// reload blocks and trigger head truncation if new blocks appeared.
|
2018-06-27 06:47:11 -07:00
|
|
|
// Blocks that are obsolete due to replacement or retention will be deleted.
|
|
|
|
func (db *DB) reload() (err error) {
|
2017-08-30 08:38:25 -07:00
|
|
|
defer func() {
|
2017-05-26 06:13:03 -07:00
|
|
|
if err != nil {
|
|
|
|
db.metrics.reloadsFailed.Inc()
|
|
|
|
}
|
|
|
|
db.metrics.reloads.Inc()
|
2017-08-30 08:38:25 -07:00
|
|
|
}()
|
2017-05-26 06:13:03 -07:00
|
|
|
|
2019-07-23 01:04:48 -07:00
|
|
|
loadable, corrupted, err := openBlocks(db.logger, db.dir, db.blocks, db.chunkPool)
|
2017-03-02 00:13:29 -08:00
|
|
|
if err != nil {
|
2019-01-16 02:03:52 -08:00
|
|
|
return err
|
|
|
|
}
|
2018-06-27 09:05:21 -07:00
|
|
|
|
2019-01-16 02:03:52 -08:00
|
|
|
deletable := db.deletableBlocks(loadable)
|
|
|
|
|
2019-07-23 01:04:48 -07:00
|
|
|
// Corrupted blocks that have been superseded by a loadable block can be safely ignored.
|
2019-01-16 02:03:52 -08:00
|
|
|
// This makes it resilient against the process crashing towards the end of a compaction.
|
|
|
|
// Creation of a new block and deletion of its parents cannot happen atomically.
|
|
|
|
// By creating blocks with their parents, we can pick up the deletion where it left off during a crash.
|
|
|
|
for _, block := range loadable {
|
|
|
|
for _, b := range block.Meta().Compaction.Parents {
|
|
|
|
delete(corrupted, b.ULID)
|
|
|
|
deletable[b.ULID] = nil
|
2017-02-09 17:54:26 -08:00
|
|
|
}
|
2019-01-16 02:03:52 -08:00
|
|
|
}
|
|
|
|
if len(corrupted) > 0 {
|
2019-01-30 01:40:40 -08:00
|
|
|
// Close all new blocks to release the lock for windows.
|
|
|
|
for _, block := range loadable {
|
2019-07-23 01:04:48 -07:00
|
|
|
if _, open := getBlock(db.blocks, block.Meta().ULID); !open {
|
2019-01-30 01:40:40 -08:00
|
|
|
block.Close()
|
|
|
|
}
|
|
|
|
}
|
2019-01-29 00:26:01 -08:00
|
|
|
return fmt.Errorf("unexpected corrupted block:%v", corrupted)
|
2019-01-16 02:03:52 -08:00
|
|
|
}
|
|
|
|
|
|
|
|
// All deletable blocks should not be loaded.
|
|
|
|
var (
|
|
|
|
bb []*Block
|
|
|
|
blocksSize int64
|
|
|
|
)
|
|
|
|
for _, block := range loadable {
|
|
|
|
if _, ok := deletable[block.Meta().ULID]; ok {
|
|
|
|
deletable[block.Meta().ULID] = block
|
2017-11-03 12:34:21 -07:00
|
|
|
continue
|
|
|
|
}
|
2019-01-16 02:03:52 -08:00
|
|
|
bb = append(bb, block)
|
|
|
|
blocksSize += block.Size()
|
|
|
|
|
|
|
|
}
|
|
|
|
loadable = bb
|
|
|
|
db.metrics.blocksBytes.Set(float64(blocksSize))
|
|
|
|
|
|
|
|
sort.Slice(loadable, func(i, j int) bool {
|
2019-02-14 05:29:41 -08:00
|
|
|
return loadable[i].Meta().MinTime < loadable[j].Meta().MinTime
|
2019-01-16 02:03:52 -08:00
|
|
|
})
|
2019-03-02 05:54:49 -08:00
|
|
|
if !db.opts.AllowOverlappingBlocks {
|
2019-02-26 11:50:37 -08:00
|
|
|
if err := validateBlockSequence(loadable); err != nil {
|
|
|
|
return errors.Wrap(err, "invalid block sequence")
|
|
|
|
}
|
|
|
|
}
|
2019-01-16 02:03:52 -08:00
|
|
|
|
|
|
|
// Swap new blocks first for subsequently created readers to be seen.
|
|
|
|
db.mtx.Lock()
|
|
|
|
oldBlocks := db.blocks
|
|
|
|
db.blocks = loadable
|
|
|
|
db.mtx.Unlock()
|
|
|
|
|
2019-02-14 05:29:41 -08:00
|
|
|
blockMetas := make([]BlockMeta, 0, len(loadable))
|
|
|
|
for _, b := range loadable {
|
|
|
|
blockMetas = append(blockMetas, b.Meta())
|
|
|
|
}
|
|
|
|
if overlaps := OverlappingBlocks(blockMetas); len(overlaps) > 0 {
|
|
|
|
level.Warn(db.logger).Log("msg", "overlapping blocks found during reload", "detail", overlaps.String())
|
|
|
|
}
|
|
|
|
|
2019-01-16 02:03:52 -08:00
|
|
|
for _, b := range oldBlocks {
|
|
|
|
if _, ok := deletable[b.Meta().ULID]; ok {
|
|
|
|
deletable[b.Meta().ULID] = b
|
2018-06-27 09:05:21 -07:00
|
|
|
}
|
|
|
|
}
|
2019-01-16 02:03:52 -08:00
|
|
|
|
|
|
|
if err := db.deleteBlocks(deletable); err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
// Garbage collect data in the head if the most recent persisted block
|
|
|
|
// covers data of its current time range.
|
|
|
|
if len(loadable) == 0 {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
maxt := loadable[len(loadable)-1].Meta().MaxTime
|
|
|
|
|
|
|
|
return errors.Wrap(db.head.Truncate(maxt), "head truncate failed")
|
|
|
|
}
|
|
|
|
|
2019-07-23 01:04:48 -07:00
|
|
|
func openBlocks(l log.Logger, dir string, loaded []*Block, chunkPool chunkenc.Pool) (blocks []*Block, corrupted map[ulid.ULID]error, err error) {
|
|
|
|
bDirs, err := blockDirs(dir)
|
2019-01-16 02:03:52 -08:00
|
|
|
if err != nil {
|
|
|
|
return nil, nil, errors.Wrap(err, "find blocks")
|
|
|
|
}
|
|
|
|
|
|
|
|
corrupted = make(map[ulid.ULID]error)
|
2019-07-23 01:04:48 -07:00
|
|
|
for _, bDir := range bDirs {
|
|
|
|
meta, _, err := readMetaFile(bDir)
|
2018-06-27 06:47:11 -07:00
|
|
|
if err != nil {
|
2019-12-09 02:37:01 -08:00
|
|
|
level.Error(l).Log("msg", "failed to read meta.json for a block", "dir", bDir, "err", err)
|
2018-06-27 06:47:11 -07:00
|
|
|
continue
|
|
|
|
}
|
2019-01-16 02:03:52 -08:00
|
|
|
|
2018-06-27 06:47:11 -07:00
|
|
|
// See if we already have the block in memory or open it otherwise.
|
2019-07-23 01:04:48 -07:00
|
|
|
block, open := getBlock(loaded, meta.ULID)
|
|
|
|
if !open {
|
|
|
|
block, err = OpenBlock(l, bDir, chunkPool)
|
2017-05-18 07:09:30 -07:00
|
|
|
if err != nil {
|
2019-01-16 02:03:52 -08:00
|
|
|
corrupted[meta.ULID] = err
|
|
|
|
continue
|
2017-03-02 00:13:29 -08:00
|
|
|
}
|
|
|
|
}
|
2019-01-16 02:03:52 -08:00
|
|
|
blocks = append(blocks, block)
|
2016-12-09 01:00:14 -08:00
|
|
|
}
|
2019-01-16 02:03:52 -08:00
|
|
|
return blocks, corrupted, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
// deletableBlocks returns all blocks past retention policy.
|
|
|
|
func (db *DB) deletableBlocks(blocks []*Block) map[ulid.ULID]*Block {
|
|
|
|
deletable := make(map[ulid.ULID]*Block)
|
|
|
|
|
|
|
|
// Sort the blocks by time - newest to oldest (largest to smallest timestamp).
|
|
|
|
// This ensures that the retentions will remove the oldest blocks.
|
2018-05-28 13:00:36 -07:00
|
|
|
sort.Slice(blocks, func(i, j int) bool {
|
2019-01-16 02:03:52 -08:00
|
|
|
return blocks[i].Meta().MaxTime > blocks[j].Meta().MaxTime
|
2018-05-28 13:00:36 -07:00
|
|
|
})
|
2019-01-16 02:03:52 -08:00
|
|
|
|
2019-01-18 00:35:16 -08:00
|
|
|
for _, block := range blocks {
|
|
|
|
if block.Meta().Compaction.Deletable {
|
|
|
|
deletable[block.Meta().ULID] = block
|
|
|
|
}
|
2017-05-18 07:09:30 -07:00
|
|
|
}
|
2017-05-26 04:01:45 -07:00
|
|
|
|
2019-01-16 02:03:52 -08:00
|
|
|
for ulid, block := range db.beyondTimeRetention(blocks) {
|
|
|
|
deletable[ulid] = block
|
2017-05-18 07:09:30 -07:00
|
|
|
}
|
|
|
|
|
2019-01-16 02:03:52 -08:00
|
|
|
for ulid, block := range db.beyondSizeRetention(blocks) {
|
|
|
|
deletable[ulid] = block
|
|
|
|
}
|
2017-05-18 07:09:30 -07:00
|
|
|
|
2019-01-16 02:03:52 -08:00
|
|
|
return deletable
|
|
|
|
}
|
|
|
|
|
2020-01-02 06:54:09 -08:00
|
|
|
func (db *DB) beyondTimeRetention(blocks []*Block) (deletable map[ulid.ULID]*Block) {
|
2019-01-16 02:03:52 -08:00
|
|
|
// Time retention is disabled or no blocks to work with.
|
|
|
|
if len(db.blocks) == 0 || db.opts.RetentionDuration == 0 {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2020-01-02 06:54:09 -08:00
|
|
|
deletable = make(map[ulid.ULID]*Block)
|
2019-01-16 02:03:52 -08:00
|
|
|
for i, block := range blocks {
|
|
|
|
// The difference between the first block and this block is larger than
|
2020-01-02 06:54:09 -08:00
|
|
|
// the retention period so any blocks after that are added as deletable.
|
2020-02-11 08:34:09 -08:00
|
|
|
if i > 0 && blocks[0].Meta().MaxTime-block.Meta().MaxTime > db.opts.RetentionDuration {
|
2019-01-16 02:03:52 -08:00
|
|
|
for _, b := range blocks[i:] {
|
2020-01-02 06:54:09 -08:00
|
|
|
deletable[b.meta.ULID] = b
|
2019-01-16 02:03:52 -08:00
|
|
|
}
|
|
|
|
db.metrics.timeRetentionCount.Inc()
|
|
|
|
break
|
2017-11-03 12:34:21 -07:00
|
|
|
}
|
2019-01-16 02:03:52 -08:00
|
|
|
}
|
2020-01-02 06:54:09 -08:00
|
|
|
return deletable
|
2019-01-16 02:03:52 -08:00
|
|
|
}
|
|
|
|
|
2020-01-02 06:54:09 -08:00
|
|
|
func (db *DB) beyondSizeRetention(blocks []*Block) (deletable map[ulid.ULID]*Block) {
|
2019-01-16 02:03:52 -08:00
|
|
|
// Size retention is disabled or no blocks to work with.
|
|
|
|
if len(db.blocks) == 0 || db.opts.MaxBytes <= 0 {
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2020-01-02 06:54:09 -08:00
|
|
|
deletable = make(map[ulid.ULID]*Block)
|
2019-11-11 18:40:16 -08:00
|
|
|
|
|
|
|
walSize, _ := db.Head().wal.Size()
|
|
|
|
// Initializing size counter with WAL size,
|
|
|
|
// as that is part of the retention strategy.
|
|
|
|
blocksSize := walSize
|
2019-01-16 02:03:52 -08:00
|
|
|
for i, block := range blocks {
|
|
|
|
blocksSize += block.Size()
|
2020-02-06 07:58:38 -08:00
|
|
|
if blocksSize > int64(db.opts.MaxBytes) {
|
2019-01-16 02:03:52 -08:00
|
|
|
// Add this and all following blocks for deletion.
|
|
|
|
for _, b := range blocks[i:] {
|
2020-01-02 06:54:09 -08:00
|
|
|
deletable[b.meta.ULID] = b
|
2019-01-16 02:03:52 -08:00
|
|
|
}
|
|
|
|
db.metrics.sizeRetentionCount.Inc()
|
|
|
|
break
|
2017-11-03 12:34:21 -07:00
|
|
|
}
|
2018-06-27 06:47:11 -07:00
|
|
|
}
|
2020-01-02 06:54:09 -08:00
|
|
|
return deletable
|
2019-01-16 02:03:52 -08:00
|
|
|
}
|
|
|
|
|
|
|
|
// deleteBlocks closes and deletes blocks from the disk.
|
|
|
|
// When the map contains a non nil block object it means it is loaded in memory
|
|
|
|
// so needs to be closed first as it might need to wait for pending readers to complete.
|
|
|
|
func (db *DB) deleteBlocks(blocks map[ulid.ULID]*Block) error {
|
|
|
|
for ulid, block := range blocks {
|
|
|
|
if block != nil {
|
|
|
|
if err := block.Close(); err != nil {
|
|
|
|
level.Warn(db.logger).Log("msg", "closing block failed", "err", err)
|
|
|
|
}
|
|
|
|
}
|
2018-06-27 06:47:11 -07:00
|
|
|
if err := os.RemoveAll(filepath.Join(db.dir, ulid.String())); err != nil {
|
|
|
|
return errors.Wrapf(err, "delete obsolete block %s", ulid)
|
2017-10-23 11:30:03 -07:00
|
|
|
}
|
|
|
|
}
|
2019-01-16 02:03:52 -08:00
|
|
|
return nil
|
2017-05-18 07:09:30 -07:00
|
|
|
}
|
2017-01-03 06:43:26 -08:00
|
|
|
|
2019-02-26 11:50:37 -08:00
|
|
|
// validateBlockSequence returns error if given block meta files indicate that some blocks overlaps within sequence.
|
|
|
|
func validateBlockSequence(bs []*Block) error {
|
|
|
|
if len(bs) <= 1 {
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
var metas []BlockMeta
|
|
|
|
for _, b := range bs {
|
|
|
|
metas = append(metas, b.meta)
|
|
|
|
}
|
|
|
|
|
|
|
|
overlaps := OverlappingBlocks(metas)
|
|
|
|
if len(overlaps) > 0 {
|
|
|
|
return errors.Errorf("block time ranges overlap: %s", overlaps)
|
|
|
|
}
|
|
|
|
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
2018-04-05 06:15:24 -07:00
|
|
|
// TimeRange specifies minTime and maxTime range.
|
2018-03-29 04:50:46 -07:00
|
|
|
type TimeRange struct {
|
2018-04-05 05:51:33 -07:00
|
|
|
Min, Max int64
|
2018-03-29 04:50:46 -07:00
|
|
|
}
|
2018-04-05 05:51:33 -07:00
|
|
|
|
2018-04-05 06:15:24 -07:00
|
|
|
// Overlaps contains overlapping blocks aggregated by overlapping range.
|
|
|
|
type Overlaps map[TimeRange][]BlockMeta
|
|
|
|
|
|
|
|
// String returns human readable string form of overlapped blocks.
|
|
|
|
func (o Overlaps) String() string {
|
|
|
|
var res []string
|
|
|
|
for r, overlaps := range o {
|
|
|
|
var groups []string
|
|
|
|
for _, m := range overlaps {
|
|
|
|
groups = append(groups, fmt.Sprintf(
|
2018-04-05 08:53:24 -07:00
|
|
|
"<ulid: %s, mint: %d, maxt: %d, range: %s>",
|
2018-04-05 06:15:24 -07:00
|
|
|
m.ULID.String(),
|
|
|
|
m.MinTime,
|
|
|
|
m.MaxTime,
|
|
|
|
(time.Duration((m.MaxTime-m.MinTime)/1000)*time.Second).String(),
|
|
|
|
))
|
|
|
|
}
|
2018-04-05 08:01:16 -07:00
|
|
|
res = append(res, fmt.Sprintf(
|
2018-04-05 08:53:24 -07:00
|
|
|
"[mint: %d, maxt: %d, range: %s, blocks: %d]: %s",
|
2018-04-05 08:01:16 -07:00
|
|
|
r.Min, r.Max,
|
|
|
|
(time.Duration((r.Max-r.Min)/1000)*time.Second).String(),
|
|
|
|
len(overlaps),
|
2018-04-05 08:53:24 -07:00
|
|
|
strings.Join(groups, ", ")),
|
2018-04-05 08:01:16 -07:00
|
|
|
)
|
2018-04-05 06:15:24 -07:00
|
|
|
}
|
2018-04-05 08:01:16 -07:00
|
|
|
return strings.Join(res, "\n")
|
2018-04-05 06:15:24 -07:00
|
|
|
}
|
|
|
|
|
|
|
|
// OverlappingBlocks returns all overlapping blocks from given meta files.
|
|
|
|
func OverlappingBlocks(bm []BlockMeta) Overlaps {
|
2018-03-28 10:33:41 -07:00
|
|
|
if len(bm) <= 1 {
|
2018-03-28 07:50:52 -07:00
|
|
|
return nil
|
|
|
|
}
|
2018-03-28 15:50:42 -07:00
|
|
|
var (
|
2018-04-05 05:51:33 -07:00
|
|
|
overlaps [][]BlockMeta
|
|
|
|
|
2018-03-28 15:50:42 -07:00
|
|
|
// pending contains not ended blocks in regards to "current" timestamp.
|
|
|
|
pending = []BlockMeta{bm[0]}
|
2018-03-29 04:50:46 -07:00
|
|
|
// continuousPending helps to aggregate same overlaps to single group.
|
|
|
|
continuousPending = true
|
2018-03-28 15:50:42 -07:00
|
|
|
)
|
2018-04-05 06:15:24 -07:00
|
|
|
|
|
|
|
// We have here blocks sorted by minTime. We iterate over each block and treat its minTime as our "current" timestamp.
|
|
|
|
// We check if any of the pending block finished (blocks that we have seen before, but their maxTime was still ahead current
|
|
|
|
// timestamp). If not, it means they overlap with our current block. In the same time current block is assumed pending.
|
2018-03-28 15:18:24 -07:00
|
|
|
for _, b := range bm[1:] {
|
2018-03-28 15:50:42 -07:00
|
|
|
var newPending []BlockMeta
|
2018-03-28 10:33:41 -07:00
|
|
|
|
2018-03-28 15:18:24 -07:00
|
|
|
for _, p := range pending {
|
2018-03-28 15:50:42 -07:00
|
|
|
// "b.MinTime" is our current time.
|
2018-03-28 15:18:24 -07:00
|
|
|
if b.MinTime >= p.MaxTime {
|
2018-03-29 04:50:46 -07:00
|
|
|
continuousPending = false
|
2018-03-28 15:18:24 -07:00
|
|
|
continue
|
2018-03-28 10:33:41 -07:00
|
|
|
}
|
|
|
|
|
2018-03-28 15:18:24 -07:00
|
|
|
// "p" overlaps with "b" and "p" is still pending.
|
|
|
|
newPending = append(newPending, p)
|
2017-05-18 07:09:30 -07:00
|
|
|
}
|
2018-03-28 15:50:42 -07:00
|
|
|
|
2018-03-28 15:18:24 -07:00
|
|
|
// Our block "b" is now pending.
|
|
|
|
pending = append(newPending, b)
|
|
|
|
if len(newPending) == 0 {
|
2018-03-28 15:50:42 -07:00
|
|
|
// No overlaps.
|
2018-03-28 15:18:24 -07:00
|
|
|
continue
|
2018-03-28 10:33:41 -07:00
|
|
|
}
|
|
|
|
|
2018-03-29 04:50:46 -07:00
|
|
|
if continuousPending && len(overlaps) > 0 {
|
2018-03-28 15:18:24 -07:00
|
|
|
overlaps[len(overlaps)-1] = append(overlaps[len(overlaps)-1], b)
|
2018-03-28 10:33:41 -07:00
|
|
|
continue
|
2017-05-18 07:09:30 -07:00
|
|
|
}
|
2018-03-28 15:18:24 -07:00
|
|
|
overlaps = append(overlaps, append(newPending, b))
|
2018-03-29 04:50:46 -07:00
|
|
|
// Start new pendings.
|
|
|
|
continuousPending = true
|
2017-05-18 07:09:30 -07:00
|
|
|
}
|
2018-04-05 05:51:33 -07:00
|
|
|
|
|
|
|
// Fetch the critical overlapped time range foreach overlap groups.
|
2018-04-05 06:15:24 -07:00
|
|
|
overlapGroups := Overlaps{}
|
2018-04-05 05:51:33 -07:00
|
|
|
for _, overlap := range overlaps {
|
|
|
|
|
|
|
|
minRange := TimeRange{Min: 0, Max: math.MaxInt64}
|
|
|
|
for _, b := range overlap {
|
|
|
|
if minRange.Max > b.MaxTime {
|
|
|
|
minRange.Max = b.MaxTime
|
|
|
|
}
|
|
|
|
|
|
|
|
if minRange.Min < b.MinTime {
|
|
|
|
minRange.Min = b.MinTime
|
|
|
|
}
|
|
|
|
}
|
|
|
|
overlapGroups[minRange] = overlap
|
|
|
|
}
|
|
|
|
|
|
|
|
return overlapGroups
|
2017-01-02 13:24:35 -08:00
|
|
|
}
|
|
|
|
|
2017-10-09 06:21:46 -07:00
|
|
|
func (db *DB) String() string {
|
|
|
|
return "HEAD"
|
|
|
|
}
|
|
|
|
|
|
|
|
// Blocks returns the databases persisted blocks.
|
|
|
|
func (db *DB) Blocks() []*Block {
|
2017-08-29 06:39:27 -07:00
|
|
|
db.mtx.RLock()
|
|
|
|
defer db.mtx.RUnlock()
|
|
|
|
|
|
|
|
return db.blocks
|
|
|
|
}
|
|
|
|
|
2017-10-09 06:21:46 -07:00
|
|
|
// Head returns the databases's head.
|
2017-09-25 07:45:24 -07:00
|
|
|
func (db *DB) Head() *Head {
|
|
|
|
return db.head
|
|
|
|
}
|
|
|
|
|
2017-01-05 23:08:02 -08:00
|
|
|
// Close the partition.
|
2017-01-06 02:40:09 -08:00
|
|
|
func (db *DB) Close() error {
|
2017-01-06 03:37:28 -08:00
|
|
|
close(db.stopc)
|
2019-02-06 04:07:35 -08:00
|
|
|
db.compactCancel()
|
2017-01-06 03:37:28 -08:00
|
|
|
<-db.donec
|
|
|
|
|
2017-01-06 02:40:09 -08:00
|
|
|
db.mtx.Lock()
|
2017-03-17 04:12:50 -07:00
|
|
|
defer db.mtx.Unlock()
|
2017-03-04 07:50:48 -08:00
|
|
|
|
2017-03-06 03:13:15 -08:00
|
|
|
var g errgroup.Group
|
2017-01-02 01:34:55 -08:00
|
|
|
|
2017-03-20 00:41:56 -07:00
|
|
|
// blocks also contains all head blocks.
|
|
|
|
for _, pb := range db.blocks {
|
2017-03-06 03:13:15 -08:00
|
|
|
g.Go(pb.Close)
|
2016-12-14 23:31:26 -08:00
|
|
|
}
|
|
|
|
|
2019-03-19 06:31:57 -07:00
|
|
|
var merr tsdb_errors.MultiError
|
2017-03-06 03:13:15 -08:00
|
|
|
|
|
|
|
merr.Add(g.Wait())
|
2017-08-28 15:39:17 -07:00
|
|
|
|
2017-05-09 03:52:47 -07:00
|
|
|
if db.lockf != nil {
|
2018-05-29 11:35:48 -07:00
|
|
|
merr.Add(db.lockf.Release())
|
2017-05-09 03:52:47 -07:00
|
|
|
}
|
2017-11-10 12:19:39 -08:00
|
|
|
merr.Add(db.head.Close())
|
2017-01-02 13:24:35 -08:00
|
|
|
return merr.Err()
|
2016-12-09 01:00:14 -08:00
|
|
|
}
|
|
|
|
|
2018-11-20 02:34:26 -08:00
|
|
|
// DisableCompactions disables auto compactions.
|
2017-06-06 11:15:23 -07:00
|
|
|
func (db *DB) DisableCompactions() {
|
2018-11-20 02:34:26 -08:00
|
|
|
db.autoCompactMtx.Lock()
|
|
|
|
defer db.autoCompactMtx.Unlock()
|
2017-07-14 01:06:07 -07:00
|
|
|
|
2018-11-20 02:34:26 -08:00
|
|
|
db.autoCompact = false
|
2017-09-28 00:19:34 -07:00
|
|
|
level.Info(db.logger).Log("msg", "compactions disabled")
|
2017-06-06 07:53:20 -07:00
|
|
|
}
|
|
|
|
|
2018-11-20 02:34:26 -08:00
|
|
|
// EnableCompactions enables auto compactions.
|
2017-06-06 11:15:23 -07:00
|
|
|
func (db *DB) EnableCompactions() {
|
2018-11-20 02:34:26 -08:00
|
|
|
db.autoCompactMtx.Lock()
|
|
|
|
defer db.autoCompactMtx.Unlock()
|
2017-07-14 01:06:07 -07:00
|
|
|
|
2018-11-20 02:34:26 -08:00
|
|
|
db.autoCompact = true
|
2017-09-28 00:19:34 -07:00
|
|
|
level.Info(db.logger).Log("msg", "compactions enabled")
|
2017-06-05 01:18:31 -07:00
|
|
|
}
|
|
|
|
|
2018-02-28 03:04:55 -08:00
|
|
|
// Snapshot writes the current data to the directory. If withHead is set to true it
|
|
|
|
// will create a new block containing all data that's currently in the memory buffer/WAL.
|
|
|
|
func (db *DB) Snapshot(dir string, withHead bool) error {
|
2017-08-30 09:34:54 -07:00
|
|
|
if dir == db.dir {
|
|
|
|
return errors.Errorf("cannot snapshot into base directory")
|
|
|
|
}
|
2019-03-18 07:14:10 -07:00
|
|
|
if _, err := ulid.ParseStrict(dir); err == nil {
|
2017-08-30 09:34:54 -07:00
|
|
|
return errors.Errorf("dir must not be a valid ULID")
|
|
|
|
}
|
2017-06-05 01:18:31 -07:00
|
|
|
|
2017-08-30 09:34:54 -07:00
|
|
|
db.cmtx.Lock()
|
|
|
|
defer db.cmtx.Unlock()
|
|
|
|
|
2017-10-23 11:30:03 -07:00
|
|
|
db.mtx.RLock()
|
|
|
|
defer db.mtx.RUnlock()
|
|
|
|
|
|
|
|
for _, b := range db.blocks {
|
2017-09-28 00:19:34 -07:00
|
|
|
level.Info(db.logger).Log("msg", "snapshotting block", "block", b)
|
2017-08-30 09:34:54 -07:00
|
|
|
|
|
|
|
if err := b.Snapshot(dir); err != nil {
|
2017-11-22 04:28:06 -08:00
|
|
|
return errors.Wrapf(err, "error snapshotting block: %s", b.Dir())
|
2017-08-30 09:34:54 -07:00
|
|
|
}
|
|
|
|
}
|
2018-02-28 03:04:55 -08:00
|
|
|
if !withHead {
|
|
|
|
return nil
|
|
|
|
}
|
2019-07-03 03:47:31 -07:00
|
|
|
|
|
|
|
mint := db.head.MinTime()
|
|
|
|
maxt := db.head.MaxTime()
|
2020-02-14 01:50:24 -08:00
|
|
|
head := &RangeHead{
|
2019-07-03 03:47:31 -07:00
|
|
|
head: db.head,
|
|
|
|
mint: mint,
|
|
|
|
maxt: maxt,
|
|
|
|
}
|
|
|
|
// Add +1 millisecond to block maxt because block intervals are half-open: [b.MinTime, b.MaxTime).
|
|
|
|
// Because of this block intervals are always +1 than the total samples it includes.
|
|
|
|
if _, err := db.compactor.Write(dir, head, mint, maxt+1, nil); err != nil {
|
|
|
|
return errors.Wrap(err, "snapshot head block")
|
|
|
|
}
|
|
|
|
return nil
|
2017-08-28 15:39:17 -07:00
|
|
|
}
|
2017-07-14 00:00:22 -07:00
|
|
|
|
2017-08-28 15:39:17 -07:00
|
|
|
// Querier returns a new querier over the data partition for the given time range.
|
|
|
|
// A goroutine must not handle more than one open Querier.
|
2020-02-06 07:58:38 -08:00
|
|
|
func (db *DB) Querier(_ context.Context, mint, maxt int64) (storage.Querier, error) {
|
2017-10-09 06:21:46 -07:00
|
|
|
var blocks []BlockReader
|
2019-02-14 05:29:41 -08:00
|
|
|
var blockMetas []BlockMeta
|
2017-08-28 15:39:17 -07:00
|
|
|
|
2017-10-23 11:30:03 -07:00
|
|
|
db.mtx.RLock()
|
|
|
|
defer db.mtx.RUnlock()
|
|
|
|
|
|
|
|
for _, b := range db.blocks {
|
2018-07-02 01:23:36 -07:00
|
|
|
if b.OverlapsClosedInterval(mint, maxt) {
|
2017-10-09 06:21:46 -07:00
|
|
|
blocks = append(blocks, b)
|
2019-02-14 05:29:41 -08:00
|
|
|
blockMetas = append(blockMetas, b.Meta())
|
2017-10-09 06:21:46 -07:00
|
|
|
}
|
|
|
|
}
|
|
|
|
if maxt >= db.head.MinTime() {
|
2020-02-14 01:50:24 -08:00
|
|
|
blocks = append(blocks, &RangeHead{
|
2018-11-09 05:54:56 -08:00
|
|
|
head: db.head,
|
|
|
|
mint: mint,
|
|
|
|
maxt: maxt,
|
|
|
|
})
|
2017-10-09 06:21:46 -07:00
|
|
|
}
|
2017-08-28 15:39:17 -07:00
|
|
|
|
2020-02-06 07:58:38 -08:00
|
|
|
blockQueriers := make([]storage.Querier, 0, len(blocks))
|
2017-06-06 05:45:54 -07:00
|
|
|
for _, b := range blocks {
|
2017-10-09 06:21:46 -07:00
|
|
|
q, err := NewBlockQuerier(b, mint, maxt)
|
2017-10-23 11:30:03 -07:00
|
|
|
if err == nil {
|
2019-02-14 05:29:41 -08:00
|
|
|
blockQueriers = append(blockQueriers, q)
|
2017-10-23 11:30:03 -07:00
|
|
|
continue
|
|
|
|
}
|
|
|
|
// If we fail, all previously opened queriers must be closed.
|
2019-02-14 05:29:41 -08:00
|
|
|
for _, q := range blockQueriers {
|
2017-10-23 11:30:03 -07:00
|
|
|
q.Close()
|
2017-10-09 06:21:46 -07:00
|
|
|
}
|
2017-10-23 11:30:03 -07:00
|
|
|
return nil, errors.Wrapf(err, "open querier for block %s", b)
|
2017-10-09 06:21:46 -07:00
|
|
|
}
|
2019-02-14 05:29:41 -08:00
|
|
|
|
|
|
|
if len(OverlappingBlocks(blockMetas)) > 0 {
|
|
|
|
return &verticalQuerier{
|
|
|
|
querier: querier{
|
|
|
|
blocks: blockQueriers,
|
|
|
|
},
|
|
|
|
}, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
return &querier{
|
|
|
|
blocks: blockQueriers,
|
|
|
|
}, nil
|
2017-08-28 15:39:17 -07:00
|
|
|
}
|
|
|
|
|
2018-12-04 02:30:49 -08:00
|
|
|
func rangeForTimestamp(t int64, width int64) (maxt int64) {
|
|
|
|
return (t/width)*width + width
|
2017-02-01 06:29:48 -08:00
|
|
|
}
|
|
|
|
|
2017-08-28 15:39:17 -07:00
|
|
|
// Delete implements deletion of metrics. It only has atomicity guarantees on a per-block basis.
|
2019-11-18 11:53:33 -08:00
|
|
|
func (db *DB) Delete(mint, maxt int64, ms ...*labels.Matcher) error {
|
2017-05-20 00:51:10 -07:00
|
|
|
db.cmtx.Lock()
|
|
|
|
defer db.cmtx.Unlock()
|
2017-07-14 00:00:22 -07:00
|
|
|
|
2017-05-19 12:05:50 -07:00
|
|
|
var g errgroup.Group
|
|
|
|
|
2017-10-23 11:30:03 -07:00
|
|
|
db.mtx.RLock()
|
|
|
|
defer db.mtx.RUnlock()
|
|
|
|
|
|
|
|
for _, b := range db.blocks {
|
2018-07-02 01:23:36 -07:00
|
|
|
if b.OverlapsClosedInterval(mint, maxt) {
|
2017-10-09 06:21:46 -07:00
|
|
|
g.Go(func(b *Block) func() error {
|
2017-08-28 15:39:17 -07:00
|
|
|
return func() error { return b.Delete(mint, maxt, ms...) }
|
|
|
|
}(b))
|
|
|
|
}
|
|
|
|
}
|
2017-08-30 09:34:54 -07:00
|
|
|
g.Go(func() error {
|
|
|
|
return db.head.Delete(mint, maxt, ms...)
|
|
|
|
})
|
2018-03-21 14:23:47 -07:00
|
|
|
return g.Wait()
|
2017-05-19 12:05:50 -07:00
|
|
|
}
|
|
|
|
|
2017-11-22 04:34:50 -08:00
|
|
|
// CleanTombstones re-writes any blocks with tombstones.
|
2018-05-30 19:09:30 -07:00
|
|
|
func (db *DB) CleanTombstones() (err error) {
|
2017-11-22 04:34:50 -08:00
|
|
|
db.cmtx.Lock()
|
|
|
|
defer db.cmtx.Unlock()
|
|
|
|
|
|
|
|
start := time.Now()
|
2018-03-21 13:23:47 -07:00
|
|
|
defer db.metrics.tombCleanTimer.Observe(time.Since(start).Seconds())
|
2017-11-22 04:34:50 -08:00
|
|
|
|
2018-05-30 19:09:30 -07:00
|
|
|
newUIDs := []ulid.ULID{}
|
|
|
|
defer func() {
|
|
|
|
// If any error is caused, we need to delete all the new directory created.
|
|
|
|
if err != nil {
|
|
|
|
for _, uid := range newUIDs {
|
|
|
|
dir := filepath.Join(db.Dir(), uid.String())
|
|
|
|
if err := os.RemoveAll(dir); err != nil {
|
|
|
|
level.Error(db.logger).Log("msg", "failed to delete block after failed `CleanTombstones`", "dir", dir, "err", err)
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}()
|
|
|
|
|
2017-11-22 04:34:50 -08:00
|
|
|
db.mtx.RLock()
|
|
|
|
blocks := db.blocks[:]
|
|
|
|
db.mtx.RUnlock()
|
|
|
|
|
|
|
|
for _, b := range blocks {
|
2018-06-04 12:18:44 -07:00
|
|
|
if uid, er := b.CleanTombstones(db.Dir(), db.compactor); er != nil {
|
2018-05-30 19:09:30 -07:00
|
|
|
err = errors.Wrapf(er, "clean tombstones: %s", b.Dir())
|
|
|
|
return err
|
2018-06-04 12:18:44 -07:00
|
|
|
} else if uid != nil { // New block was created.
|
2018-05-30 19:09:30 -07:00
|
|
|
newUIDs = append(newUIDs, *uid)
|
2017-11-22 04:34:50 -08:00
|
|
|
}
|
|
|
|
}
|
2018-06-27 06:47:11 -07:00
|
|
|
return errors.Wrap(db.reload(), "reload blocks")
|
2017-11-22 04:34:50 -08:00
|
|
|
}
|
|
|
|
|
2017-01-19 02:22:47 -08:00
|
|
|
func isBlockDir(fi os.FileInfo) bool {
|
|
|
|
if !fi.IsDir() {
|
|
|
|
return false
|
|
|
|
}
|
2019-03-18 07:14:10 -07:00
|
|
|
_, err := ulid.ParseStrict(fi.Name())
|
2017-05-18 07:09:30 -07:00
|
|
|
return err == nil
|
2017-01-19 02:22:47 -08:00
|
|
|
}
|
|
|
|
|
|
|
|
func blockDirs(dir string) ([]string, error) {
|
|
|
|
files, err := ioutil.ReadDir(dir)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
var dirs []string
|
|
|
|
|
|
|
|
for _, fi := range files {
|
|
|
|
if isBlockDir(fi) {
|
|
|
|
dirs = append(dirs, filepath.Join(dir, fi.Name()))
|
|
|
|
}
|
|
|
|
}
|
|
|
|
return dirs, nil
|
2017-01-03 06:43:26 -08:00
|
|
|
}
|
2016-12-09 04:41:38 -08:00
|
|
|
|
2017-08-30 09:34:54 -07:00
|
|
|
func sequenceFiles(dir string) ([]string, error) {
|
2017-02-13 23:53:19 -08:00
|
|
|
files, err := ioutil.ReadDir(dir)
|
|
|
|
if err != nil {
|
|
|
|
return nil, err
|
|
|
|
}
|
|
|
|
var res []string
|
|
|
|
|
|
|
|
for _, fi := range files {
|
2017-08-30 09:34:54 -07:00
|
|
|
if _, err := strconv.ParseUint(fi.Name(), 10, 64); err != nil {
|
|
|
|
continue
|
2017-02-13 23:53:19 -08:00
|
|
|
}
|
2017-08-30 09:34:54 -07:00
|
|
|
res = append(res, filepath.Join(dir, fi.Name()))
|
2017-02-13 23:53:19 -08:00
|
|
|
}
|
|
|
|
return res, nil
|
|
|
|
}
|
|
|
|
|
2017-08-30 09:34:54 -07:00
|
|
|
func nextSequenceFile(dir string) (string, int, error) {
|
2017-01-19 02:22:47 -08:00
|
|
|
names, err := fileutil.ReadDir(dir)
|
2017-01-06 00:26:39 -08:00
|
|
|
if err != nil {
|
2017-01-28 23:11:47 -08:00
|
|
|
return "", 0, err
|
2017-01-06 00:26:39 -08:00
|
|
|
}
|
2017-01-06 04:13:22 -08:00
|
|
|
|
2017-01-06 00:26:39 -08:00
|
|
|
i := uint64(0)
|
2017-01-06 04:13:22 -08:00
|
|
|
for _, n := range names {
|
2017-08-30 09:34:54 -07:00
|
|
|
j, err := strconv.ParseUint(n, 10, 64)
|
2017-01-06 04:13:22 -08:00
|
|
|
if err != nil {
|
|
|
|
continue
|
2017-01-06 00:26:39 -08:00
|
|
|
}
|
2017-01-06 04:13:22 -08:00
|
|
|
i = j
|
2017-01-06 00:26:39 -08:00
|
|
|
}
|
2017-08-30 09:34:54 -07:00
|
|
|
return filepath.Join(dir, fmt.Sprintf("%0.6d", i+1)), int(i + 1), nil
|
2017-01-06 00:26:39 -08:00
|
|
|
}
|
2016-12-09 04:41:38 -08:00
|
|
|
|
2019-02-11 02:22:11 -08:00
|
|
|
func closeAll(cs []io.Closer) error {
|
2019-03-19 06:31:57 -07:00
|
|
|
var merr tsdb_errors.MultiError
|
2017-02-27 01:46:15 -08:00
|
|
|
|
|
|
|
for _, c := range cs {
|
|
|
|
merr.Add(c.Close())
|
|
|
|
}
|
|
|
|
return merr.Err()
|
|
|
|
}
|
2017-08-28 15:39:17 -07:00
|
|
|
|
|
|
|
func exponential(d, min, max time.Duration) time.Duration {
|
|
|
|
d *= 2
|
|
|
|
if d < min {
|
|
|
|
d = min
|
|
|
|
}
|
|
|
|
if d > max {
|
|
|
|
d = max
|
|
|
|
}
|
|
|
|
return d
|
|
|
|
}
|