Documentation ¶
Overview ¶
Package tsm1 provides a TSDB in the Time Structured Merge tree format.
Index ¶
- Constants
- Variables
- func BlockCount(block []byte) (int, error)
- func BlockType(block []byte) (byte, error)
- func BlockTypeToInfluxQLDataType(typ byte) influxql.DataType
- func BooleanArrayDecodeAll(b []byte, dst []bool) ([]bool, error)
- func BooleanArrayEncodeAll(src []bool, b []byte) ([]byte, error)
- func CacheCollectors() []prometheus.Collector
- func CountTimestamps(b []byte) int
- func DecodeBooleanArrayBlock(block []byte, a *tsdb.BooleanArray) error
- func DecodeFloatArrayBlock(block []byte, a *tsdb.FloatArray) error
- func DecodeIntegerArrayBlock(block []byte, a *tsdb.IntegerArray) error
- func DecodeStringArrayBlock(block []byte, a *tsdb.StringArray) error
- func DecodeUnsignedArrayBlock(block []byte, a *tsdb.UnsignedArray) error
- func DefaultFormatFileName(generation, sequence int) string
- func DefaultParseFileName(name string) (int, int, error)
- func Digest(dir string, files []string, w io.WriteCloser) error
- func DigestFresh(dir string, files []string, shardLastMod time.Time) (bool, string)
- func DigestWithOptions(dir string, files []string, opts DigestOptions, w io.WriteCloser) (err error)
- func EncodeBooleanArrayBlock(a *tsdb.BooleanArray, b []byte) ([]byte, error)
- func EncodeFloatArrayBlock(a *tsdb.FloatArray, b []byte) ([]byte, error)
- func EncodeIntegerArrayBlock(a *tsdb.IntegerArray, b []byte) ([]byte, error)
- func EncodeStringArrayBlock(a *tsdb.StringArray, b []byte) ([]byte, error)
- func EncodeUnsignedArrayBlock(a *tsdb.UnsignedArray, b []byte) ([]byte, error)
- func ErrCacheMemorySizeLimitExceeded(n, limit uint64) error
- func FileStoreCollectors() []prometheus.Collector
- func FloatArrayDecodeAll(b []byte, buf []float64) ([]float64, error)
- func FloatArrayEncodeAll(src []float64, b []byte) ([]byte, error)
- func IntegerArrayDecodeAll(b []byte, dst []int64) ([]int64, error)
- func IntegerArrayEncodeAll(src []int64, b []byte) ([]byte, error)
- func NewBooleanArrayFromValues(v BooleanValues) *tsdb.BooleanArray
- func NewEngine(id uint64, idx tsdb.Index, path string, walPath string, sfile *tsdb.SeriesFile, ...) tsdb.Engine
- func NewFloatArrayFromValues(v FloatValues) *tsdb.FloatArray
- func NewIndirectIndex() *indirectIndex
- func NewIntegerArrayFromValues(v IntegerValues) *tsdb.IntegerArray
- func NewStringArrayFromValues(v StringValues) *tsdb.StringArray
- func NewUnsignedArrayFromValues(v UnsignedValues) *tsdb.UnsignedArray
- func PrometheusCollectors() []prometheus.Collector
- func SeriesAndFieldFromCompositeKey(key []byte) ([]byte, []byte)
- func SeriesFieldKey(seriesKey, field string) string
- func SeriesFieldKeyBytes(seriesKey, field string) []byte
- func StringArrayDecodeAll(b []byte, dst []string) ([]string, error)
- func StringArrayEncodeAll(src []string, b []byte) ([]byte, error)
- func TimeArrayDecodeAll(b []byte, dst []int64) ([]int64, error)
- func TimeArrayEncodeAll(src []int64, b []byte) ([]byte, error)
- func UnsignedArrayDecodeAll(b []byte, dst []uint64) ([]uint64, error)
- func UnsignedArrayEncodeAll(src []uint64, b []byte) ([]byte, error)
- func WALCollectors() []prometheus.Collector
- func ZigZagDecode(v uint64) int64
- func ZigZagEncode(x int64) uint64
- type BatchDeleter
- type BatchDeleters
- type BitReader
- type BlockIterator
- type BooleanDecoder
- type BooleanEncoder
- type BooleanValue
- type BooleanValues
- func (a BooleanValues) Deduplicate() BooleanValues
- func (a BooleanValues) Encode(buf []byte) ([]byte, error)
- func (a BooleanValues) Exclude(min, max int64) BooleanValues
- func (a BooleanValues) FindRange(min, max int64) (int, int)
- func (a BooleanValues) Include(min, max int64) BooleanValues
- func (a BooleanValues) Len() int
- func (a BooleanValues) Less(i, j int) bool
- func (a BooleanValues) MaxTime() int64
- func (a BooleanValues) Merge(b BooleanValues) BooleanValues
- func (a BooleanValues) MinTime() int64
- func (a BooleanValues) Size() int
- func (a BooleanValues) Swap(i, j int)
- type Cache
- func (c *Cache) ApplyEntryFn(f func(key []byte, entry *entry) error) error
- func (c *Cache) ClearSnapshot(success bool)
- func (c *Cache) Count() int
- func (c *Cache) Deduplicate()
- func (c *Cache) Delete(keys [][]byte)
- func (c *Cache) DeleteRange(keys [][]byte, min, max int64)
- func (c *Cache) Free()
- func (c *Cache) Keys() [][]byte
- func (c *Cache) LastWriteTime() time.Time
- func (c *Cache) MaxSize() uint64
- func (c *Cache) SetMaxSize(size uint64)
- func (c *Cache) Size() uint64
- func (c *Cache) Snapshot() (*Cache, error)
- func (c *Cache) Split(n int) []*Cache
- func (c *Cache) Type(key []byte) (models.FieldType, error)
- func (c *Cache) Values(key []byte) Values
- func (c *Cache) WriteMulti(values map[string][]Value) error
- type CacheLoader
- type CompactionGroup
- type CompactionPlanner
- type Compactor
- func (c *Compactor) Close()
- func (c *Compactor) CompactFast(tsmFiles []string, logger *zap.Logger) ([]string, error)
- func (c *Compactor) CompactFull(tsmFiles []string, logger *zap.Logger) ([]string, error)
- func (c *Compactor) DisableCompactions()
- func (c *Compactor) DisableSnapshots()
- func (c *Compactor) EnableCompactions()
- func (c *Compactor) EnableSnapshots()
- func (c *Compactor) Open()
- func (c *Compactor) WithFormatFileNameFunc(formatFileNameFunc FormatFileNameFunc)
- func (c *Compactor) WithParseFileNameFunc(parseFileNameFunc ParseFileNameFunc)
- func (c *Compactor) WriteSnapshot(cache *Cache, logger *zap.Logger) ([]string, error)
- type DefaultPlanner
- func (c *DefaultPlanner) ForceFull()
- func (c *DefaultPlanner) FullyCompacted() (bool, string)
- func (c *DefaultPlanner) ParseFileName(path string) (int, int, error)
- func (c *DefaultPlanner) Plan(lastWrite time.Time) ([]CompactionGroup, int64)
- func (c *DefaultPlanner) PlanLevel(level int) ([]CompactionGroup, int64)
- func (c *DefaultPlanner) PlanOptimize() ([]CompactionGroup, int64)
- func (c *DefaultPlanner) Release(groups []CompactionGroup)
- func (c *DefaultPlanner) SetFileStore(fs *FileStore)
- type DeleteRangeWALEntry
- type DeleteWALEntry
- type DigestManifest
- type DigestManifestEntries
- type DigestManifestEntry
- type DigestOptions
- type DigestReader
- type DigestTimeRange
- type DigestTimeSpan
- type DigestWriter
- type EmptyValue
- type Engine
- func (e *Engine) Backup(w io.Writer, basePath string, since time.Time) error
- func (e *Engine) Close() error
- func (e *Engine) CreateCursorIterator(ctx context.Context) (tsdb.CursorIterator, error)
- func (e *Engine) CreateIterator(ctx context.Context, measurement string, opt query.IteratorOptions) (query.Iterator, error)
- func (e *Engine) CreateSeriesIfNotExists(key, name []byte, tags models.Tags) error
- func (e *Engine) CreateSeriesListIfNotExists(keys, names [][]byte, tagsSlice []models.Tags) error
- func (e *Engine) CreateSnapshot(skipCacheOk bool) (string, error)
- func (e *Engine) DeleteMeasurement(ctx context.Context, name []byte) error
- func (e *Engine) DeleteSeriesRange(ctx context.Context, itr tsdb.SeriesIterator, min, max int64) error
- func (e *Engine) DeleteSeriesRangeWithPredicate(ctx context.Context, itr tsdb.SeriesIterator, ...) error
- func (e *Engine) Digest() (io.ReadCloser, int64, error)
- func (e *Engine) DiskSize() int64
- func (e *Engine) Export(w io.Writer, basePath string, start time.Time, end time.Time) error
- func (e *Engine) ForEachMeasurementName(fn func(name []byte) error) error
- func (e *Engine) Free() error
- func (e *Engine) HasTagKey(name, key []byte) (bool, error)
- func (e *Engine) Import(r io.Reader, basePath string) error
- func (e *Engine) InUse() (bool, error)
- func (e *Engine) IsIdle() (state bool, reason string)
- func (e *Engine) IteratorCost(measurement string, opt query.IteratorOptions) (query.IteratorCost, error)
- func (e *Engine) KeyCursor(ctx context.Context, key []byte, t int64, ascending bool) *KeyCursor
- func (e *Engine) LastModified() time.Time
- func (e *Engine) LoadMetadataIndex(shardID uint64, index tsdb.Index) error
- func (e *Engine) MeasurementExists(name []byte) (bool, error)
- func (e *Engine) MeasurementFieldSet() *tsdb.MeasurementFieldSet
- func (e *Engine) MeasurementFields(measurement []byte) *tsdb.MeasurementFields
- func (e *Engine) MeasurementNamesByRegex(re *regexp.Regexp) ([][]byte, error)
- func (e *Engine) MeasurementTagKeysByExpr(name []byte, expr influxql.Expr) (map[string]struct{}, error)
- func (e *Engine) MeasurementsSketches() (estimator.Sketch, estimator.Sketch, error)
- func (e *Engine) Open(ctx context.Context) error
- func (e *Engine) Path() string
- func (e *Engine) Reindex() error
- func (e *Engine) Restore(r io.Reader, basePath string) error
- func (e *Engine) ScheduleFullCompaction() error
- func (e *Engine) SeriesN() int64
- func (e *Engine) SeriesSketches() (estimator.Sketch, estimator.Sketch, error)
- func (e *Engine) SetCompactionsEnabled(enabled bool)
- func (e *Engine) SetEnabled(enabled bool)
- func (e *Engine) SetNewReadersBlocked(blocked bool) error
- func (e *Engine) ShouldCompactCache(t time.Time) bool
- func (e *Engine) TagKeyCardinality(name, key []byte) int
- func (e *Engine) Type(series []byte) (models.FieldType, error)
- func (e *Engine) WithFormatFileNameFunc(formatFileNameFunc FormatFileNameFunc)
- func (e *Engine) WithLogger(log *zap.Logger)
- func (e *Engine) WithParseFileNameFunc(parseFileNameFunc ParseFileNameFunc)
- func (e *Engine) WritePoints(ctx context.Context, points []models.Point) error
- func (e *Engine) WriteSnapshot() (err error)
- func (e *Engine) WriteTo(w io.Writer) (n int64, err error)
- type FileStat
- type FileStore
- func (f *FileStore) Apply(ctx context.Context, fn func(r TSMFile) error) error
- func (f *FileStore) BlockCount(path string, idx int) int
- func (f *FileStore) Close() error
- func (f *FileStore) Cost(key []byte, min, max int64) query.IteratorCost
- func (f *FileStore) Count() int
- func (f *FileStore) CreateSnapshot() (string, error)
- func (f *FileStore) CurrentGeneration() int
- func (f *FileStore) Delete(keys [][]byte) error
- func (f *FileStore) DeleteRange(keys [][]byte, min, max int64) error
- func (f *FileStore) DiskSizeBytes() int64
- func (f *FileStore) Files() []TSMFile
- func (f *FileStore) Free() error
- func (f *FileStore) InUse() (bool, error)
- func (f *FileStore) KeyCursor(ctx context.Context, key []byte, t int64, ascending bool) *KeyCursor
- func (f *FileStore) Keys() map[string]byte
- func (f *FileStore) LastModified() time.Time
- func (f *FileStore) MakeSnapshotLinks(destPath string, files []TSMFile) (returnErr error)
- func (f *FileStore) NextGeneration() int
- func (f *FileStore) Open(ctx context.Context) error
- func (f *FileStore) ParseFileName(path string) (int, int, error)
- func (f *FileStore) Read(key []byte, t int64) ([]Value, error)
- func (f *FileStore) Replace(oldFiles, newFiles []string) error
- func (f *FileStore) ReplaceWithCallback(oldFiles, newFiles []string, updatedFn func(r []TSMFile)) error
- func (f *FileStore) SetNewReadersBlocked(block bool) error
- func (f *FileStore) Stats() []FileStat
- func (f *FileStore) TSMReader(path string) (*TSMReader, error)
- func (f *FileStore) Type(key []byte) (byte, error)
- func (f *FileStore) WalkKeys(seek []byte, fn func(key []byte, typ byte) error) error
- func (f *FileStore) WithLogger(log *zap.Logger)
- func (f *FileStore) WithObserver(obs tsdb.FileStoreObserver)
- func (f *FileStore) WithParseFileNameFunc(parseFileNameFunc ParseFileNameFunc)
- type FloatDecoder
- type FloatEncoder
- type FloatValue
- type FloatValues
- func (a FloatValues) Deduplicate() FloatValues
- func (a FloatValues) Encode(buf []byte) ([]byte, error)
- func (a FloatValues) Exclude(min, max int64) FloatValues
- func (a FloatValues) FindRange(min, max int64) (int, int)
- func (a FloatValues) Include(min, max int64) FloatValues
- func (a FloatValues) Len() int
- func (a FloatValues) Less(i, j int) bool
- func (a FloatValues) MaxTime() int64
- func (a FloatValues) Merge(b FloatValues) FloatValues
- func (a FloatValues) MinTime() int64
- func (a FloatValues) Size() int
- func (a FloatValues) Swap(i, j int)
- type FormatFileNameFunc
- type IndexEntry
- type IndexWriter
- type IntegerDecoder
- type IntegerEncoder
- type IntegerValue
- type IntegerValues
- func (a IntegerValues) Deduplicate() IntegerValues
- func (a IntegerValues) Encode(buf []byte) ([]byte, error)
- func (a IntegerValues) Exclude(min, max int64) IntegerValues
- func (a IntegerValues) FindRange(min, max int64) (int, int)
- func (a IntegerValues) Include(min, max int64) IntegerValues
- func (a IntegerValues) Len() int
- func (a IntegerValues) Less(i, j int) bool
- func (a IntegerValues) MaxTime() int64
- func (a IntegerValues) Merge(b IntegerValues) IntegerValues
- func (a IntegerValues) MinTime() int64
- func (a IntegerValues) Size() int
- func (a IntegerValues) Swap(i, j int)
- type KeyCursor
- func (c *KeyCursor) Close()
- func (c *KeyCursor) Next()
- func (c *KeyCursor) ReadBooleanArrayBlock(values *tsdb.BooleanArray) (*tsdb.BooleanArray, error)
- func (c *KeyCursor) ReadBooleanBlock(buf *[]BooleanValue) ([]BooleanValue, error)
- func (c *KeyCursor) ReadFloatArrayBlock(values *tsdb.FloatArray) (*tsdb.FloatArray, error)
- func (c *KeyCursor) ReadFloatBlock(buf *[]FloatValue) ([]FloatValue, error)
- func (c *KeyCursor) ReadIntegerArrayBlock(values *tsdb.IntegerArray) (*tsdb.IntegerArray, error)
- func (c *KeyCursor) ReadIntegerBlock(buf *[]IntegerValue) ([]IntegerValue, error)
- func (c *KeyCursor) ReadStringArrayBlock(values *tsdb.StringArray) (*tsdb.StringArray, error)
- func (c *KeyCursor) ReadStringBlock(buf *[]StringValue) ([]StringValue, error)
- func (c *KeyCursor) ReadUnsignedArrayBlock(values *tsdb.UnsignedArray) (*tsdb.UnsignedArray, error)
- func (c *KeyCursor) ReadUnsignedBlock(buf *[]UnsignedValue) ([]UnsignedValue, error)
- type KeyIterator
- type ParseFileNameFunc
- type Predicate
- type StringDecoder
- type StringEncoder
- type StringValue
- type StringValues
- func (a StringValues) Deduplicate() StringValues
- func (a StringValues) Encode(buf []byte) ([]byte, error)
- func (a StringValues) Exclude(min, max int64) StringValues
- func (a StringValues) FindRange(min, max int64) (int, int)
- func (a StringValues) Include(min, max int64) StringValues
- func (a StringValues) Len() int
- func (a StringValues) Less(i, j int) bool
- func (a StringValues) MaxTime() int64
- func (a StringValues) Merge(b StringValues) StringValues
- func (a StringValues) MinTime() int64
- func (a StringValues) Size() int
- func (a StringValues) Swap(i, j int)
- type TSMErrors
- type TSMFile
- type TSMIndex
- type TSMReader
- func (r *TSMReader) BatchDelete() BatchDeleter
- func (t *TSMReader) BlockIterator() *BlockIterator
- func (t *TSMReader) Close() error
- func (t *TSMReader) Contains(key []byte) bool
- func (t *TSMReader) ContainsValue(key []byte, ts int64) bool
- func (t *TSMReader) Delete(keys [][]byte) error
- func (t *TSMReader) DeleteRange(keys [][]byte, minTime, maxTime int64) error
- func (t *TSMReader) Entries(key []byte) []IndexEntry
- func (t *TSMReader) Free() error
- func (t *TSMReader) HasTombstones() bool
- func (t *TSMReader) InUse() bool
- func (t *TSMReader) IndexSize() uint32
- func (t *TSMReader) Key(index int, entries *[]IndexEntry) ([]byte, byte, []IndexEntry)
- func (t *TSMReader) KeyAt(idx int) ([]byte, byte)
- func (t *TSMReader) KeyCount() int
- func (t *TSMReader) KeyRange() ([]byte, []byte)
- func (t *TSMReader) LastModified() int64
- func (t *TSMReader) OverlapsKeyRange(min, max []byte) bool
- func (t *TSMReader) OverlapsTimeRange(min, max int64) bool
- func (t *TSMReader) Path() string
- func (t *TSMReader) Read(key []byte, timestamp int64) ([]Value, error)
- func (t *TSMReader) ReadAll(key []byte) ([]Value, error)
- func (t *TSMReader) ReadAt(entry *IndexEntry, vals []Value) ([]Value, error)
- func (t *TSMReader) ReadBooleanArrayBlockAt(entry *IndexEntry, vals *tsdb.BooleanArray) error
- func (t *TSMReader) ReadBooleanBlockAt(entry *IndexEntry, vals *[]BooleanValue) ([]BooleanValue, error)
- func (t *TSMReader) ReadBytes(e *IndexEntry, b []byte) (uint32, []byte, error)
- func (t *TSMReader) ReadEntries(key []byte, entries *[]IndexEntry) []IndexEntry
- func (t *TSMReader) ReadFloatArrayBlockAt(entry *IndexEntry, vals *tsdb.FloatArray) error
- func (t *TSMReader) ReadFloatBlockAt(entry *IndexEntry, vals *[]FloatValue) ([]FloatValue, error)
- func (t *TSMReader) ReadIntegerArrayBlockAt(entry *IndexEntry, vals *tsdb.IntegerArray) error
- func (t *TSMReader) ReadIntegerBlockAt(entry *IndexEntry, vals *[]IntegerValue) ([]IntegerValue, error)
- func (t *TSMReader) ReadStringArrayBlockAt(entry *IndexEntry, vals *tsdb.StringArray) error
- func (t *TSMReader) ReadStringBlockAt(entry *IndexEntry, vals *[]StringValue) ([]StringValue, error)
- func (t *TSMReader) ReadUnsignedArrayBlockAt(entry *IndexEntry, vals *tsdb.UnsignedArray) error
- func (t *TSMReader) ReadUnsignedBlockAt(entry *IndexEntry, vals *[]UnsignedValue) ([]UnsignedValue, error)
- func (t *TSMReader) Ref()
- func (t *TSMReader) Remove() error
- func (t *TSMReader) Rename(path string) error
- func (t *TSMReader) Seek(key []byte) int
- func (t *TSMReader) Size() uint32
- func (t *TSMReader) Stats() FileStat
- func (t *TSMReader) TimeRange() (int64, int64)
- func (t *TSMReader) TombstoneRange(key []byte) []TimeRange
- func (t *TSMReader) TombstoneStats() TombstoneStat
- func (t *TSMReader) Type(key []byte) (byte, error)
- func (t *TSMReader) Unref()
- func (t *TSMReader) WithObserver(obs tsdb.FileStoreObserver)
- type TSMWriter
- type TimeDecoder
- type TimeEncoder
- type TimeRange
- type Tombstone
- type TombstoneStat
- type Tombstoner
- func (t *Tombstoner) Add(keys [][]byte) error
- func (t *Tombstoner) AddRange(keys [][]byte, min, max int64) error
- func (t *Tombstoner) Delete() error
- func (t *Tombstoner) Flush() error
- func (t *Tombstoner) HasTombstones() bool
- func (t *Tombstoner) Rollback() error
- func (t *Tombstoner) TombstoneStats() TombstoneStat
- func (t *Tombstoner) Walk(fn func(t Tombstone) error) error
- func (t *Tombstoner) WithObserver(obs tsdb.FileStoreObserver)
- type UnsignedValue
- type UnsignedValues
- func (a UnsignedValues) Deduplicate() UnsignedValues
- func (a UnsignedValues) Encode(buf []byte) ([]byte, error)
- func (a UnsignedValues) Exclude(min, max int64) UnsignedValues
- func (a UnsignedValues) FindRange(min, max int64) (int, int)
- func (a UnsignedValues) Include(min, max int64) UnsignedValues
- func (a UnsignedValues) Len() int
- func (a UnsignedValues) Less(i, j int) bool
- func (a UnsignedValues) MaxTime() int64
- func (a UnsignedValues) Merge(b UnsignedValues) UnsignedValues
- func (a UnsignedValues) MinTime() int64
- func (a UnsignedValues) Size() int
- func (a UnsignedValues) Swap(i, j int)
- type Value
- func DecodeBlock(block []byte, vals []Value) ([]Value, error)
- func NewBooleanValue(t int64, v bool) Value
- func NewFloatValue(t int64, v float64) Value
- func NewIntegerValue(t int64, v int64) Value
- func NewStringValue(t int64, v string) Value
- func NewUnsignedValue(t int64, v uint64) Value
- func NewValue(t int64, value interface{}) Value
- type Values
- func (a Values) Deduplicate() Values
- func (a Values) Encode(buf []byte) ([]byte, error)
- func (a Values) Exclude(min, max int64) Values
- func (a Values) FindRange(min, max int64) (int, int)
- func (a Values) Include(min, max int64) Values
- func (a Values) InfluxQLType() (influxql.DataType, error)
- func (a Values) Len() int
- func (a Values) Less(i, j int) bool
- func (a Values) MaxTime() int64
- func (a Values) Merge(b Values) Values
- func (a Values) MinTime() int64
- func (a Values) Size() int
- func (a Values) Swap(i, j int)
- type WAL
- func (l *WAL) Close() error
- func (l *WAL) CloseSegment() error
- func (l *WAL) ClosedSegments() ([]string, error)
- func (l *WAL) Delete(ctx context.Context, keys [][]byte) (int, error)
- func (l *WAL) DeleteRange(ctx context.Context, keys [][]byte, min, max int64) (int, error)
- func (l *WAL) DiskSizeBytes() int64
- func (l *WAL) LastWriteTime() time.Time
- func (l *WAL) Open() error
- func (l *WAL) Path() string
- func (l *WAL) Remove(files []string) error
- func (l *WAL) WithLogger(log *zap.Logger)
- func (l *WAL) WriteMulti(ctx context.Context, values map[string][]Value) (int, error)
- type WALEntry
- type WALSegmentReader
- type WALSegmentWriter
- type WalEntryType
- type WriteWALEntry
Constants ¶
const ( // CompactionTempExtension is the extension used for temporary files created during compaction. CompactionTempExtension = "tmp" // TSMFileExtension is the extension used for TSM files. TSMFileExtension = "tsm" // DefaultMaxSavedErrors is the number of errors that are stored by a TSMBatchKeyReader before // subsequent errors are discarded DefaultMaxSavedErrors = 100 )
const ( // BlockFloat64 designates a block encodes float64 values. BlockFloat64 = byte(0) // BlockInteger designates a block encodes int64 values. BlockInteger = byte(1) // BlockBoolean designates a block encodes boolean values. BlockBoolean = byte(2) // BlockString designates a block encodes string values. BlockString = byte(3) // BlockUnsigned designates a block encodes uint64 values. BlockUnsigned = byte(4) )
const ( // The extension used to describe temporary snapshot files. TmpTSMFileExtension = "tmp" // The extension used to describe corrupt snapshot files. BadTSMFileExtension = "bad" )
const ( // DefaultSegmentSize of 10MB is the size at which segment files will be rolled over. DefaultSegmentSize = 10 * 1024 * 1024 // WALFileExtension is the file extension we expect for wal segments. WALFileExtension = "wal" // WALFilePrefix is the prefix on all wal segment files. WALFilePrefix = "_" )
const ( // MagicNumber is written as the first 4 bytes of a data file to // identify the file as a tsm1 formatted file MagicNumber uint32 = 0x16D116D1 // Version indicates the version of the TSM file format. Version byte = 1 )
const (
DigestFilename = "digest.tsd"
)
const TombstoneFileExtension = "tombstone"
Variables ¶
var ( // ErrNoDigestManifest is returned if an attempt is made to write other parts of a // digest before writing the manifest. ErrNoDigestManifest = errors.New("no digest manifest") // ErrDigestAlreadyWritten is returned if the client attempts to write more than // one manifest. ErrDigestAlreadyWritten = errors.New("digest manifest already written") )
var ( // ErrWALClosed is returned when attempting to write to a closed WAL file. ErrWALClosed = fmt.Errorf("WAL closed") // ErrWALCorrupt is returned when reading a corrupt WAL entry. ErrWALCorrupt = fmt.Errorf("corrupted WAL entry") )
var ( //ErrNoValues is returned when TSMWriter.WriteIndex is called and there are no values to write. ErrNoValues = fmt.Errorf("no values written") // ErrTSMClosed is returned when performing an operation against a closed TSM file. ErrTSMClosed = fmt.Errorf("tsm file closed") // ErrMaxKeyLengthExceeded is returned when attempting to write a key that is too long. ErrMaxKeyLengthExceeded = fmt.Errorf("max key length exceeded") // ErrMaxBlocksExceeded is returned when attempting to write a block past the allowed number. ErrMaxBlocksExceeded = fmt.Errorf("max blocks exceeded") )
var ( // ErrDigestManifestAlreadyRead is returned if the client attempts to read // a manifest from a digest more than once on the same reader. ErrDigestManifestAlreadyRead = errors.New("digest manifest already read") )
var ErrFileInUse = fmt.Errorf("file still in use")
ErrFileInUse is returned when attempting to remove or close a TSM file that is still being used.
var (
ErrNewReadersBlocked = errors.New("new readers blocked")
)
var ( // ErrSnapshotInProgress is returned if a snapshot is attempted while one is already running. ErrSnapshotInProgress = fmt.Errorf("snapshot in progress") )
var ( // ErrStringArrayEncodeTooLarge reports that the encoded length of a slice of strings is too large. ErrStringArrayEncodeTooLarge = errors.New("StringArrayEncodeAll: source length too large") )
var WithMadviseWillNeed = func(willNeed bool) tsmReaderOption { return func(r *TSMReader) { r.madviseWillNeed = willNeed } }
WithMadviseWillNeed is an option for specifying whether to provide a MADV_WILL need hint to the kernel.
Functions ¶
func BlockCount ¶
BlockCount returns the number of timestamps encoded in block.
func BlockType ¶
BlockType returns the type of value encoded in a block or an error if the block type is unknown.
func BooleanArrayEncodeAll ¶
BooleanArrayEncodeAll encodes src into b, returning b and any error encountered. The returned slice may be of a different length and capacity to b.
func CacheCollectors ¶ added in v2.2.0
func CacheCollectors() []prometheus.Collector
func CountTimestamps ¶
func DecodeBooleanArrayBlock ¶
func DecodeBooleanArrayBlock(block []byte, a *tsdb.BooleanArray) error
DecodeBooleanArrayBlock decodes the boolean block from the byte slice and writes the values to a.
func DecodeFloatArrayBlock ¶
func DecodeFloatArrayBlock(block []byte, a *tsdb.FloatArray) error
DecodeFloatArrayBlock decodes the float block from the byte slice and writes the values to a.
func DecodeIntegerArrayBlock ¶
func DecodeIntegerArrayBlock(block []byte, a *tsdb.IntegerArray) error
DecodeIntegerArrayBlock decodes the integer block from the byte slice and writes the values to a.
func DecodeStringArrayBlock ¶
func DecodeStringArrayBlock(block []byte, a *tsdb.StringArray) error
DecodeStringArrayBlock decodes the string block from the byte slice and writes the values to a.
func DecodeUnsignedArrayBlock ¶
func DecodeUnsignedArrayBlock(block []byte, a *tsdb.UnsignedArray) error
DecodeUnsignedArrayBlock decodes the unsigned integer block from the byte slice and writes the values to a.
func DefaultFormatFileName ¶
DefaultFormatFileName is the default implementation to format TSM filenames.
func DefaultParseFileName ¶
DefaultParseFileName is used to parse the filenames of TSM files.
func Digest ¶
func Digest(dir string, files []string, w io.WriteCloser) error
Digest writes a digest of dir to w of a full shard dir.
func DigestFresh ¶
DigestFresh returns true if digest cached in dir is still fresh and returns false if it is stale. If the digest is stale, a string description of the reason is also returned. files is a list of filenames the caller expects the digest to contain, usually from the engine's FileStore.
func DigestWithOptions ¶
func DigestWithOptions(dir string, files []string, opts DigestOptions, w io.WriteCloser) (err error)
DigestWithOptions writes a digest of dir to w using options to filter by time and key range.
func EncodeBooleanArrayBlock ¶
func EncodeBooleanArrayBlock(a *tsdb.BooleanArray, b []byte) ([]byte, error)
func EncodeFloatArrayBlock ¶
func EncodeFloatArrayBlock(a *tsdb.FloatArray, b []byte) ([]byte, error)
func EncodeIntegerArrayBlock ¶
func EncodeIntegerArrayBlock(a *tsdb.IntegerArray, b []byte) ([]byte, error)
func EncodeStringArrayBlock ¶
func EncodeStringArrayBlock(a *tsdb.StringArray, b []byte) ([]byte, error)
func EncodeUnsignedArrayBlock ¶
func EncodeUnsignedArrayBlock(a *tsdb.UnsignedArray, b []byte) ([]byte, error)
func ErrCacheMemorySizeLimitExceeded ¶
ErrCacheMemorySizeLimitExceeded returns an error indicating an operation could not be completed due to exceeding the cache-max-memory-size setting.
func FileStoreCollectors ¶ added in v2.2.0
func FileStoreCollectors() []prometheus.Collector
func FloatArrayEncodeAll ¶
FloatArrayEncodeAll encodes src into b, returning b and any error encountered. The returned slice may be of a different length and capacity to b.
Currently only the float compression scheme used in Facebook's Gorilla is supported, so this method implements a batch oriented version of that.
func IntegerArrayEncodeAll ¶
IntegerArrayEncodeAll encodes src into b, returning b and any error encountered. The returned slice may be of a different length and capacity to b.
IntegerArrayEncodeAll implements batch oriented versions of the three integer encoding types we support: uncompressed, simple8b and RLE.
Important: IntegerArrayEncodeAll modifies the contents of src by using it as scratch space for delta encoded values. It is NOT SAFE to use src after passing it into IntegerArrayEncodeAll.
func NewBooleanArrayFromValues ¶
func NewBooleanArrayFromValues(v BooleanValues) *tsdb.BooleanArray
func NewEngine ¶
func NewEngine(id uint64, idx tsdb.Index, path string, walPath string, sfile *tsdb.SeriesFile, opt tsdb.EngineOptions) tsdb.Engine
NewEngine returns a new instance of Engine.
func NewFloatArrayFromValues ¶
func NewFloatArrayFromValues(v FloatValues) *tsdb.FloatArray
func NewIndirectIndex ¶
func NewIndirectIndex() *indirectIndex
NewIndirectIndex returns a new indirect index.
func NewIntegerArrayFromValues ¶
func NewIntegerArrayFromValues(v IntegerValues) *tsdb.IntegerArray
func NewStringArrayFromValues ¶
func NewStringArrayFromValues(v StringValues) *tsdb.StringArray
func NewUnsignedArrayFromValues ¶
func NewUnsignedArrayFromValues(v UnsignedValues) *tsdb.UnsignedArray
func PrometheusCollectors ¶ added in v2.2.0
func PrometheusCollectors() []prometheus.Collector
PrometheusCollectors returns all prometheus metrics for the tsm1 package.
func SeriesAndFieldFromCompositeKey ¶
SeriesAndFieldFromCompositeKey returns the series key and the field key extracted from the composite key.
func SeriesFieldKey ¶
SeriesFieldKey combine a series key and field name for a unique string to be hashed to a numeric ID.
func SeriesFieldKeyBytes ¶
func StringArrayEncodeAll ¶
StringArrayEncodeAll encodes src into b, returning b and any error encountered. The returned slice may be of a different length and capacity to b.
Currently only the string compression scheme used snappy.
func TimeArrayEncodeAll ¶
TimeArrayEncodeAll encodes src into b, returning b and any error encountered. The returned slice may be of a different length and capacity to b.
TimeArrayEncodeAll implements batch oriented versions of the three integer encoding types we support: uncompressed, simple8b and RLE.
Timestamp values to be encoded should be sorted before encoding. When encoded, the values are first delta-encoded. The first value is the starting timestamp, subsequent values are the difference from the prior value.
Important: TimeArrayEncodeAll modifies the contents of src by using it as scratch space for delta encoded values. It is NOT SAFE to use src after passing it into TimeArrayEncodeAll.
func UnsignedArrayEncodeAll ¶
UnsignedArrayEncodeAll encodes src into b, returning b and any error encountered. The returned slice may be of a different length and capacity to b.
UnsignedArrayEncodeAll implements batch oriented versions of the three integer encoding types we support: uncompressed, simple8b and RLE.
Important: IntegerArrayEncodeAll modifies the contents of src by using it as scratch space for delta encoded values. It is NOT SAFE to use src after passing it into IntegerArrayEncodeAll.
func WALCollectors ¶ added in v2.2.0
func WALCollectors() []prometheus.Collector
func ZigZagDecode ¶
ZigZagDecode converts a previously zigzag encoded uint64 back to a int64.
func ZigZagEncode ¶
ZigZagEncode converts a int64 to a uint64 by zig zagging negative and positive values across even and odd numbers. Eg. [0,-1,1,-2] becomes [0, 1, 2, 3].
Types ¶
type BatchDeleter ¶
type BatchDeleters ¶
type BatchDeleters []BatchDeleter
func (BatchDeleters) Commit ¶
func (a BatchDeleters) Commit() error
func (BatchDeleters) DeleteRange ¶
func (a BatchDeleters) DeleteRange(keys [][]byte, min, max int64) error
func (BatchDeleters) Rollback ¶
func (a BatchDeleters) Rollback() error
type BitReader ¶
type BitReader struct {
// contains filtered or unexported fields
}
BitReader reads bits from an io.Reader.
func NewBitReader ¶
NewBitReader returns a new instance of BitReader that reads from data.
func (*BitReader) CanReadBitFast ¶
CanReadBitFast returns true if calling ReadBitFast() is allowed. Fast bit reads are allowed when at least 2 values are in the buffer. This is because it is not required to refilled the buffer and the caller can inline the calls.
func (*BitReader) ReadBitFast ¶
ReadBitFast is an optimized bit read. IMPORTANT: Only allowed if CanReadFastBit() is true!
type BlockIterator ¶
type BlockIterator struct {
// contains filtered or unexported fields
}
BlockIterator allows iterating over each block in a TSM file in order. It provides raw access to the block bytes without decoding them.
func (*BlockIterator) Err ¶
func (b *BlockIterator) Err() error
Err returns any errors encounter during iteration.
func (*BlockIterator) Next ¶
func (b *BlockIterator) Next() bool
Next returns true if there are more blocks to iterate through.
func (*BlockIterator) PeekNext ¶
func (b *BlockIterator) PeekNext() []byte
PeekNext returns the next key to be iterated or an empty string.
type BooleanDecoder ¶
type BooleanDecoder struct {
// contains filtered or unexported fields
}
BooleanDecoder decodes a series of booleans from an in-memory buffer.
func (*BooleanDecoder) Error ¶
func (e *BooleanDecoder) Error() error
Error returns the error encountered during decoding, if one occurred.
func (*BooleanDecoder) Next ¶
func (e *BooleanDecoder) Next() bool
Next returns whether there are any bits remaining in the decoder. It returns false if there was an error decoding. The error is available on the Error method.
func (*BooleanDecoder) Read ¶
func (e *BooleanDecoder) Read() bool
Read returns the next bit from the decoder.
func (*BooleanDecoder) SetBytes ¶
func (e *BooleanDecoder) SetBytes(b []byte)
SetBytes initializes the decoder with a new set of bytes to read from. This must be called before calling any other methods.
type BooleanEncoder ¶
type BooleanEncoder struct {
// contains filtered or unexported fields
}
BooleanEncoder encodes a series of booleans to an in-memory buffer.
func NewBooleanEncoder ¶
func NewBooleanEncoder(sz int) BooleanEncoder
NewBooleanEncoder returns a new instance of BooleanEncoder.
func (*BooleanEncoder) Bytes ¶
func (e *BooleanEncoder) Bytes() ([]byte, error)
Bytes returns a new byte slice containing the encoded booleans from previous calls to Write.
func (*BooleanEncoder) Reset ¶
func (e *BooleanEncoder) Reset()
Reset sets the encoder to its initial state.
func (*BooleanEncoder) Write ¶
func (e *BooleanEncoder) Write(b bool)
Write encodes b to the underlying buffer.
type BooleanValue ¶
type BooleanValue struct {
// contains filtered or unexported fields
}
BooleanValue represents a boolean value.
func DecodeBooleanBlock ¶
func DecodeBooleanBlock(block []byte, a *[]BooleanValue) ([]BooleanValue, error)
DecodeBooleanBlock decodes the boolean block from the byte slice and appends the boolean values to a.
func (BooleanValue) RawValue ¶
func (v BooleanValue) RawValue() bool
func (BooleanValue) Size ¶
func (v BooleanValue) Size() int
Size returns the number of bytes necessary to represent the value and its timestamp.
func (BooleanValue) String ¶
func (v BooleanValue) String() string
String returns the string representation of the value and its timestamp.
func (BooleanValue) UnixNano ¶
func (v BooleanValue) UnixNano() int64
UnixNano returns the timestamp of the value in nanoseconds since unix epoch.
func (BooleanValue) Value ¶
func (v BooleanValue) Value() interface{}
Value returns the underlying boolean value.
type BooleanValues ¶
type BooleanValues []BooleanValue
BooleanValues represents a slice of Boolean values.
func (BooleanValues) Deduplicate ¶
func (a BooleanValues) Deduplicate() BooleanValues
Deduplicate returns a new slice with any values that have the same timestamp removed. The Value that appears last in the slice is the one that is kept. The returned Values are sorted if necessary.
func (BooleanValues) Exclude ¶
func (a BooleanValues) Exclude(min, max int64) BooleanValues
Exclude returns the subset of values not in [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (BooleanValues) FindRange ¶
func (a BooleanValues) FindRange(min, max int64) (int, int)
FindRange returns the positions where min and max would be inserted into the array. If a[0].UnixNano() > max or a[len-1].UnixNano() < min then FindRange returns (-1, -1) indicating the array is outside the [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (BooleanValues) Include ¶
func (a BooleanValues) Include(min, max int64) BooleanValues
Include returns the subset values between min and max inclusive. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (BooleanValues) Less ¶
func (a BooleanValues) Less(i, j int) bool
func (BooleanValues) MaxTime ¶
func (a BooleanValues) MaxTime() int64
func (BooleanValues) Merge ¶
func (a BooleanValues) Merge(b BooleanValues) BooleanValues
Merge overlays b to top of a. If two values conflict with the same timestamp, b is used. Both a and b must be sorted in ascending order.
func (BooleanValues) MinTime ¶
func (a BooleanValues) MinTime() int64
func (BooleanValues) Size ¶
func (a BooleanValues) Size() int
func (BooleanValues) Swap ¶
func (a BooleanValues) Swap(i, j int)
type Cache ¶
type Cache struct {
// contains filtered or unexported fields
}
Cache maintains an in-memory store of Values for a set of keys.
func NewCache ¶
func NewCache(maxSize uint64, tags tsdb.EngineTags) *Cache
NewCache returns an instance of a cache which will use a maximum of maxSize bytes of memory. Only used for engine caches, never for snapshots. Note tags are for metrics only, so if metrics are not desired tags do not have to be set.
func (*Cache) ApplyEntryFn ¶
ApplyEntryFn applies the function f to each entry in the Cache. ApplyEntryFn calls f on each entry in turn, within the same goroutine. It is safe for use by multiple goroutines.
func (*Cache) ClearSnapshot ¶
ClearSnapshot removes the snapshot cache from the list of flushing caches and adjusts the size.
func (*Cache) Deduplicate ¶
func (c *Cache) Deduplicate()
Deduplicate sorts the snapshot before returning it. The compactor and any queries coming in while it writes will need the values sorted.
func (*Cache) DeleteRange ¶
DeleteRange removes the values for all keys containing points with timestamps between between min and max from the cache.
TODO(edd): Lock usage could possibly be optimised if necessary.
func (*Cache) Free ¶
func (c *Cache) Free()
Free releases the underlying store and memory held by the Cache.
func (*Cache) LastWriteTime ¶
func (*Cache) SetMaxSize ¶
SetMaxSize updates the memory limit of the cache.
func (*Cache) Snapshot ¶
Snapshot takes a snapshot of the current cache, adds it to the slice of caches that are being flushed, and resets the current cache with new values.
func (*Cache) WriteMulti ¶
WriteMulti writes the map of keys and associated values to the cache. This function is goroutine-safe. It returns an error if the cache will exceeded its max size by adding the new values. The write attempts to write as many values as possible. If one key fails, the others can still succeed and an error will be returned.
type CacheLoader ¶
CacheLoader processes a set of WAL segment files, and loads a cache with the data contained within those files. Processing of the supplied files take place in the order they exist in the files slice.
func NewCacheLoader ¶
func NewCacheLoader(files []string) *CacheLoader
NewCacheLoader returns a new instance of a CacheLoader.
func (*CacheLoader) Load ¶
func (cl *CacheLoader) Load(cache *Cache) error
Load returns a cache loaded with the data contained within the segment files. If, during reading of a segment file, corruption is encountered, that segment file is truncated up to and including the last valid byte, and processing continues with the next segment file.
func (*CacheLoader) WithLogger ¶
func (cl *CacheLoader) WithLogger(log *zap.Logger)
WithLogger sets the logger on the CacheLoader.
type CompactionGroup ¶
type CompactionGroup []string
CompactionGroup represents a list of files eligible to be compacted together.
type CompactionPlanner ¶
type CompactionPlanner interface { Plan(lastWrite time.Time) ([]CompactionGroup, int64) PlanLevel(level int) ([]CompactionGroup, int64) PlanOptimize() ([]CompactionGroup, int64) Release(group []CompactionGroup) FullyCompacted() (bool, string) // ForceFull causes the planner to return a full compaction plan the next // time Plan() is called if there are files that could be compacted. ForceFull() SetFileStore(fs *FileStore) }
CompactionPlanner determines what TSM files and WAL segments to include in a given compaction run.
type Compactor ¶
type Compactor struct { Dir string Size int FileStore interface { NextGeneration() int TSMReader(path string) (*TSMReader, error) } // RateLimit is the limit for disk writes for all concurrent compactions. RateLimit limiter.Rate // contains filtered or unexported fields }
Compactor merges multiple TSM files into new files or writes a Cache into 1 or more TSM files.
func NewCompactor ¶
func NewCompactor() *Compactor
NewCompactor returns a new instance of Compactor.
func (*Compactor) CompactFast ¶
CompactFast writes multiple smaller TSM files into 1 or more larger files.
func (*Compactor) CompactFull ¶
CompactFull writes multiple smaller TSM files into 1 or more larger files.
func (*Compactor) DisableCompactions ¶
func (c *Compactor) DisableCompactions()
DisableSnapshots disables the compactor from performing compactions.
func (*Compactor) DisableSnapshots ¶
func (c *Compactor) DisableSnapshots()
DisableSnapshots disables the compactor from performing snapshots.
func (*Compactor) EnableCompactions ¶
func (c *Compactor) EnableCompactions()
EnableCompactions allows the compactor to perform compactions.
func (*Compactor) EnableSnapshots ¶
func (c *Compactor) EnableSnapshots()
EnableSnapshots allows the compactor to perform snapshots.
func (*Compactor) WithFormatFileNameFunc ¶
func (c *Compactor) WithFormatFileNameFunc(formatFileNameFunc FormatFileNameFunc)
func (*Compactor) WithParseFileNameFunc ¶
func (c *Compactor) WithParseFileNameFunc(parseFileNameFunc ParseFileNameFunc)
type DefaultPlanner ¶
type DefaultPlanner struct { FileStore fileStore // contains filtered or unexported fields }
DefaultPlanner implements CompactionPlanner using a strategy to roll up multiple generations of TSM files into larger files in stages. It attempts to minimize the number of TSM files on disk while rolling up a bounder number of files.
func NewDefaultPlanner ¶
func NewDefaultPlanner(fs fileStore, writeColdDuration time.Duration) *DefaultPlanner
func (*DefaultPlanner) ForceFull ¶
func (c *DefaultPlanner) ForceFull()
ForceFull causes the planner to return a full compaction plan the next time a plan is requested. When ForceFull is called, level and optimize plans will not return plans until a full plan is requested and released.
func (*DefaultPlanner) FullyCompacted ¶
func (c *DefaultPlanner) FullyCompacted() (bool, string)
FullyCompacted returns true if the shard is fully compacted.
func (*DefaultPlanner) ParseFileName ¶
func (c *DefaultPlanner) ParseFileName(path string) (int, int, error)
func (*DefaultPlanner) Plan ¶
func (c *DefaultPlanner) Plan(lastWrite time.Time) ([]CompactionGroup, int64)
Plan returns a set of TSM files to rewrite for level 4 or higher. The planning returns multiple groups if possible to allow compactions to run concurrently.
func (*DefaultPlanner) PlanLevel ¶
func (c *DefaultPlanner) PlanLevel(level int) ([]CompactionGroup, int64)
PlanLevel returns a set of TSM files to rewrite for a specific level.
func (*DefaultPlanner) PlanOptimize ¶
func (c *DefaultPlanner) PlanOptimize() ([]CompactionGroup, int64)
PlanOptimize returns all TSM files if they are in different generations in order to optimize the index across TSM files. Each returned compaction group can be compacted concurrently.
func (*DefaultPlanner) Release ¶
func (c *DefaultPlanner) Release(groups []CompactionGroup)
Release removes the files reference in each compaction group allowing new plans to be able to use them.
func (*DefaultPlanner) SetFileStore ¶
func (c *DefaultPlanner) SetFileStore(fs *FileStore)
type DeleteRangeWALEntry ¶
type DeleteRangeWALEntry struct { Keys [][]byte Min, Max int64 // contains filtered or unexported fields }
DeleteRangeWALEntry represents the deletion of multiple series.
func (*DeleteRangeWALEntry) Encode ¶
func (w *DeleteRangeWALEntry) Encode(b []byte) ([]byte, error)
Encode converts the DeleteRangeWALEntry into a byte slice, appending to b.
func (*DeleteRangeWALEntry) MarshalBinary ¶
func (w *DeleteRangeWALEntry) MarshalBinary() ([]byte, error)
MarshalBinary returns a binary representation of the entry in a new byte slice.
func (*DeleteRangeWALEntry) MarshalSize ¶
func (w *DeleteRangeWALEntry) MarshalSize() int
func (*DeleteRangeWALEntry) Type ¶
func (w *DeleteRangeWALEntry) Type() WalEntryType
Type returns DeleteRangeWALEntryType.
func (*DeleteRangeWALEntry) UnmarshalBinary ¶
func (w *DeleteRangeWALEntry) UnmarshalBinary(b []byte) error
UnmarshalBinary deserializes the byte slice into w.
type DeleteWALEntry ¶
type DeleteWALEntry struct { Keys [][]byte // contains filtered or unexported fields }
DeleteWALEntry represents the deletion of multiple series.
func (*DeleteWALEntry) Encode ¶
func (w *DeleteWALEntry) Encode(dst []byte) ([]byte, error)
Encode converts the DeleteWALEntry into a byte slice, appending to dst.
func (*DeleteWALEntry) MarshalBinary ¶
func (w *DeleteWALEntry) MarshalBinary() ([]byte, error)
MarshalBinary returns a binary representation of the entry in a new byte slice.
func (*DeleteWALEntry) MarshalSize ¶
func (w *DeleteWALEntry) MarshalSize() int
func (*DeleteWALEntry) Type ¶
func (w *DeleteWALEntry) Type() WalEntryType
Type returns DeleteWALEntryType.
func (*DeleteWALEntry) UnmarshalBinary ¶
func (w *DeleteWALEntry) UnmarshalBinary(b []byte) error
UnmarshalBinary deserializes the byte slice into w.
type DigestManifest ¶
type DigestManifest struct { // Dir is the directory path this manifest describes. Dir string `json:"dir"` // Entries is a list of files used to generate a digest. Entries DigestManifestEntries `json:"entries"` }
DigestManifest contains a list of tsm files used to generate a digest and information about those files which can be used to verify the associated digest file is still valid.
func NewDigestManifest ¶
func NewDigestManifest(dir string, files []string) (*DigestManifest, error)
NewDigestManifest creates a digest manifest for a shard directory and list of tsm files from that directory.
type DigestManifestEntries ¶
type DigestManifestEntries []*DigestManifestEntry
DigestManifestEntries is a list of entries in a manifest file, ordered by tsm filename.
func (DigestManifestEntries) Len ¶
func (a DigestManifestEntries) Len() int
func (DigestManifestEntries) Less ¶
func (a DigestManifestEntries) Less(i, j int) bool
func (DigestManifestEntries) Swap ¶
func (a DigestManifestEntries) Swap(i, j int)
type DigestManifestEntry ¶
type DigestManifestEntry struct { // Filename is the name of one .tsm file used in digest generation. Filename string `json:"filename"` // Size is the size, in bytes, of the .tsm file. Size int64 `json:"size"` }
func NewDigestManifestEntry ¶
func NewDigestManifestEntry(filename string, size int64) *DigestManifestEntry
NewDigestManifestEntry creates a digest manifest entry initialized with a tsm filename and its size.
type DigestOptions ¶
type DigestReader ¶
type DigestReader struct {
// contains filtered or unexported fields
}
func NewDigestReader ¶
func NewDigestReader(r io.ReadCloser) (*DigestReader, error)
func (*DigestReader) Close ¶
func (r *DigestReader) Close() error
func (*DigestReader) ReadManifest ¶
func (r *DigestReader) ReadManifest() (*DigestManifest, error)
func (*DigestReader) ReadTimeSpan ¶
func (r *DigestReader) ReadTimeSpan() (string, *DigestTimeSpan, error)
type DigestTimeRange ¶
type DigestTimeSpan ¶
type DigestTimeSpan struct {
Ranges []DigestTimeRange
}
func (DigestTimeSpan) Len ¶
func (a DigestTimeSpan) Len() int
func (DigestTimeSpan) Less ¶
func (a DigestTimeSpan) Less(i, j int) bool
func (DigestTimeSpan) Swap ¶
func (a DigestTimeSpan) Swap(i, j int)
type DigestWriter ¶
type DigestWriter struct {
// contains filtered or unexported fields
}
DigestWriter allows for writing a digest of a shard. A digest is a condensed representation of the contents of a shard. It can be scoped to one or more series keys, ranges of times or sets of files.
func NewDigestWriter ¶
func NewDigestWriter(w io.WriteCloser) (*DigestWriter, error)
func (*DigestWriter) Close ¶
func (w *DigestWriter) Close() error
func (*DigestWriter) Flush ¶
func (w *DigestWriter) Flush() error
func (*DigestWriter) WriteManifest ¶
func (w *DigestWriter) WriteManifest(m *DigestManifest) error
func (*DigestWriter) WriteTimeSpan ¶
func (w *DigestWriter) WriteTimeSpan(key string, t *DigestTimeSpan) error
type EmptyValue ¶
type EmptyValue struct{}
EmptyValue is used when there is no appropriate other value.
type Engine ¶
type Engine struct { WAL *WAL Cache *Cache Compactor *Compactor CompactionPlan CompactionPlanner FileStore *FileStore MaxPointsPerBlock int // CacheFlushMemorySizeThreshold specifies the minimum size threshold for // the cache when the engine should write a snapshot to a TSM file CacheFlushMemorySizeThreshold uint64 // CacheFlushWriteColdDuration specifies the length of time after which if // no writes have been committed to the WAL, the engine will write // a snapshot of the cache to a TSM file CacheFlushWriteColdDuration time.Duration // WALEnabled determines whether writes to the WAL are enabled. If this is false, // writes will only exist in the cache and can be lost if a snapshot has not occurred. WALEnabled bool // contains filtered or unexported fields }
Engine represents a storage engine with compressed blocks.
func (*Engine) Backup ¶
Backup writes a tar archive of any TSM files modified since the passed in time to the passed in writer. The basePath will be prepended to the names of the files in the archive. It will force a snapshot of the WAL first then perform the backup with a read lock against the file store. This means that new TSM files will not be able to be created in this shard while the backup is running. For shards that are still actively getting writes, this could cause the WAL to backup, increasing memory usage and eventually rejecting writes.
func (*Engine) CreateCursorIterator ¶
func (*Engine) CreateIterator ¶
func (e *Engine) CreateIterator(ctx context.Context, measurement string, opt query.IteratorOptions) (query.Iterator, error)
CreateIterator returns an iterator for the measurement based on opt.
func (*Engine) CreateSeriesIfNotExists ¶
func (*Engine) CreateSeriesListIfNotExists ¶
func (*Engine) CreateSnapshot ¶
CreateSnapshot will create a temp directory that holds temporary hardlinks to the underlying shard files. skipCacheOk controls whether it is permissible to fail writing out in-memory cache data when a previous snapshot is in progress.
func (*Engine) DeleteMeasurement ¶
DeleteMeasurement deletes a measurement and all related series.
func (*Engine) DeleteSeriesRange ¶
func (e *Engine) DeleteSeriesRange(ctx context.Context, itr tsdb.SeriesIterator, min, max int64) error
DeleteSeriesRange removes the values between min and max (inclusive) from all series
func (*Engine) DeleteSeriesRangeWithPredicate ¶
func (e *Engine) DeleteSeriesRangeWithPredicate( ctx context.Context, itr tsdb.SeriesIterator, predicate func(name []byte, tags models.Tags) (int64, int64, bool), ) error
DeleteSeriesRangeWithPredicate removes the values between min and max (inclusive) from all series for which predicate() returns true. If predicate() is nil, then all values in range are removed.
func (*Engine) Digest ¶
func (e *Engine) Digest() (io.ReadCloser, int64, error)
Digest returns a reader for the shard's digest.
func (*Engine) DiskSize ¶
DiskSize returns the total size in bytes of all TSM and WAL segments on disk.
func (*Engine) ForEachMeasurementName ¶
ForEachMeasurementName iterates over each measurement name in the engine.
func (*Engine) Import ¶
Import reads a tar archive generated by Backup() and adds each file matching basePath as a new TSM file. This obtains a write lock so no operations can be performed while Importing. If the import is successful, a full compaction is scheduled.
func (*Engine) IsIdle ¶
IsIdle returns true if the cache is empty, there are no running compactions and the shard is fully compacted.
func (*Engine) IteratorCost ¶
func (e *Engine) IteratorCost(measurement string, opt query.IteratorOptions) (query.IteratorCost, error)
IteratorCost produces the cost of an iterator.
func (*Engine) LastModified ¶
LastModified returns the time when this shard was last modified.
func (*Engine) LoadMetadataIndex ¶
LoadMetadataIndex loads the shard metadata into memory.
Note, it not safe to call LoadMetadataIndex concurrently. LoadMetadataIndex should only be called when initialising a new Engine.
func (*Engine) MeasurementFieldSet ¶
func (e *Engine) MeasurementFieldSet() *tsdb.MeasurementFieldSet
MeasurementFieldSet returns the measurement field set.
func (*Engine) MeasurementFields ¶
func (e *Engine) MeasurementFields(measurement []byte) *tsdb.MeasurementFields
MeasurementFields returns the measurement fields for a measurement.
func (*Engine) MeasurementNamesByRegex ¶
func (*Engine) MeasurementTagKeysByExpr ¶
func (*Engine) MeasurementsSketches ¶
MeasurementsSketches returns sketches that describe the cardinality of the measurements in this shard and measurements that were in this shard, but have been tombstoned.
func (*Engine) Restore ¶
Restore reads a tar archive generated by Backup(). Only files that match basePath will be copied into the directory. This obtains a write lock so no operations can be performed while restoring.
func (*Engine) ScheduleFullCompaction ¶
ScheduleFullCompaction will force the engine to fully compact all data stored. This will cancel and running compactions and snapshot any data in the cache to TSM files. This is an expensive operation.
func (*Engine) SeriesSketches ¶
SeriesSketches returns sketches that describe the cardinality of the series in this shard and series that were in this shard, but have been tombstoned.
func (*Engine) SetCompactionsEnabled ¶
SetCompactionsEnabled enables compactions on the engine. When disabled all running compactions are aborted and new compactions stop running.
func (*Engine) SetEnabled ¶
SetEnabled sets whether the engine is enabled.
func (*Engine) SetNewReadersBlocked ¶ added in v2.7.7
SetNewReadersBlocked sets if new readers can access the shard. If blocked is true, the number of reader blocks is incremented and new readers will receive an error instead of shard access. If blocked is false, the number of reader blocks is decremented. If the reader blocks drops to 0, then new readers will be granted access to the shard.
func (*Engine) ShouldCompactCache ¶
ShouldCompactCache returns true if the Cache is over its flush threshold or if the passed in lastWriteTime is older than the write cold threshold.
func (*Engine) TagKeyCardinality ¶
func (*Engine) Type ¶
Type returns FieldType for a series. If the series does not exist, ErrUnknownFieldType is returned.
func (*Engine) WithFormatFileNameFunc ¶
func (e *Engine) WithFormatFileNameFunc(formatFileNameFunc FormatFileNameFunc)
func (*Engine) WithLogger ¶
WithLogger sets the logger for the engine.
func (*Engine) WithParseFileNameFunc ¶
func (e *Engine) WithParseFileNameFunc(parseFileNameFunc ParseFileNameFunc)
func (*Engine) WritePoints ¶
WritePoints writes metadata and point data into the engine. It returns an error if new points are added to an existing key.
func (*Engine) WriteSnapshot ¶
WriteSnapshot will snapshot the cache and write a new TSM file with its contents, releasing the snapshot when done.
type FileStat ¶
type FileStat struct { Path string HasTombstone bool Size uint32 LastModified int64 MinTime, MaxTime int64 MinKey, MaxKey []byte }
FileStat holds information about a TSM file on disk.
func (FileStat) ContainsKey ¶
ContainsKey returns true if the min and max keys of the file overlap the arguments min and max.
func (FileStat) OverlapsKeyRange ¶
OverlapsKeyRange returns true if the min and max keys of the file overlap the arguments min and max.
func (FileStat) OverlapsTimeRange ¶
OverlapsTimeRange returns true if the time range of the file intersect min and max.
type FileStore ¶
type FileStore struct {
// contains filtered or unexported fields
}
FileStore is an abstraction around multiple TSM files.
func NewFileStore ¶
func NewFileStore(dir string, tags tsdb.EngineTags) *FileStore
NewFileStore returns a new instance of FileStore based on the given directory.
func (*FileStore) BlockCount ¶
BlockCount returns number of values stored in the block at location idx in the file at path. If path does not match any file in the store, 0 is returned. If idx is out of range for the number of blocks in the file, 0 is returned.
func (*FileStore) CreateSnapshot ¶
CreateSnapshot creates hardlinks for all tsm and tombstone files in the path provided.
func (*FileStore) CurrentGeneration ¶
CurrentGeneration returns the current generation of the TSM files.
func (*FileStore) DeleteRange ¶
DeleteRange removes the values for keys between timestamps min and max. This should only be used with smaller batches of series keys.
func (*FileStore) DiskSizeBytes ¶
func (*FileStore) Files ¶
Files returns the slice of TSM files currently loaded. This is only used for tests, and the files aren't guaranteed to stay valid in the presence of compactions.
func (*FileStore) Free ¶
Free releases any resources held by the FileStore. The resources will be re-acquired if necessary if they are needed after freeing them.
func (*FileStore) InUse ¶ added in v2.7.7
InUse returns true if any files in this FileStore are in-use. InUse can only be called if a new readers have been blocked using SetNewReadersBlocked. This is to avoid a race condition between calling InUse and attempting an operation that requires no active readers. Calling InUse without a new readers block results in an error.
func (*FileStore) KeyCursor ¶
KeyCursor returns a KeyCursor for key and t across the files in the FileStore.
func (*FileStore) LastModified ¶
LastModified returns the last time the file store was updated with new TSM files or a delete.
func (*FileStore) MakeSnapshotLinks ¶ added in v2.0.9
MakeSnapshotLinks creates hardlinks from the supplied TSMFiles to corresponding files under a supplied directory.
func (*FileStore) NextGeneration ¶
NextGeneration increments the max file ID and returns the new value.
func (*FileStore) Read ¶
Read returns the slice of values for the given key and the given timestamp, if any file matches those constraints.
func (*FileStore) ReplaceWithCallback ¶
func (f *FileStore) ReplaceWithCallback(oldFiles, newFiles []string, updatedFn func(r []TSMFile)) error
ReplaceWithCallback replaces oldFiles with newFiles and calls updatedFn with the files to be added the FileStore.
func (*FileStore) SetNewReadersBlocked ¶ added in v2.7.7
SetNewReadersBlocked sets if new readers can access the files in this FileStore. If blocked is true, the number of reader blocks is incremented and new readers will receive an error instead of reader access. If blocked is false, the number of reader blocks is decremented. If the reader blocks drops to 0, then new readers will be granted access to the files.
func (*FileStore) Stats ¶
Stats returns the stats of the underlying files, preferring the cached version if it is still valid.
func (*FileStore) TSMReader ¶
Reader returns a TSMReader for path if one is currently managed by the FileStore. Otherwise it returns nil. If it returns a file, you must call Unref on it when you are done, and never use it after that.
func (*FileStore) WalkKeys ¶
WalkKeys calls fn for every key in every TSM file known to the FileStore. If the key exists in multiple files, it will be invoked for each file.
func (*FileStore) WithLogger ¶
WithLogger sets the logger on the file store.
func (*FileStore) WithObserver ¶
func (f *FileStore) WithObserver(obs tsdb.FileStoreObserver)
WithObserver sets the observer for the file store.
func (*FileStore) WithParseFileNameFunc ¶
func (f *FileStore) WithParseFileNameFunc(parseFileNameFunc ParseFileNameFunc)
type FloatDecoder ¶
type FloatDecoder struct {
// contains filtered or unexported fields
}
FloatDecoder decodes a byte slice into multiple float64 values.
func (*FloatDecoder) Error ¶
func (it *FloatDecoder) Error() error
Error returns the current decoding error.
func (*FloatDecoder) Next ¶
func (it *FloatDecoder) Next() bool
Next returns true if there are remaining values to read.
func (*FloatDecoder) SetBytes ¶
func (it *FloatDecoder) SetBytes(b []byte) error
SetBytes initializes the decoder with b. Must call before calling Next().
func (*FloatDecoder) Values ¶
func (it *FloatDecoder) Values() float64
Values returns the current float64 value.
type FloatEncoder ¶
type FloatEncoder struct {
// contains filtered or unexported fields
}
FloatEncoder encodes multiple float64s into a byte slice.
func NewFloatEncoder ¶
func NewFloatEncoder() *FloatEncoder
NewFloatEncoder returns a new FloatEncoder.
func (*FloatEncoder) Bytes ¶
func (s *FloatEncoder) Bytes() ([]byte, error)
Bytes returns a copy of the underlying byte buffer used in the encoder.
func (*FloatEncoder) Flush ¶
func (s *FloatEncoder) Flush()
Flush indicates there are no more values to encode.
func (*FloatEncoder) Reset ¶
func (s *FloatEncoder) Reset()
Reset sets the encoder back to its initial state.
func (*FloatEncoder) Write ¶
func (s *FloatEncoder) Write(v float64)
Write encodes v to the underlying buffer.
type FloatValue ¶
type FloatValue struct {
// contains filtered or unexported fields
}
FloatValue represents a float64 value.
func DecodeFloatBlock ¶
func DecodeFloatBlock(block []byte, a *[]FloatValue) ([]FloatValue, error)
DecodeFloatBlock decodes the float block from the byte slice and appends the float values to a.
func (FloatValue) RawValue ¶
func (v FloatValue) RawValue() float64
func (FloatValue) Size ¶
func (v FloatValue) Size() int
Size returns the number of bytes necessary to represent the value and its timestamp.
func (FloatValue) String ¶
func (v FloatValue) String() string
String returns the string representation of the value and its timestamp.
func (FloatValue) UnixNano ¶
func (v FloatValue) UnixNano() int64
UnixNano returns the timestamp of the value.
func (FloatValue) Value ¶
func (v FloatValue) Value() interface{}
Value returns the underlying float64 value.
type FloatValues ¶
type FloatValues []FloatValue
FloatValues represents a slice of Float values.
func (FloatValues) Deduplicate ¶
func (a FloatValues) Deduplicate() FloatValues
Deduplicate returns a new slice with any values that have the same timestamp removed. The Value that appears last in the slice is the one that is kept. The returned Values are sorted if necessary.
func (FloatValues) Exclude ¶
func (a FloatValues) Exclude(min, max int64) FloatValues
Exclude returns the subset of values not in [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (FloatValues) FindRange ¶
func (a FloatValues) FindRange(min, max int64) (int, int)
FindRange returns the positions where min and max would be inserted into the array. If a[0].UnixNano() > max or a[len-1].UnixNano() < min then FindRange returns (-1, -1) indicating the array is outside the [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (FloatValues) Include ¶
func (a FloatValues) Include(min, max int64) FloatValues
Include returns the subset values between min and max inclusive. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (FloatValues) Less ¶
func (a FloatValues) Less(i, j int) bool
func (FloatValues) MaxTime ¶
func (a FloatValues) MaxTime() int64
func (FloatValues) Merge ¶
func (a FloatValues) Merge(b FloatValues) FloatValues
Merge overlays b to top of a. If two values conflict with the same timestamp, b is used. Both a and b must be sorted in ascending order.
func (FloatValues) MinTime ¶
func (a FloatValues) MinTime() int64
func (FloatValues) Size ¶
func (a FloatValues) Size() int
func (FloatValues) Swap ¶
func (a FloatValues) Swap(i, j int)
type FormatFileNameFunc ¶
FormatFileNameFunc is executed when generating a new TSM filename. Source filenames are provided via src.
type IndexEntry ¶
type IndexEntry struct {
// The min and max time of all points stored in the block.
MinTime, MaxTime int64
// The absolute position in the file where this block is located.
Offset int64
// The size in bytes of the block in the file.
Size uint32
}
IndexEntry is the index information for a given block in a TSM file.
func (*IndexEntry) AppendTo ¶
func (e *IndexEntry) AppendTo(b []byte) []byte
AppendTo writes a binary-encoded version of IndexEntry to b, allocating and returning a new slice, if necessary.
func (*IndexEntry) Contains ¶
func (e *IndexEntry) Contains(t int64) bool
Contains returns true if this IndexEntry may contain values for the given time. The min and max times are inclusive.
func (*IndexEntry) OverlapsTimeRange ¶
func (e *IndexEntry) OverlapsTimeRange(min, max int64) bool
OverlapsTimeRange returns true if the given time ranges are completely within the entry's time bounds.
func (*IndexEntry) String ¶
func (e *IndexEntry) String() string
String returns a string representation of the entry.
func (*IndexEntry) UnmarshalBinary ¶
func (e *IndexEntry) UnmarshalBinary(b []byte) error
UnmarshalBinary decodes an IndexEntry from a byte slice.
type IndexWriter ¶
type IndexWriter interface { // Add records a new block entry for a key in the index. Add(key []byte, blockType byte, minTime, maxTime int64, offset int64, size uint32) // Entries returns all index entries for a key. Entries(key []byte) []IndexEntry // KeyCount returns the count of unique keys in the index. KeyCount() int // Size returns the size of a the current index in bytes. Size() uint32 // MarshalBinary returns a byte slice encoded version of the index. MarshalBinary() ([]byte, error) // WriteTo writes the index contents to a writer. WriteTo(w io.Writer) (int64, error) Close() error Remove() error }
IndexWriter writes a TSMIndex.
func NewDiskIndexWriter ¶
func NewDiskIndexWriter(f *os.File) IndexWriter
NewIndexWriter returns a new IndexWriter.
type IntegerDecoder ¶
type IntegerDecoder struct {
// contains filtered or unexported fields
}
IntegerDecoder decodes a byte slice into int64s.
func (*IntegerDecoder) Error ¶
func (d *IntegerDecoder) Error() error
Error returns the last error encountered by the decoder.
func (*IntegerDecoder) Next ¶
func (d *IntegerDecoder) Next() bool
Next returns true if there are any values remaining to be decoded.
func (*IntegerDecoder) Read ¶
func (d *IntegerDecoder) Read() int64
Read returns the next value from the decoder.
func (*IntegerDecoder) SetBytes ¶
func (d *IntegerDecoder) SetBytes(b []byte)
SetBytes sets the underlying byte slice of the decoder.
type IntegerEncoder ¶
type IntegerEncoder struct {
// contains filtered or unexported fields
}
IntegerEncoder encodes int64s into byte slices.
func NewIntegerEncoder ¶
func NewIntegerEncoder(sz int) IntegerEncoder
NewIntegerEncoder returns a new integer encoder with an initial buffer of values sized at sz.
func (*IntegerEncoder) Bytes ¶
func (e *IntegerEncoder) Bytes() ([]byte, error)
Bytes returns a copy of the underlying buffer.
func (*IntegerEncoder) Reset ¶
func (e *IntegerEncoder) Reset()
Reset sets the encoder back to its initial state.
func (*IntegerEncoder) Write ¶
func (e *IntegerEncoder) Write(v int64)
Write encodes v to the underlying buffers.
type IntegerValue ¶
type IntegerValue struct {
// contains filtered or unexported fields
}
IntegerValue represents an int64 value.
func DecodeIntegerBlock ¶
func DecodeIntegerBlock(block []byte, a *[]IntegerValue) ([]IntegerValue, error)
DecodeIntegerBlock decodes the integer block from the byte slice and appends the integer values to a.
func (IntegerValue) RawValue ¶
func (v IntegerValue) RawValue() int64
func (IntegerValue) Size ¶
func (v IntegerValue) Size() int
Size returns the number of bytes necessary to represent the value and its timestamp.
func (IntegerValue) String ¶
func (v IntegerValue) String() string
String returns the string representation of the value and its timestamp.
func (IntegerValue) UnixNano ¶
func (v IntegerValue) UnixNano() int64
UnixNano returns the timestamp of the value.
func (IntegerValue) Value ¶
func (v IntegerValue) Value() interface{}
Value returns the underlying int64 value.
type IntegerValues ¶
type IntegerValues []IntegerValue
IntegerValues represents a slice of Integer values.
func (IntegerValues) Deduplicate ¶
func (a IntegerValues) Deduplicate() IntegerValues
Deduplicate returns a new slice with any values that have the same timestamp removed. The Value that appears last in the slice is the one that is kept. The returned Values are sorted if necessary.
func (IntegerValues) Exclude ¶
func (a IntegerValues) Exclude(min, max int64) IntegerValues
Exclude returns the subset of values not in [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (IntegerValues) FindRange ¶
func (a IntegerValues) FindRange(min, max int64) (int, int)
FindRange returns the positions where min and max would be inserted into the array. If a[0].UnixNano() > max or a[len-1].UnixNano() < min then FindRange returns (-1, -1) indicating the array is outside the [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (IntegerValues) Include ¶
func (a IntegerValues) Include(min, max int64) IntegerValues
Include returns the subset values between min and max inclusive. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (IntegerValues) Less ¶
func (a IntegerValues) Less(i, j int) bool
func (IntegerValues) MaxTime ¶
func (a IntegerValues) MaxTime() int64
func (IntegerValues) Merge ¶
func (a IntegerValues) Merge(b IntegerValues) IntegerValues
Merge overlays b to top of a. If two values conflict with the same timestamp, b is used. Both a and b must be sorted in ascending order.
func (IntegerValues) MinTime ¶
func (a IntegerValues) MinTime() int64
func (IntegerValues) Size ¶
func (a IntegerValues) Size() int
func (IntegerValues) Swap ¶
func (a IntegerValues) Swap(i, j int)
type KeyCursor ¶
type KeyCursor struct {
// contains filtered or unexported fields
}
KeyCursor allows iteration through keys in a set of files within a FileStore.
func (*KeyCursor) Next ¶
func (c *KeyCursor) Next()
Next moves the cursor to the next position. Data should be read by the ReadBlock functions.
func (*KeyCursor) ReadBooleanArrayBlock ¶
func (c *KeyCursor) ReadBooleanArrayBlock(values *tsdb.BooleanArray) (*tsdb.BooleanArray, error)
ReadBooleanArrayBlock reads the next block as a set of boolean values.
func (*KeyCursor) ReadBooleanBlock ¶
func (c *KeyCursor) ReadBooleanBlock(buf *[]BooleanValue) ([]BooleanValue, error)
ReadBooleanBlock reads the next block as a set of boolean values.
func (*KeyCursor) ReadFloatArrayBlock ¶
func (c *KeyCursor) ReadFloatArrayBlock(values *tsdb.FloatArray) (*tsdb.FloatArray, error)
ReadFloatArrayBlock reads the next block as a set of float values.
func (*KeyCursor) ReadFloatBlock ¶
func (c *KeyCursor) ReadFloatBlock(buf *[]FloatValue) ([]FloatValue, error)
ReadFloatBlock reads the next block as a set of float values.
func (*KeyCursor) ReadIntegerArrayBlock ¶
func (c *KeyCursor) ReadIntegerArrayBlock(values *tsdb.IntegerArray) (*tsdb.IntegerArray, error)
ReadIntegerArrayBlock reads the next block as a set of integer values.
func (*KeyCursor) ReadIntegerBlock ¶
func (c *KeyCursor) ReadIntegerBlock(buf *[]IntegerValue) ([]IntegerValue, error)
ReadIntegerBlock reads the next block as a set of integer values.
func (*KeyCursor) ReadStringArrayBlock ¶
func (c *KeyCursor) ReadStringArrayBlock(values *tsdb.StringArray) (*tsdb.StringArray, error)
ReadStringArrayBlock reads the next block as a set of string values.
func (*KeyCursor) ReadStringBlock ¶
func (c *KeyCursor) ReadStringBlock(buf *[]StringValue) ([]StringValue, error)
ReadStringBlock reads the next block as a set of string values.
func (*KeyCursor) ReadUnsignedArrayBlock ¶
func (c *KeyCursor) ReadUnsignedArrayBlock(values *tsdb.UnsignedArray) (*tsdb.UnsignedArray, error)
ReadUnsignedArrayBlock reads the next block as a set of unsigned values.
func (*KeyCursor) ReadUnsignedBlock ¶
func (c *KeyCursor) ReadUnsignedBlock(buf *[]UnsignedValue) ([]UnsignedValue, error)
ReadUnsignedBlock reads the next block as a set of unsigned values.
type KeyIterator ¶
type KeyIterator interface { // Next returns true if there are any values remaining in the iterator. Next() bool // Read returns the key, time range, and raw data for the next block, // or any error that occurred. Read() (key []byte, minTime int64, maxTime int64, data []byte, err error) // Close closes the iterator. Close() error // Err returns any errors encountered during iteration. Err() error // EstimatedIndexSize returns the estimated size of the index that would // be required to store all the series and entries in the KeyIterator. EstimatedIndexSize() int }
KeyIterator allows iteration over set of keys and values in sorted order.
func NewCacheKeyIterator ¶
func NewCacheKeyIterator(cache *Cache, size int, interrupt chan struct{}) KeyIterator
NewCacheKeyIterator returns a new KeyIterator from a Cache.
func NewTSMBatchKeyIterator ¶
func NewTSMBatchKeyIterator(size int, fast bool, maxErrors int, interrupt chan struct{}, tsmFiles []string, readers ...*TSMReader) (KeyIterator, error)
NewTSMBatchKeyIterator returns a new TSM key iterator from readers. size indicates the maximum number of values to encode in a single block.
type ParseFileNameFunc ¶
ParseFileNameFunc is executed when parsing a TSM filename into generation & sequence.
type Predicate ¶
type Predicate interface { Clone() influxdb.Predicate Matches(key []byte) bool Marshal() ([]byte, error) }
Predicate is something that can match on a series key.
func NewProtobufPredicate ¶
NewProtobufPredicate returns a Predicate that matches based on the comparison structure described by the incoming protobuf.
func UnmarshalPredicate ¶
UnmarshalPredicate takes stored predicate bytes from a Marshal call and returns a Predicate.
type StringDecoder ¶
type StringDecoder struct {
// contains filtered or unexported fields
}
StringDecoder decodes a byte slice into strings.
func (*StringDecoder) Error ¶
func (e *StringDecoder) Error() error
Error returns the last error encountered by the decoder.
func (*StringDecoder) Next ¶
func (e *StringDecoder) Next() bool
Next returns true if there are any values remaining to be decoded.
func (*StringDecoder) Read ¶
func (e *StringDecoder) Read() string
Read returns the next value from the decoder.
func (*StringDecoder) SetBytes ¶
func (e *StringDecoder) SetBytes(b []byte) error
SetBytes initializes the decoder with bytes to read from. This must be called before calling any other method.
type StringEncoder ¶
type StringEncoder struct {
// contains filtered or unexported fields
}
StringEncoder encodes multiple strings into a byte slice.
func NewStringEncoder ¶
func NewStringEncoder(sz int) StringEncoder
NewStringEncoder returns a new StringEncoder with an initial buffer ready to hold sz bytes.
func (*StringEncoder) Bytes ¶
func (e *StringEncoder) Bytes() ([]byte, error)
Bytes returns a copy of the underlying buffer.
func (*StringEncoder) Reset ¶
func (e *StringEncoder) Reset()
Reset sets the encoder back to its initial state.
func (*StringEncoder) Write ¶
func (e *StringEncoder) Write(s string)
Write encodes s to the underlying buffer.
type StringValue ¶
type StringValue struct {
// contains filtered or unexported fields
}
StringValue represents a string value.
func DecodeStringBlock ¶
func DecodeStringBlock(block []byte, a *[]StringValue) ([]StringValue, error)
DecodeStringBlock decodes the string block from the byte slice and appends the string values to a.
func (StringValue) RawValue ¶
func (v StringValue) RawValue() string
func (StringValue) Size ¶
func (v StringValue) Size() int
Size returns the number of bytes necessary to represent the value and its timestamp.
func (StringValue) String ¶
func (v StringValue) String() string
String returns the string representation of the value and its timestamp.
func (StringValue) UnixNano ¶
func (v StringValue) UnixNano() int64
UnixNano returns the timestamp of the value.
func (StringValue) Value ¶
func (v StringValue) Value() interface{}
Value returns the underlying string value.
type StringValues ¶
type StringValues []StringValue
StringValues represents a slice of String values.
func (StringValues) Deduplicate ¶
func (a StringValues) Deduplicate() StringValues
Deduplicate returns a new slice with any values that have the same timestamp removed. The Value that appears last in the slice is the one that is kept. The returned Values are sorted if necessary.
func (StringValues) Exclude ¶
func (a StringValues) Exclude(min, max int64) StringValues
Exclude returns the subset of values not in [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (StringValues) FindRange ¶
func (a StringValues) FindRange(min, max int64) (int, int)
FindRange returns the positions where min and max would be inserted into the array. If a[0].UnixNano() > max or a[len-1].UnixNano() < min then FindRange returns (-1, -1) indicating the array is outside the [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (StringValues) Include ¶
func (a StringValues) Include(min, max int64) StringValues
Include returns the subset values between min and max inclusive. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (StringValues) Less ¶
func (a StringValues) Less(i, j int) bool
func (StringValues) MaxTime ¶
func (a StringValues) MaxTime() int64
func (StringValues) Merge ¶
func (a StringValues) Merge(b StringValues) StringValues
Merge overlays b to top of a. If two values conflict with the same timestamp, b is used. Both a and b must be sorted in ascending order.
func (StringValues) MinTime ¶
func (a StringValues) MinTime() int64
func (StringValues) Size ¶
func (a StringValues) Size() int
func (StringValues) Swap ¶
func (a StringValues) Swap(i, j int)
type TSMFile ¶
type TSMFile interface { // Path returns the underlying file path for the TSMFile. If the file // has not be written or loaded from disk, the zero value is returned. Path() string // Read returns all the values in the block where time t resides. Read(key []byte, t int64) ([]Value, error) // ReadAt returns all the values in the block identified by entry. ReadAt(entry *IndexEntry, values []Value) ([]Value, error) ReadFloatBlockAt(entry *IndexEntry, values *[]FloatValue) ([]FloatValue, error) ReadFloatArrayBlockAt(entry *IndexEntry, values *tsdb.FloatArray) error ReadIntegerBlockAt(entry *IndexEntry, values *[]IntegerValue) ([]IntegerValue, error) ReadIntegerArrayBlockAt(entry *IndexEntry, values *tsdb.IntegerArray) error ReadUnsignedBlockAt(entry *IndexEntry, values *[]UnsignedValue) ([]UnsignedValue, error) ReadUnsignedArrayBlockAt(entry *IndexEntry, values *tsdb.UnsignedArray) error ReadStringBlockAt(entry *IndexEntry, values *[]StringValue) ([]StringValue, error) ReadStringArrayBlockAt(entry *IndexEntry, values *tsdb.StringArray) error ReadBooleanBlockAt(entry *IndexEntry, values *[]BooleanValue) ([]BooleanValue, error) ReadBooleanArrayBlockAt(entry *IndexEntry, values *tsdb.BooleanArray) error // Entries returns the index entries for all blocks for the given key. Entries(key []byte) []IndexEntry ReadEntries(key []byte, entries *[]IndexEntry) []IndexEntry // Returns true if the TSMFile may contain a value with the specified // key and time. ContainsValue(key []byte, t int64) bool // Contains returns true if the file contains any values for the given // key. Contains(key []byte) bool // OverlapsTimeRange returns true if the time range of the file intersect min and max. OverlapsTimeRange(min, max int64) bool // OverlapsKeyRange returns true if the key range of the file intersects min and max. OverlapsKeyRange(min, max []byte) bool // TimeRange returns the min and max time across all keys in the file. TimeRange() (int64, int64) // TombstoneRange returns ranges of time that are deleted for the given key. TombstoneRange(key []byte) []TimeRange // KeyRange returns the min and max keys in the file. KeyRange() ([]byte, []byte) // KeyCount returns the number of distinct keys in the file. KeyCount() int // Seek returns the position in the index with the key <= key. Seek(key []byte) int // KeyAt returns the key located at index position idx. KeyAt(idx int) ([]byte, byte) // Type returns the block type of the values stored for the key. Returns one of // BlockFloat64, BlockInt64, BlockBoolean, BlockString. If key does not exist, // an error is returned. Type(key []byte) (byte, error) // BatchDelete return a BatchDeleter that allows for multiple deletes in batches // and group commit or rollback. BatchDelete() BatchDeleter // Delete removes the keys from the set of keys available in this file. Delete(keys [][]byte) error // DeleteRange removes the values for keys between timestamps min and max. DeleteRange(keys [][]byte, min, max int64) error // HasTombstones returns true if file contains values that have been deleted. HasTombstones() bool // TombstoneStats returns the tombstone filestats if there are any tombstones // written for this file. TombstoneStats() TombstoneStat // Close closes the underlying file resources. Close() error // Size returns the size of the file on disk in bytes. Size() uint32 // Rename renames the existing TSM file to a new name and replaces the mmap backing slice using the new // file name. Index and Reader state are not re-initialized. Rename(path string) error // Remove deletes the file from the filesystem. Remove() error // InUse returns true if the file is currently in use by queries. InUse() bool // Ref records that this file is actively in use. Ref() // Unref records that this file is no longer in use. Unref() // Stats returns summary information about the TSM file. Stats() FileStat // BlockIterator returns an iterator pointing to the first block in the file and // allows sequential iteration to each and every block. BlockIterator() *BlockIterator // Free releases any resources held by the FileStore to free up system resources. Free() error }
TSMFile represents an on-disk TSM file.
type TSMIndex ¶
type TSMIndex interface { // Delete removes the given keys from the index. Delete(keys [][]byte) // DeleteRange removes the given keys with data between minTime and maxTime from the index. DeleteRange(keys [][]byte, minTime, maxTime int64) // ContainsKey returns true if the given key may exist in the index. This func is faster than // Contains but, may return false positives. ContainsKey(key []byte) bool // Contains return true if the given key exists in the index. Contains(key []byte) bool // ContainsValue returns true if key and time might exist in this file. This function could // return true even though the actual point does not exists. For example, the key may // exist in this file, but not have a point exactly at time t. ContainsValue(key []byte, timestamp int64) bool // Entries returns all index entries for a key. Entries(key []byte) []IndexEntry // ReadEntries reads the index entries for key into entries. ReadEntries(key []byte, entries *[]IndexEntry) []IndexEntry // Entry returns the index entry for the specified key and timestamp. If no entry // matches the key and timestamp, nil is returned. Entry(key []byte, timestamp int64) *IndexEntry // Key returns the key in the index at the given position, using entries to avoid allocations. Key(index int, entries *[]IndexEntry) ([]byte, byte, []IndexEntry) // KeyAt returns the key in the index at the given position. KeyAt(index int) ([]byte, byte) // KeyCount returns the count of unique keys in the index. KeyCount() int // Seek returns the position in the index where key <= value in the index. Seek(key []byte) int // OverlapsTimeRange returns true if the time range of the file intersect min and max. OverlapsTimeRange(min, max int64) bool // OverlapsKeyRange returns true if the min and max keys of the file overlap the arguments min and max. OverlapsKeyRange(min, max []byte) bool // Size returns the size of the current index in bytes. Size() uint32 // TimeRange returns the min and max time across all keys in the file. TimeRange() (int64, int64) // TombstoneRange returns ranges of time that are deleted for the given key. TombstoneRange(key []byte) []TimeRange // KeyRange returns the min and max keys in the file. KeyRange() ([]byte, []byte) // Type returns the block type of the values stored for the key. Returns one of // BlockFloat64, BlockInt64, BlockBool, BlockString. If key does not exist, // an error is returned. Type(key []byte) (byte, error) // UnmarshalBinary populates an index from an encoded byte slice // representation of an index. UnmarshalBinary(b []byte) error // Close closes the index and releases any resources. Close() error }
TSMIndex represent the index section of a TSM file. The index records all blocks, their locations, sizes, min and max times.
type TSMReader ¶
type TSMReader struct {
// contains filtered or unexported fields
}
TSMReader is a reader for a TSM file.
func NewTSMReader ¶
NewTSMReader returns a new TSMReader from the given file.
func (*TSMReader) BatchDelete ¶
func (r *TSMReader) BatchDelete() BatchDeleter
BatchDelete returns a BatchDeleter. Only a single goroutine may run a BatchDelete at a time. Callers must either Commit or Rollback the operation.
func (*TSMReader) BlockIterator ¶
func (t *TSMReader) BlockIterator() *BlockIterator
BlockIterator returns a BlockIterator for the underlying TSM file.
func (*TSMReader) ContainsValue ¶
ContainsValue returns true if key and time might exists in this file. This function could return true even though the actual point does not exist. For example, the key may exist in this file, but not have a point exactly at time t.
func (*TSMReader) DeleteRange ¶
DeleteRange removes the given points for keys between minTime and maxTime. The series keys passed in must be sorted.
func (*TSMReader) Entries ¶
func (t *TSMReader) Entries(key []byte) []IndexEntry
Entries returns all index entries for key.
func (*TSMReader) HasTombstones ¶
HasTombstones return true if there are any tombstone entries recorded.
func (*TSMReader) Key ¶
func (t *TSMReader) Key(index int, entries *[]IndexEntry) ([]byte, byte, []IndexEntry)
Key returns the key and the underlying entry at the numeric index.
func (*TSMReader) LastModified ¶
LastModified returns the last time the underlying file was modified.
func (*TSMReader) OverlapsKeyRange ¶
OverlapsKeyRange returns true if the key range of the file intersect min and max.
func (*TSMReader) OverlapsTimeRange ¶
OverlapsTimeRange returns true if the time range of the file intersect min and max.
func (*TSMReader) Read ¶
Read returns the values corresponding to the block at the given key and timestamp.
func (*TSMReader) ReadAt ¶
func (t *TSMReader) ReadAt(entry *IndexEntry, vals []Value) ([]Value, error)
ReadAt returns the values corresponding to the given index entry.
func (*TSMReader) ReadBooleanArrayBlockAt ¶
func (t *TSMReader) ReadBooleanArrayBlockAt(entry *IndexEntry, vals *tsdb.BooleanArray) error
ReadBooleanArrayBlockAt fills vals with the boolean values corresponding to the given index entry.
func (*TSMReader) ReadBooleanBlockAt ¶
func (t *TSMReader) ReadBooleanBlockAt(entry *IndexEntry, vals *[]BooleanValue) ([]BooleanValue, error)
ReadBooleanBlockAt returns the boolean values corresponding to the given index entry.
func (*TSMReader) ReadEntries ¶
func (t *TSMReader) ReadEntries(key []byte, entries *[]IndexEntry) []IndexEntry
ReadEntries reads the index entries for key into entries.
func (*TSMReader) ReadFloatArrayBlockAt ¶
func (t *TSMReader) ReadFloatArrayBlockAt(entry *IndexEntry, vals *tsdb.FloatArray) error
ReadFloatArrayBlockAt fills vals with the float values corresponding to the given index entry.
func (*TSMReader) ReadFloatBlockAt ¶
func (t *TSMReader) ReadFloatBlockAt(entry *IndexEntry, vals *[]FloatValue) ([]FloatValue, error)
ReadFloatBlockAt returns the float values corresponding to the given index entry.
func (*TSMReader) ReadIntegerArrayBlockAt ¶
func (t *TSMReader) ReadIntegerArrayBlockAt(entry *IndexEntry, vals *tsdb.IntegerArray) error
ReadIntegerArrayBlockAt fills vals with the integer values corresponding to the given index entry.
func (*TSMReader) ReadIntegerBlockAt ¶
func (t *TSMReader) ReadIntegerBlockAt(entry *IndexEntry, vals *[]IntegerValue) ([]IntegerValue, error)
ReadIntegerBlockAt returns the integer values corresponding to the given index entry.
func (*TSMReader) ReadStringArrayBlockAt ¶
func (t *TSMReader) ReadStringArrayBlockAt(entry *IndexEntry, vals *tsdb.StringArray) error
ReadStringArrayBlockAt fills vals with the string values corresponding to the given index entry.
func (*TSMReader) ReadStringBlockAt ¶
func (t *TSMReader) ReadStringBlockAt(entry *IndexEntry, vals *[]StringValue) ([]StringValue, error)
ReadStringBlockAt returns the string values corresponding to the given index entry.
func (*TSMReader) ReadUnsignedArrayBlockAt ¶
func (t *TSMReader) ReadUnsignedArrayBlockAt(entry *IndexEntry, vals *tsdb.UnsignedArray) error
ReadUnsignedArrayBlockAt fills vals with the unsigned values corresponding to the given index entry.
func (*TSMReader) ReadUnsignedBlockAt ¶
func (t *TSMReader) ReadUnsignedBlockAt(entry *IndexEntry, vals *[]UnsignedValue) ([]UnsignedValue, error)
ReadUnsignedBlockAt returns the unsigned values corresponding to the given index entry.
func (*TSMReader) Ref ¶
func (t *TSMReader) Ref()
Ref records a usage of this TSMReader. If there are active references when the reader is closed or removed, the reader will remain open until there are no more references.
func (*TSMReader) TombstoneRange ¶
TombstoneRange returns ranges of time that are deleted for the given key.
func (*TSMReader) TombstoneStats ¶ added in v2.0.5
func (t *TSMReader) TombstoneStats() TombstoneStat
TombstoneFiles returns any tombstone files associated with this TSM file.
func (*TSMReader) Unref ¶
func (t *TSMReader) Unref()
Unref removes a usage record of this TSMReader. If the Reader was closed by another goroutine while there were active references, the file will be closed and remove
func (*TSMReader) WithObserver ¶
func (t *TSMReader) WithObserver(obs tsdb.FileStoreObserver)
WithObserver sets the observer for the TSM reader.
type TSMWriter ¶
type TSMWriter interface { // Write writes a new block for key containing and values. Writes append // blocks in the order that the Write function is called. The caller is // responsible for ensuring keys and blocks are sorted appropriately. // Values are encoded as a full block. The caller is responsible for // ensuring a fixed number of values are encoded in each block as well as // ensuring the Values are sorted. The first and last timestamp values are // used as the minimum and maximum values for the index entry. Write(key []byte, values Values) error // WriteBlock writes a new block for key containing the bytes in block. WriteBlock appends // blocks in the order that the WriteBlock function is called. The caller is // responsible for ensuring keys and blocks are sorted appropriately, and that the // block and index information is correct for the block. The minTime and maxTime // timestamp values are used as the minimum and maximum values for the index entry. WriteBlock(key []byte, minTime, maxTime int64, block []byte) error // WriteIndex finishes the TSM write streams and writes the index. WriteIndex() error // Flushes flushes all pending changes to the underlying file resources. Flush() error // Close closes any underlying file resources. Close() error // Size returns the current size in bytes of the file. Size() uint32 Remove() error }
TSMWriter writes TSM formatted key and values.
func NewTSMWriter ¶
NewTSMWriter returns a new TSMWriter writing to w.
type TimeDecoder ¶
type TimeDecoder struct {
// contains filtered or unexported fields
}
TimeDecoder decodes a byte slice into timestamps.
func (*TimeDecoder) Error ¶
func (d *TimeDecoder) Error() error
Error returns the last error encountered by the decoder.
func (*TimeDecoder) Init ¶
func (d *TimeDecoder) Init(b []byte)
Init initializes the decoder with bytes to read from.
func (*TimeDecoder) Next ¶
func (d *TimeDecoder) Next() bool
Next returns true if there are any timestamps remaining to be decoded.
func (*TimeDecoder) Read ¶
func (d *TimeDecoder) Read() int64
Read returns the next timestamp from the decoder.
type TimeEncoder ¶
TimeEncoder encodes time.Time to byte slices.
func NewTimeEncoder ¶
func NewTimeEncoder(sz int) TimeEncoder
NewTimeEncoder returns a TimeEncoder with an initial buffer ready to hold sz bytes.
type Tombstone ¶
type Tombstone struct { // Key is the tombstoned series key. Key []byte // Min and Max are the min and max unix nanosecond time ranges of Key that are deleted. If // the full range is deleted, both values are -1. Min, Max int64 }
Tombstone represents an individual deletion.
type TombstoneStat ¶ added in v2.0.5
TombstoneStat holds information about a possible tombstone file on disk.
type Tombstoner ¶
type Tombstoner struct { // Path is the location of the file to record tombstone. This should be the // full path to a TSM file. Path string FilterFn func(k []byte) bool // contains filtered or unexported fields }
Tombstoner records tombstones when entries are deleted.
func NewTombstoner ¶
func NewTombstoner(path string, filterFn func(k []byte) bool) *Tombstoner
NewTombstoner constructs a Tombstoner for the given path. FilterFn can be nil.
func (*Tombstoner) Add ¶
func (t *Tombstoner) Add(keys [][]byte) error
Add adds the all keys, across all timestamps, to the tombstone.
func (*Tombstoner) AddRange ¶
func (t *Tombstoner) AddRange(keys [][]byte, min, max int64) error
AddRange adds all keys to the tombstone specifying only the data between min and max to be removed.
func (*Tombstoner) Delete ¶
func (t *Tombstoner) Delete() error
Delete removes all the tombstone files from disk.
func (*Tombstoner) Flush ¶
func (t *Tombstoner) Flush() error
func (*Tombstoner) HasTombstones ¶
func (t *Tombstoner) HasTombstones() bool
HasTombstones return true if there are any tombstone entries recorded.
func (*Tombstoner) Rollback ¶
func (t *Tombstoner) Rollback() error
func (*Tombstoner) TombstoneStats ¶ added in v2.0.5
func (t *Tombstoner) TombstoneStats() TombstoneStat
TombstoneFiles returns any tombstone files associated with Tombstoner's TSM file.
func (*Tombstoner) Walk ¶
func (t *Tombstoner) Walk(fn func(t Tombstone) error) error
Walk calls fn for every Tombstone under the Tombstoner.
func (*Tombstoner) WithObserver ¶
func (t *Tombstoner) WithObserver(obs tsdb.FileStoreObserver)
WithObserver sets a FileStoreObserver for when the tombstone file is written.
type UnsignedValue ¶
type UnsignedValue struct {
// contains filtered or unexported fields
}
UnsignedValue represents an int64 value.
func DecodeUnsignedBlock ¶
func DecodeUnsignedBlock(block []byte, a *[]UnsignedValue) ([]UnsignedValue, error)
DecodeUnsignedBlock decodes the unsigned integer block from the byte slice and appends the unsigned integer values to a.
func (UnsignedValue) RawValue ¶
func (v UnsignedValue) RawValue() uint64
func (UnsignedValue) Size ¶
func (v UnsignedValue) Size() int
Size returns the number of bytes necessary to represent the value and its timestamp.
func (UnsignedValue) String ¶
func (v UnsignedValue) String() string
String returns the string representation of the value and its timestamp.
func (UnsignedValue) UnixNano ¶
func (v UnsignedValue) UnixNano() int64
UnixNano returns the timestamp of the value.
func (UnsignedValue) Value ¶
func (v UnsignedValue) Value() interface{}
Value returns the underlying int64 value.
type UnsignedValues ¶
type UnsignedValues []UnsignedValue
UnsignedValues represents a slice of Unsigned values.
func (UnsignedValues) Deduplicate ¶
func (a UnsignedValues) Deduplicate() UnsignedValues
Deduplicate returns a new slice with any values that have the same timestamp removed. The Value that appears last in the slice is the one that is kept. The returned Values are sorted if necessary.
func (UnsignedValues) Exclude ¶
func (a UnsignedValues) Exclude(min, max int64) UnsignedValues
Exclude returns the subset of values not in [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (UnsignedValues) FindRange ¶
func (a UnsignedValues) FindRange(min, max int64) (int, int)
FindRange returns the positions where min and max would be inserted into the array. If a[0].UnixNano() > max or a[len-1].UnixNano() < min then FindRange returns (-1, -1) indicating the array is outside the [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (UnsignedValues) Include ¶
func (a UnsignedValues) Include(min, max int64) UnsignedValues
Include returns the subset values between min and max inclusive. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (UnsignedValues) Less ¶
func (a UnsignedValues) Less(i, j int) bool
func (UnsignedValues) MaxTime ¶
func (a UnsignedValues) MaxTime() int64
func (UnsignedValues) Merge ¶
func (a UnsignedValues) Merge(b UnsignedValues) UnsignedValues
Merge overlays b to top of a. If two values conflict with the same timestamp, b is used. Both a and b must be sorted in ascending order.
func (UnsignedValues) MinTime ¶
func (a UnsignedValues) MinTime() int64
func (UnsignedValues) Size ¶
func (a UnsignedValues) Size() int
func (UnsignedValues) Swap ¶
func (a UnsignedValues) Swap(i, j int)
type Value ¶
type Value interface { // UnixNano returns the timestamp of the value in nanoseconds since unix epoch. UnixNano() int64 // Value returns the underlying value. Value() interface{} // Size returns the number of bytes necessary to represent the value and its timestamp. Size() int // String returns the string representation of the value and its timestamp. String() string // contains filtered or unexported methods }
Value represents a TSM-encoded value.
func DecodeBlock ¶
DecodeBlock takes a byte slice and decodes it into values of the appropriate type based on the block.
func NewBooleanValue ¶
NewBooleanValue returns a new boolean value.
func NewFloatValue ¶
NewFloatValue returns a new float value.
func NewIntegerValue ¶
NewIntegerValue returns a new integer value.
func NewStringValue ¶
NewStringValue returns a new string value.
func NewUnsignedValue ¶
NewUnsignedValue returns a new unsigned integer value.
type Values ¶
type Values []Value
Values represents a slice of values.
func (Values) Deduplicate ¶
Deduplicate returns a new slice with any values that have the same timestamp removed. The Value that appears last in the slice is the one that is kept. The returned Values are sorted if necessary.
func (Values) Encode ¶
Encode converts the values to a byte slice. If there are no values, this function panics.
func (Values) Exclude ¶
Exclude returns the subset of values not in [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (Values) FindRange ¶
FindRange returns the positions where min and max would be inserted into the array. If a[0].UnixNano() > max or a[len-1].UnixNano() < min then FindRange returns (-1, -1) indicating the array is outside the [min, max]. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (Values) Include ¶
Include returns the subset values between min and max inclusive. The values must be deduplicated and sorted before calling Exclude or the results are undefined.
func (Values) InfluxQLType ¶
InfluxQLType returns the influxql.DataType the values map to.
type WAL ¶
type WAL struct { // SegmentSize is the file size at which a segment file will be rotated SegmentSize int // contains filtered or unexported fields }
WAL represents the write-ahead log used for writing TSM files.
func NewWAL ¶
func NewWAL(path string, maxConcurrentWrites int, maxWriteDelay time.Duration, tags tsdb.EngineTags) *WAL
NewWAL initializes a new WAL at the given directory.
func (*WAL) Close ¶
Close will finish any flush that is currently in progress and close file handles.
func (*WAL) CloseSegment ¶
CloseSegment closes the current segment if it is non-empty and opens a new one.
func (*WAL) ClosedSegments ¶
ClosedSegments returns a slice of the names of the closed segment files.
func (*WAL) DeleteRange ¶
DeleteRange deletes the given keys within the given time range, returning the segment ID for the operation.
func (*WAL) DiskSizeBytes ¶
func (*WAL) LastWriteTime ¶
LastWriteTime is the last time anything was written to the WAL.
func (*WAL) Open ¶
Open opens and initializes the Log. Open can recover from previous unclosed shutdowns.
func (*WAL) Remove ¶
Remove deletes the given segment file paths from disk and cleans up any associated objects.
func (*WAL) WithLogger ¶
WithLogger sets the WAL's logger.
type WALEntry ¶
type WALEntry interface { Type() WalEntryType Encode(dst []byte) ([]byte, error) MarshalBinary() ([]byte, error) UnmarshalBinary(b []byte) error MarshalSize() int }
WALEntry is record stored in each WAL segment. Each entry has a type and an opaque, type dependent byte slice data attribute.
type WALSegmentReader ¶
type WALSegmentReader struct {
// contains filtered or unexported fields
}
WALSegmentReader reads WAL segments.
func NewWALSegmentReader ¶
func NewWALSegmentReader(r io.ReadCloser) *WALSegmentReader
NewWALSegmentReader returns a new WALSegmentReader reading from r.
func (*WALSegmentReader) Close ¶
func (r *WALSegmentReader) Close() error
Close closes the underlying io.Reader.
func (*WALSegmentReader) Count ¶
func (r *WALSegmentReader) Count() int64
Count returns the total number of bytes read successfully from the segment, as of the last call to Read(). The segment is guaranteed to be valid up to and including this number of bytes.
func (*WALSegmentReader) Error ¶
func (r *WALSegmentReader) Error() error
Error returns the last error encountered by the reader.
func (*WALSegmentReader) Next ¶
func (r *WALSegmentReader) Next() bool
Next indicates if there is a value to read.
func (*WALSegmentReader) Read ¶
func (r *WALSegmentReader) Read() (WALEntry, error)
Read returns the next entry in the reader.
func (*WALSegmentReader) Reset ¶
func (r *WALSegmentReader) Reset(rc io.ReadCloser)
type WALSegmentWriter ¶
type WALSegmentWriter struct {
// contains filtered or unexported fields
}
WALSegmentWriter writes WAL segments.
func NewWALSegmentWriter ¶
func NewWALSegmentWriter(w io.WriteCloser) *WALSegmentWriter
NewWALSegmentWriter returns a new WALSegmentWriter writing to w.
func (*WALSegmentWriter) Flush ¶
func (w *WALSegmentWriter) Flush() error
func (*WALSegmentWriter) Write ¶
func (w *WALSegmentWriter) Write(entryType WalEntryType, compressed []byte) error
Write writes entryType and the buffer containing compressed entry data.
type WalEntryType ¶
type WalEntryType byte
WalEntryType is a byte written to a wal segment file that indicates what the following compressed block contains.
const ( // WriteWALEntryType indicates a write entry. WriteWALEntryType WalEntryType = 0x01 // DeleteWALEntryType indicates a delete entry. DeleteWALEntryType WalEntryType = 0x02 // DeleteRangeWALEntryType indicates a delete range entry. DeleteRangeWALEntryType WalEntryType = 0x03 )
type WriteWALEntry ¶
WriteWALEntry represents a write of points.
func (*WriteWALEntry) Encode ¶
func (w *WriteWALEntry) Encode(dst []byte) ([]byte, error)
Encode converts the WriteWALEntry into a byte stream using dst if it is large enough. If dst is too small, the slice will be grown to fit the encoded entry.
func (*WriteWALEntry) MarshalBinary ¶
func (w *WriteWALEntry) MarshalBinary() ([]byte, error)
MarshalBinary returns a binary representation of the entry in a new byte slice.
func (*WriteWALEntry) MarshalSize ¶
func (w *WriteWALEntry) MarshalSize() int
func (*WriteWALEntry) Type ¶
func (w *WriteWALEntry) Type() WalEntryType
Type returns WriteWALEntryType.
func (*WriteWALEntry) UnmarshalBinary ¶
func (w *WriteWALEntry) UnmarshalBinary(b []byte) error
UnmarshalBinary deserializes the byte slice into w.
Source Files ¶
- array_cursor.gen.go
- array_cursor_iterator.gen.go
- array_cursor_iterator.go
- array_encoding.go
- batch_boolean.go
- batch_float.go
- batch_integer.go
- batch_string.go
- batch_timestamp.go
- bit_reader.go
- bool.go
- cache.go
- compact.gen.go
- compact.go
- digest.go
- digest_reader.go
- digest_writer.go
- encoding.gen.go
- encoding.go
- engine.gen.go
- engine.go
- engine_cursor.go
- file_store.gen.go
- file_store.go
- file_store_array.gen.go
- file_store_key_iterator.go
- file_store_observer.go
- float.go
- int.go
- iterator.gen.go
- iterator.go
- mmap_unix.go
- pools.go
- predicate.go
- reader.gen.go
- reader.go
- ring.go
- scheduler.go
- string.go
- timestamp.go
- tombstone.go
- wal.go
- writer.go