Documentation ¶
Index ¶
- Constants
- Variables
- func AppendSeriesEntry(dst []byte, flag uint8, id SeriesIDTyped, key []byte) []byte
- func AppendSeriesKey(dst []byte, name []byte, tags models.Tags) []byte
- func CompareSeriesKeys(a, b []byte) int
- func DecodeName(name [16]byte) (org, bucket platform.ID)
- func EncodeName(org, bucket platform.ID) [16]byte
- func ExplodePoints(org, bucket platform.ID, points []models.Point) ([]models.Point, error)
- func GenerateSeriesKeys(names [][]byte, tagsSlice []models.Tags) [][]byte
- func IsValidSeriesEntryFlag(flag byte) bool
- func IsValidSeriesSegmentFilename(filename string) bool
- func JoinSeriesOffset(segmentID uint16, pos uint32) int64
- func MakeTagsKey(keys []string, tags models.Tags) []byte
- func MarshalTags(tags map[string]string) []byte
- func NewMeasurementSliceIterator(names [][]byte) *measurementSliceIterator
- func NewSeriesQueryAdapterIterator(sfile *SeriesFile, itr SeriesIDIterator, opt query.IteratorOptions) query.Iterator
- func NewShardError(id uint64, err error) error
- func NewTagKeySliceIterator(keys [][]byte) *tagKeySliceIterator
- func NewTagValueSliceIterator(values [][]byte) *tagValueSliceIterator
- func ParseSeriesKey(data []byte) (name []byte, tags models.Tags)
- func ParseSeriesKeyInto(data []byte, dstTags models.Tags) ([]byte, models.Tags)
- func ParseSeriesSegmentFilename(filename string) (uint16, error)
- func PrometheusCollectors() []prometheus.Collector
- func ReadSeriesKey(data []byte) (key, remainder []byte)
- func ReadSeriesKeyFromSegments(a []*SeriesSegment, offset int64) []byte
- func ReadSeriesKeyLen(data []byte) (sz int, remainder []byte)
- func ReadSeriesKeyMeasurement(data []byte) (name, remainder []byte)
- func ReadSeriesKeyTag(data []byte) (key, value, remainder []byte)
- func ReadSeriesKeyTagN(data []byte) (n int, remainder []byte)
- func SeriesKeySize(name []byte, tags models.Tags) int
- func SeriesKeysSize(names [][]byte, tagsSlice []models.Tags) int
- func SeriesSegmentSize(id uint16) uint32
- func SplitSeriesOffset(offset int64) (segmentID uint16, pos uint32)
- type BooleanArray
- type BooleanArrayCursor
- type ByTagKey
- type Cursor
- type CursorIterator
- type CursorIterators
- type CursorRequest
- type FloatArray
- type FloatArrayCursor
- type IntegerArray
- type IntegerArrayCursor
- type MeasurementIterator
- type MeasurementIterators
- type PartialWriteError
- type SeriesCollection
- func (s *SeriesCollection) Advance(length int)
- func (s *SeriesCollection) ApplyConcurrentDrops()
- func (s *SeriesCollection) Copy(dst, src int)
- func (s SeriesCollection) Duplicate() *SeriesCollection
- func (s *SeriesCollection) InvalidateAll(reason string)
- func (s *SeriesCollection) Iterator() SeriesCollectionIterator
- func (s *SeriesCollection) Length() int
- func (s *SeriesCollection) PartialWriteError() error
- func (s *SeriesCollection) Swap(i, j int)
- func (s *SeriesCollection) Truncate(length int)
- type SeriesCollectionIterator
- func (i SeriesCollectionIterator) Index() int
- func (i *SeriesCollectionIterator) Invalid(reason string)
- func (i SeriesCollectionIterator) Key() []byte
- func (i SeriesCollectionIterator) Length() int
- func (i SeriesCollectionIterator) Name() []byte
- func (i *SeriesCollectionIterator) Next() bool
- func (i SeriesCollectionIterator) Point() models.Point
- func (i SeriesCollectionIterator) SeriesID() SeriesID
- func (i SeriesCollectionIterator) SeriesKey() []byte
- func (i SeriesCollectionIterator) Tags() models.Tags
- func (i SeriesCollectionIterator) Type() models.FieldType
- type SeriesElem
- type SeriesFile
- func (f *SeriesFile) Close() (err error)
- func (f *SeriesFile) CreateSeriesListIfNotExists(collection *SeriesCollection) error
- func (f *SeriesFile) DeleteSeriesID(id SeriesID) error
- func (f *SeriesFile) DisableCompactions()
- func (f *SeriesFile) DisableMetrics()
- func (f *SeriesFile) EnableCompactions()
- func (f *SeriesFile) HasSeries(name []byte, tags models.Tags, buf []byte) bool
- func (f *SeriesFile) IsDeleted(id SeriesID) bool
- func (f *SeriesFile) Open() error
- func (f *SeriesFile) Partitions() []*SeriesPartition
- func (f *SeriesFile) Path() string
- func (f *SeriesFile) Retain() func()
- func (f *SeriesFile) Series(id SeriesID) ([]byte, models.Tags)
- func (f *SeriesFile) SeriesCount() uint64
- func (f *SeriesFile) SeriesID(name []byte, tags models.Tags, buf []byte) SeriesID
- func (f *SeriesFile) SeriesIDIterator() SeriesIDIterator
- func (f *SeriesFile) SeriesIDPartition(id SeriesID) *SeriesPartition
- func (f *SeriesFile) SeriesIDPartitionID(id SeriesID) int
- func (f *SeriesFile) SeriesIDTyped(name []byte, tags models.Tags, buf []byte) SeriesIDTyped
- func (f *SeriesFile) SeriesIDTypedBySeriesKey(key []byte) SeriesIDTyped
- func (f *SeriesFile) SeriesKey(id SeriesID) []byte
- func (f *SeriesFile) SeriesKeyName(id SeriesID) []byte
- func (f *SeriesFile) SeriesKeyPartition(key []byte) *SeriesPartition
- func (f *SeriesFile) SeriesKeyPartitionID(key []byte) int
- func (f *SeriesFile) SeriesKeys(ids []SeriesID) [][]byte
- func (f *SeriesFile) SeriesKeysPartitionIDs(keys [][]byte) []int
- func (f *SeriesFile) SeriesPartitionPath(i int) string
- func (f *SeriesFile) SetDefaultMetricLabels(labels prometheus.Labels)
- func (f *SeriesFile) Wait()
- func (f *SeriesFile) WithLogger(log *zap.Logger)
- type SeriesID
- type SeriesIDElem
- type SeriesIDElems
- type SeriesIDExprIterator
- type SeriesIDIterator
- func DifferenceSeriesIDIterators(itr0, itr1 SeriesIDIterator) SeriesIDIterator
- func FilterUndeletedSeriesIDIterator(sfile *SeriesFile, itr SeriesIDIterator) SeriesIDIterator
- func IntersectSeriesIDIterators(itr0, itr1 SeriesIDIterator) SeriesIDIterator
- func MergeSeriesIDIterators(itrs ...SeriesIDIterator) SeriesIDIterator
- func NewSeriesIDExprIterator(itr SeriesIDIterator, expr influxql.Expr) SeriesIDIterator
- func UnionSeriesIDIterators(itr0, itr1 SeriesIDIterator) SeriesIDIterator
- type SeriesIDIterators
- type SeriesIDSet
- func (s *SeriesIDSet) Add(id SeriesID)
- func (s *SeriesIDSet) AddMany(ids ...SeriesID)
- func (s *SeriesIDSet) AddNoLock(id SeriesID)
- func (s *SeriesIDSet) And(other *SeriesIDSet) *SeriesIDSet
- func (s *SeriesIDSet) AndNot(other *SeriesIDSet) *SeriesIDSet
- func (s *SeriesIDSet) Bytes() int
- func (s *SeriesIDSet) Cardinality() uint64
- func (s *SeriesIDSet) Clear()
- func (s *SeriesIDSet) ClearNoLock()
- func (s *SeriesIDSet) Clone() *SeriesIDSet
- func (s *SeriesIDSet) CloneNoLock() *SeriesIDSet
- func (s *SeriesIDSet) Contains(id SeriesID) bool
- func (s *SeriesIDSet) ContainsNoLock(id SeriesID) bool
- func (s *SeriesIDSet) Diff(other *SeriesIDSet)
- func (s *SeriesIDSet) Equals(other *SeriesIDSet) bool
- func (s *SeriesIDSet) ForEach(f func(id SeriesID))
- func (s *SeriesIDSet) ForEachNoLock(f func(id SeriesID))
- func (s *SeriesIDSet) Iterator() SeriesIDSetIterable
- func (s *SeriesIDSet) Merge(others ...*SeriesIDSet)
- func (s *SeriesIDSet) MergeInPlace(other *SeriesIDSet)
- func (s *SeriesIDSet) Remove(id SeriesID)
- func (s *SeriesIDSet) RemoveNoLock(id SeriesID)
- func (s *SeriesIDSet) SetCOW(b bool)
- func (s *SeriesIDSet) Slice() []uint64
- func (s *SeriesIDSet) String() string
- func (s *SeriesIDSet) UnmarshalBinary(data []byte) error
- func (s *SeriesIDSet) UnmarshalBinaryUnsafe(data []byte) error
- func (s *SeriesIDSet) WriteTo(w io.Writer) (int64, error)
- type SeriesIDSetIterable
- type SeriesIDSetIterator
- type SeriesIDSliceIterator
- type SeriesIDTyped
- type SeriesIndex
- func (idx *SeriesIndex) Clone() *SeriesIndex
- func (idx *SeriesIndex) Close() (err error)
- func (idx *SeriesIndex) Count() uint64
- func (idx *SeriesIndex) Delete(id SeriesID)
- func (idx *SeriesIndex) FindIDByNameTags(segments []*SeriesSegment, name []byte, tags models.Tags, buf []byte) SeriesIDTyped
- func (idx *SeriesIndex) FindIDBySeriesKey(segments []*SeriesSegment, key []byte) SeriesIDTyped
- func (idx *SeriesIndex) FindIDListByNameTags(segments []*SeriesSegment, names [][]byte, tagsSlice []models.Tags, buf []byte) (ids []SeriesIDTyped, ok bool)
- func (idx *SeriesIndex) FindOffsetByID(id SeriesID) int64
- func (idx *SeriesIndex) InMemCount() uint64
- func (idx *SeriesIndex) InMemSize() uint64
- func (idx *SeriesIndex) Insert(key []byte, id SeriesIDTyped, offset int64)
- func (idx *SeriesIndex) IsDeleted(id SeriesID) bool
- func (idx *SeriesIndex) OnDiskCount() uint64
- func (idx *SeriesIndex) OnDiskSize() uint64
- func (idx *SeriesIndex) Open() (err error)
- func (idx *SeriesIndex) Recover(segments []*SeriesSegment) error
- type SeriesIndexHeader
- type SeriesIterator
- type SeriesPartition
- func (p *SeriesPartition) AppendSeriesIDs(a []SeriesID) []SeriesID
- func (p *SeriesPartition) Close() (err error)
- func (p *SeriesPartition) Compacting() bool
- func (p *SeriesPartition) CreateSeriesListIfNotExists(collection *SeriesCollection, keyPartitionIDs []int) error
- func (p *SeriesPartition) DeleteSeriesID(id SeriesID) error
- func (p *SeriesPartition) DisableCompactions()
- func (p *SeriesPartition) DiskSize() uint64
- func (p *SeriesPartition) EnableCompactions()
- func (p *SeriesPartition) FindIDBySeriesKey(key []byte) SeriesID
- func (p *SeriesPartition) FindIDTypedBySeriesKey(key []byte) SeriesIDTyped
- func (p *SeriesPartition) ID() int
- func (p *SeriesPartition) IndexPath() string
- func (p *SeriesPartition) IsDeleted(id SeriesID) bool
- func (p *SeriesPartition) Open() error
- func (p *SeriesPartition) Path() string
- func (p *SeriesPartition) Series(id SeriesID) ([]byte, models.Tags)
- func (p *SeriesPartition) SeriesCount() uint64
- func (p *SeriesPartition) SeriesKey(id SeriesID) []byte
- type SeriesPartitionCompactor
- type SeriesSegment
- func (s *SeriesSegment) AppendSeriesIDs(a []SeriesID) []SeriesID
- func (s *SeriesSegment) CanWrite(data []byte) bool
- func (s *SeriesSegment) Clone() *SeriesSegment
- func (s *SeriesSegment) Close() (err error)
- func (s *SeriesSegment) CloseForWrite() (err error)
- func (s *SeriesSegment) Data() []byte
- func (s *SeriesSegment) Flush() error
- func (s *SeriesSegment) ForEachEntry(fn func(flag uint8, id SeriesIDTyped, offset int64, key []byte) error) error
- func (s *SeriesSegment) ID() uint16
- func (s *SeriesSegment) InitForWrite() (err error)
- func (s *SeriesSegment) MaxSeriesID() SeriesID
- func (s *SeriesSegment) Open() error
- func (s *SeriesSegment) Size() int64
- func (s *SeriesSegment) Slice(pos uint32) []byte
- func (s *SeriesSegment) WriteLogEntry(data []byte) (offset int64, err error)
- type SeriesSegmentHeader
- type ShardError
- type StringArray
- type StringArrayCursor
- type TagKeyIterator
- type TagKeyIterators
- type TagValueIterator
- type TagValueIterators
- type UnsignedArray
- type UnsignedArrayCursor
Constants ¶
const ( FieldKeyTagKey = "_f" MeasurementTagKey = "_m" )
Values used to store the field key and measurement name as tags.
const ( SeriesIndexVersion = 1 SeriesIndexMagic = "SIDX" )
const ( SeriesIndexElemSize = 16 // offset + id SeriesIndexLoadFactor = 90 // rhh load factor SeriesIndexHeaderSize = 0 + 4 + 1 + 8 + 8 + 8 + 8 + 8 + 8 + 8 + 8 + 0 )
const ( SeriesSegmentVersion = 1 SeriesSegmentMagic = "SSEG" SeriesSegmentHeaderSize = 4 + 1 // magic + version )
const ( SeriesEntryFlagSize = 1 SeriesEntryHeaderSize = 1 + 8 // flag + id SeriesEntryInsertFlag = 0x01 SeriesEntryTombstoneFlag = 0x02 )
Series entry constants.
const DefaultSeriesPartitionCompactThreshold = 1 << 17 // 128K
DefaultSeriesPartitionCompactThreshold is the number of series IDs to hold in the in-memory series map before compacting and rebuilding the on-disk representation.
const EOF = query.ZeroTime
EOF represents a "not found" key returned by a Cursor.
const (
// SeriesFilePartitionN is the number of partitions a series file is split into.
SeriesFilePartitionN = 8
)
const SeriesIDSize = 8
SeriesIDSize is the size in bytes of a series key ID.
Variables ¶
var ( // ErrFieldTypeConflict is returned when a new field already exists with a different type. ErrFieldTypeConflict = errors.New("field type conflict") // ErrShardDisabled is returned when a the shard is not available for // queries or writes. ErrShardDisabled = errors.New("shard is disabled") // ErrUnknownFieldType is returned when the type of a field cannot be determined. ErrUnknownFieldType = errors.New("unknown field type") )
var ( FieldKeyTagKeyBytes = []byte(FieldKeyTagKey) MeasurementTagKeyBytes = []byte(MeasurementTagKey) )
var ( ErrSeriesFileClosed = errors.New("tsdb: series file closed") ErrInvalidSeriesPartitionID = errors.New("tsdb: invalid series partition id") )
var ( ErrSeriesPartitionClosed = errors.New("tsdb: series partition closed") ErrSeriesPartitionCompactionCancelled = errors.New("tsdb: series partition compaction cancelled") )
var ( ErrInvalidSeriesSegment = errors.New("invalid series segment") ErrInvalidSeriesSegmentVersion = errors.New("invalid series segment version") ErrSeriesSegmentNotWritable = errors.New("series segment not writable") )
var ErrInvalidSeriesIndex = errors.New("invalid series index")
Functions ¶
func AppendSeriesEntry ¶
func AppendSeriesEntry(dst []byte, flag uint8, id SeriesIDTyped, key []byte) []byte
func AppendSeriesKey ¶
AppendSeriesKey serializes name and tags to a byte slice. The total length is prepended as a uvarint.
func CompareSeriesKeys ¶
func DecodeName ¶
DecodeName converts tsdb internal serialization back to organization and bucket IDs.
func EncodeName ¶
EncodeName converts org/bucket pairs to the tsdb internal serialization
func ExplodePoints ¶
ExplodePoints creates a list of points that only contains one field per point. It also moves the measurement to a tag, and changes the measurement to be the provided argument.
func GenerateSeriesKeys ¶
GenerateSeriesKeys generates series keys for a list of names & tags using a single large memory block.
func IsValidSeriesEntryFlag ¶
IsValidSeriesEntryFlag returns true if flag is valid.
func IsValidSeriesSegmentFilename ¶
IsValidSeriesSegmentFilename returns true if filename is a 4-character lowercase hexidecimal number.
func JoinSeriesOffset ¶
JoinSeriesOffset returns an offset that combines the 2-byte segmentID and 4-byte pos.
func MakeTagsKey ¶
MakeTagsKey converts a tag set to bytes for use as a lookup key.
func MarshalTags ¶
MarshalTags converts a tag set to bytes for use as a lookup key.
func NewMeasurementSliceIterator ¶
func NewMeasurementSliceIterator(names [][]byte) *measurementSliceIterator
NewMeasurementSliceIterator returns an iterator over a slice of in-memory measurement names.
func NewSeriesQueryAdapterIterator ¶
func NewSeriesQueryAdapterIterator(sfile *SeriesFile, itr SeriesIDIterator, opt query.IteratorOptions) query.Iterator
NewSeriesQueryAdapterIterator returns a new instance of SeriesQueryAdapterIterator.
func NewShardError ¶
NewShardError returns a new ShardError.
func NewTagKeySliceIterator ¶
func NewTagKeySliceIterator(keys [][]byte) *tagKeySliceIterator
NewTagKeySliceIterator returns a TagKeyIterator that iterates over a slice.
func NewTagValueSliceIterator ¶
func NewTagValueSliceIterator(values [][]byte) *tagValueSliceIterator
NewTagValueSliceIterator returns a TagValueIterator that iterates over a slice.
func ParseSeriesKey ¶
ParseSeriesKey extracts the name & tags from a series key.
func ParseSeriesKeyInto ¶
ParseSeriesKeyInto extracts the name and tags for data, parsing the tags into dstTags, which is then returened.
The returned dstTags may have a different length and capacity.
func ParseSeriesSegmentFilename ¶
ParseSeriesSegmentFilename returns the id represented by the hexidecimal filename.
func PrometheusCollectors ¶
func PrometheusCollectors() []prometheus.Collector
PrometheusCollectors returns all the metrics associated with the tsdb package.
func ReadSeriesKey ¶
ReadSeriesKey returns the series key from the beginning of the buffer.
func ReadSeriesKeyFromSegments ¶
func ReadSeriesKeyFromSegments(a []*SeriesSegment, offset int64) []byte
ReadSeriesKeyFromSegments returns a series key from an offset within a set of segments.
func ReadSeriesKeyLen ¶
func ReadSeriesKeyTag ¶
func ReadSeriesKeyTagN ¶
func SeriesKeySize ¶
SeriesKeySize returns the number of bytes required to encode a series key.
func SeriesKeysSize ¶
SeriesKeysSize returns the number of bytes required to encode a list of name/tags.
func SeriesSegmentSize ¶
SeriesSegmentSize returns the maximum size of the segment. The size goes up by powers of 2 starting from 4MB and reaching 256MB.
func SplitSeriesOffset ¶
SplitSeriesOffset splits a offset into its 2-byte segmentID and 4-byte pos parts.
Types ¶
type BooleanArray ¶
type BooleanArray = cursors.BooleanArray
func NewBooleanArrayLen ¶
func NewBooleanArrayLen(sz int) *BooleanArray
type BooleanArrayCursor ¶
type BooleanArrayCursor = cursors.BooleanArrayCursor
type CursorIterator ¶
type CursorIterator = cursors.CursorIterator
type CursorIterators ¶
type CursorIterators = cursors.CursorIterators
type CursorRequest ¶
type CursorRequest = cursors.CursorRequest
type FloatArray ¶
type FloatArray = cursors.FloatArray
func NewFloatArrayLen ¶
func NewFloatArrayLen(sz int) *FloatArray
type FloatArrayCursor ¶
type FloatArrayCursor = cursors.FloatArrayCursor
type IntegerArray ¶
type IntegerArray = cursors.IntegerArray
func NewIntegerArrayLen ¶
func NewIntegerArrayLen(sz int) *IntegerArray
type IntegerArrayCursor ¶
type IntegerArrayCursor = cursors.IntegerArrayCursor
type MeasurementIterator ¶
MeasurementIterator represents a iterator over a list of measurements.
func MergeMeasurementIterators ¶
func MergeMeasurementIterators(itrs ...MeasurementIterator) MeasurementIterator
MergeMeasurementIterators returns an iterator that merges a set of iterators. Iterators that are first in the list take precendence and a deletion by those early iterators will invalidate elements by later iterators.
type MeasurementIterators ¶
type MeasurementIterators []MeasurementIterator
func (MeasurementIterators) Close ¶
func (a MeasurementIterators) Close() (err error)
type PartialWriteError ¶
type PartialWriteError struct { Reason string Dropped int // A sorted slice of series keys that were dropped. DroppedKeys [][]byte }
PartialWriteError indicates a write request could only write a portion of the requested values.
func (PartialWriteError) Error ¶
func (e PartialWriteError) Error() string
type SeriesCollection ¶
type SeriesCollection struct { Points []models.Point Keys [][]byte SeriesKeys [][]byte Names [][]byte Tags []models.Tags Types []models.FieldType SeriesIDs []SeriesID // Keeps track of invalid entries. Dropped uint64 DroppedKeys [][]byte Reason string // contains filtered or unexported fields }
SeriesCollection is a struct of arrays representation of a collection of series that allows for efficient filtering.
func NewSeriesCollection ¶
func NewSeriesCollection(points []models.Point) *SeriesCollection
NewSeriesCollection builds a SeriesCollection from a slice of points. It does some filtering of invalid points.
func (*SeriesCollection) Advance ¶
func (s *SeriesCollection) Advance(length int)
Advance will advance all of the slices that can length elements: x = x[length:].
func (*SeriesCollection) ApplyConcurrentDrops ¶
func (s *SeriesCollection) ApplyConcurrentDrops()
ApplyConcurrentDrops will remove all of the dropped values during concurrent iteration. It should not be called concurrently with any calls to Invalid.
func (*SeriesCollection) Copy ¶
func (s *SeriesCollection) Copy(dst, src int)
Copy will copy the element at src into dst in all slices that can: x[dst] = x[src].
func (SeriesCollection) Duplicate ¶
func (s SeriesCollection) Duplicate() *SeriesCollection
Duplicate returns a copy of the SeriesCollection. The slices are shared. Appending to any of them may or may not be reflected.
func (*SeriesCollection) InvalidateAll ¶
func (s *SeriesCollection) InvalidateAll(reason string)
InvalidateAll causes all of the entries to become invalid.
func (*SeriesCollection) Iterator ¶
func (s *SeriesCollection) Iterator() SeriesCollectionIterator
Iterator returns a new iterator over the entries in the collection. Multiple iterators can exist at the same time. Marking entries as invalid/skipped is more expensive, but thread safe. You must call ApplyConcurrentDrops after all of the iterators are finished.
func (*SeriesCollection) Length ¶
func (s *SeriesCollection) Length() int
Length returns the length of the first non-nil slice in the collection, or 0 if there is no non-nil slice.
func (*SeriesCollection) PartialWriteError ¶
func (s *SeriesCollection) PartialWriteError() error
PartialWriteError returns a PartialWriteError if any entries have been marked as invalid. It returns an error to avoid `return collection.PartialWriteError()` always being non-nil.
func (*SeriesCollection) Swap ¶
func (s *SeriesCollection) Swap(i, j int)
Swap will swap the elements at i and j in all slices that can: x[i], x[j] = x[j], x[i].
func (*SeriesCollection) Truncate ¶
func (s *SeriesCollection) Truncate(length int)
Truncate will truncate all of the slices that can down to length: x = x[:length].
type SeriesCollectionIterator ¶
type SeriesCollectionIterator struct {
// contains filtered or unexported fields
}
SeriesCollectionIterator is an iterator over the collection of series.
func (SeriesCollectionIterator) Index ¶
func (i SeriesCollectionIterator) Index() int
func (*SeriesCollectionIterator) Invalid ¶
func (i *SeriesCollectionIterator) Invalid(reason string)
Invalid flags the current entry as invalid, including it in the set of dropped keys and recording a reason. Only the first reason is kept. This is safe for concurrent callers, but ApplyConcurrentDrops must be called after all iterators are finished.
func (SeriesCollectionIterator) Key ¶
func (i SeriesCollectionIterator) Key() []byte
func (SeriesCollectionIterator) Length ¶
func (i SeriesCollectionIterator) Length() int
func (SeriesCollectionIterator) Name ¶
func (i SeriesCollectionIterator) Name() []byte
func (*SeriesCollectionIterator) Next ¶
func (i *SeriesCollectionIterator) Next() bool
Next advances the iterator and returns false if it's done.
func (SeriesCollectionIterator) Point ¶
func (i SeriesCollectionIterator) Point() models.Point
func (SeriesCollectionIterator) SeriesID ¶
func (i SeriesCollectionIterator) SeriesID() SeriesID
func (SeriesCollectionIterator) SeriesKey ¶
func (i SeriesCollectionIterator) SeriesKey() []byte
func (SeriesCollectionIterator) Tags ¶
func (i SeriesCollectionIterator) Tags() models.Tags
func (SeriesCollectionIterator) Type ¶
func (i SeriesCollectionIterator) Type() models.FieldType
type SeriesElem ¶
type SeriesElem interface { Name() []byte Tags() models.Tags Deleted() bool // InfluxQL expression associated with series during filtering. Expr() influxql.Expr }
SeriesElem represents a generic series element.
type SeriesFile ¶
SeriesFile represents the section of the index that holds series data.
func NewSeriesFile ¶
func NewSeriesFile(path string) *SeriesFile
NewSeriesFile returns a new instance of SeriesFile.
func (*SeriesFile) CreateSeriesListIfNotExists ¶
func (f *SeriesFile) CreateSeriesListIfNotExists(collection *SeriesCollection) error
CreateSeriesListIfNotExists creates a list of series in bulk if they don't exist. It overwrites the collection's Keys and SeriesIDs fields. The collection's SeriesIDs slice will have IDs for every name+tags, creating new series IDs as needed. If any SeriesID is zero, then a type conflict has occured for that series.
func (*SeriesFile) DeleteSeriesID ¶
func (f *SeriesFile) DeleteSeriesID(id SeriesID) error
DeleteSeriesID flags a series as permanently deleted. If the series is reintroduced later then it must create a new id.
func (*SeriesFile) DisableCompactions ¶
func (f *SeriesFile) DisableCompactions()
DisableCompactions prevents new compactions from running.
func (*SeriesFile) DisableMetrics ¶
func (f *SeriesFile) DisableMetrics()
DisableMetrics ensures that activity is not collected via the prometheus metrics. DisableMetrics must be called before Open.
func (*SeriesFile) EnableCompactions ¶
func (f *SeriesFile) EnableCompactions()
EnableCompactions allows compactions to run.
func (*SeriesFile) IsDeleted ¶
func (f *SeriesFile) IsDeleted(id SeriesID) bool
IsDeleted returns true if the ID has been deleted before.
func (*SeriesFile) Open ¶
func (f *SeriesFile) Open() error
Open memory maps the data file at the file's path.
func (*SeriesFile) Partitions ¶
func (f *SeriesFile) Partitions() []*SeriesPartition
Partitions returns all partitions.
func (*SeriesFile) Retain ¶
func (f *SeriesFile) Retain() func()
Retain adds a reference count to the file. It returns a release func.
func (*SeriesFile) Series ¶
func (f *SeriesFile) Series(id SeriesID) ([]byte, models.Tags)
Series returns the parsed series name and tags for an offset.
func (*SeriesFile) SeriesCount ¶
func (f *SeriesFile) SeriesCount() uint64
SeriesCount returns the number of series.
func (*SeriesFile) SeriesIDIterator ¶
func (f *SeriesFile) SeriesIDIterator() SeriesIDIterator
SeriesIterator returns an iterator over all the series.
func (*SeriesFile) SeriesIDPartition ¶
func (f *SeriesFile) SeriesIDPartition(id SeriesID) *SeriesPartition
func (*SeriesFile) SeriesIDPartitionID ¶
func (f *SeriesFile) SeriesIDPartitionID(id SeriesID) int
func (*SeriesFile) SeriesIDTyped ¶
func (f *SeriesFile) SeriesIDTyped(name []byte, tags models.Tags, buf []byte) SeriesIDTyped
SeriesIDTyped returns the typed series id for the series.
func (*SeriesFile) SeriesIDTypedBySeriesKey ¶
func (f *SeriesFile) SeriesIDTypedBySeriesKey(key []byte) SeriesIDTyped
SeriesIDTypedBySeriesKey returns the typed series id for the series.
func (*SeriesFile) SeriesKey ¶
func (f *SeriesFile) SeriesKey(id SeriesID) []byte
SeriesKey returns the series key for a given id.
func (*SeriesFile) SeriesKeyName ¶
func (f *SeriesFile) SeriesKeyName(id SeriesID) []byte
SeriesKeyName returns the measurement name for a series id.
func (*SeriesFile) SeriesKeyPartition ¶
func (f *SeriesFile) SeriesKeyPartition(key []byte) *SeriesPartition
func (*SeriesFile) SeriesKeyPartitionID ¶
func (f *SeriesFile) SeriesKeyPartitionID(key []byte) int
func (*SeriesFile) SeriesKeys ¶
func (f *SeriesFile) SeriesKeys(ids []SeriesID) [][]byte
SeriesKeys returns a list of series keys from a list of ids.
func (*SeriesFile) SeriesKeysPartitionIDs ¶
func (f *SeriesFile) SeriesKeysPartitionIDs(keys [][]byte) []int
func (*SeriesFile) SeriesPartitionPath ¶
func (f *SeriesFile) SeriesPartitionPath(i int) string
SeriesPartitionPath returns the path to a given partition.
func (*SeriesFile) SetDefaultMetricLabels ¶
func (f *SeriesFile) SetDefaultMetricLabels(labels prometheus.Labels)
SetDefaultMetricLabels sets the default labels for metrics on the Series File. It must be called before the SeriesFile is opened.
func (*SeriesFile) WithLogger ¶
func (f *SeriesFile) WithLogger(log *zap.Logger)
WithLogger sets the logger on the SeriesFile and all underlying partitions. It must be called before Open.
type SeriesID ¶
type SeriesID struct{ ID uint64 }
SeriesID is the type of a series id. It is logically a uint64, but encoded as a struct so that we gain more type checking when changing operations on it. The field is exported only so that tests that use reflection based comparisons still work; no one should use the field directly.
func NewSeriesID ¶
NewSeriesID constructs a series id from the raw value. It discards any type information.
func ReadAllSeriesIDIterator ¶
func ReadAllSeriesIDIterator(itr SeriesIDIterator) ([]SeriesID, error)
ReadAllSeriesIDIterator returns all ids from the iterator.
type SeriesIDElem ¶
SeriesIDElem represents a single series and optional expression.
type SeriesIDElems ¶
type SeriesIDElems []SeriesIDElem
SeriesIDElems represents a list of series id elements.
func (SeriesIDElems) Len ¶
func (a SeriesIDElems) Len() int
func (SeriesIDElems) Less ¶
func (a SeriesIDElems) Less(i, j int) bool
func (SeriesIDElems) Swap ¶
func (a SeriesIDElems) Swap(i, j int)
type SeriesIDExprIterator ¶
type SeriesIDExprIterator struct {
// contains filtered or unexported fields
}
seriesIDExprIterator is an iterator that attaches an associated expression.
func (*SeriesIDExprIterator) Close ¶
func (itr *SeriesIDExprIterator) Close() error
func (*SeriesIDExprIterator) Next ¶
func (itr *SeriesIDExprIterator) Next() (SeriesIDElem, error)
Next returns the next element in the iterator.
type SeriesIDIterator ¶
type SeriesIDIterator interface { Next() (SeriesIDElem, error) Close() error }
SeriesIDIterator represents a iterator over a list of series ids.
func DifferenceSeriesIDIterators ¶
func DifferenceSeriesIDIterators(itr0, itr1 SeriesIDIterator) SeriesIDIterator
DifferenceSeriesIDIterators returns an iterator that only returns series which occur the first iterator but not the second iterator.
func FilterUndeletedSeriesIDIterator ¶
func FilterUndeletedSeriesIDIterator(sfile *SeriesFile, itr SeriesIDIterator) SeriesIDIterator
FilterUndeletedSeriesIDIterator returns an iterator which filters all deleted series.
func IntersectSeriesIDIterators ¶
func IntersectSeriesIDIterators(itr0, itr1 SeriesIDIterator) SeriesIDIterator
IntersectSeriesIDIterators returns an iterator that only returns series which occur in both iterators. If both series have associated expressions then they are combined together.
func MergeSeriesIDIterators ¶
func MergeSeriesIDIterators(itrs ...SeriesIDIterator) SeriesIDIterator
MergeSeriesIDIterators returns an iterator that merges a set of iterators. Iterators that are first in the list take precendence and a deletion by those early iterators will invalidate elements by later iterators.
func NewSeriesIDExprIterator ¶
func NewSeriesIDExprIterator(itr SeriesIDIterator, expr influxql.Expr) SeriesIDIterator
newSeriesIDExprIterator returns a new instance of seriesIDExprIterator.
func UnionSeriesIDIterators ¶
func UnionSeriesIDIterators(itr0, itr1 SeriesIDIterator) SeriesIDIterator
UnionSeriesIDIterators returns an iterator that returns series from both both iterators. If both series have associated expressions then they are combined together.
type SeriesIDIterators ¶
type SeriesIDIterators []SeriesIDIterator
func (SeriesIDIterators) Close ¶
func (a SeriesIDIterators) Close() (err error)
type SeriesIDSet ¶
SeriesIDSet represents a lockable bitmap of series ids.
func NewSeriesIDSet ¶
func NewSeriesIDSet(a ...SeriesID) *SeriesIDSet
NewSeriesIDSet returns a new instance of SeriesIDSet.
func (*SeriesIDSet) AddMany ¶
func (s *SeriesIDSet) AddMany(ids ...SeriesID)
AddMany adds multiple ids to the SeriesIDSet. AddMany takes a lock, so may not be optimal to call many times with few ids.
func (*SeriesIDSet) AddNoLock ¶
func (s *SeriesIDSet) AddNoLock(id SeriesID)
AddNoLock adds the series id to the set. Add is not safe for use from multiple goroutines. Callers must manage synchronization.
func (*SeriesIDSet) And ¶
func (s *SeriesIDSet) And(other *SeriesIDSet) *SeriesIDSet
And returns a new SeriesIDSet containing elements that were present in s and other.
func (*SeriesIDSet) AndNot ¶
func (s *SeriesIDSet) AndNot(other *SeriesIDSet) *SeriesIDSet
AndNot returns a new SeriesIDSet containing elements that were present in s, but not present in other.
func (*SeriesIDSet) Bytes ¶
func (s *SeriesIDSet) Bytes() int
Bytes estimates the memory footprint of this SeriesIDSet, in bytes.
func (*SeriesIDSet) Cardinality ¶
func (s *SeriesIDSet) Cardinality() uint64
Cardinality returns the cardinality of the SeriesIDSet.
func (*SeriesIDSet) Clear ¶
func (s *SeriesIDSet) Clear()
Clear clears the underlying bitmap for re-use. Clear is safe for use by multiple goroutines.
func (*SeriesIDSet) ClearNoLock ¶
func (s *SeriesIDSet) ClearNoLock()
ClearNoLock clears the underlying bitmap for re-use without taking a lock.
func (*SeriesIDSet) Clone ¶
func (s *SeriesIDSet) Clone() *SeriesIDSet
Clone returns a new SeriesIDSet with a deep copy of the underlying bitmap.
func (*SeriesIDSet) CloneNoLock ¶
func (s *SeriesIDSet) CloneNoLock() *SeriesIDSet
CloneNoLock calls Clone without taking a lock.
func (*SeriesIDSet) Contains ¶
func (s *SeriesIDSet) Contains(id SeriesID) bool
Contains returns true if the id exists in the set.
func (*SeriesIDSet) ContainsNoLock ¶
func (s *SeriesIDSet) ContainsNoLock(id SeriesID) bool
ContainsNoLock returns true if the id exists in the set. ContainsNoLock is not safe for use from multiple goroutines. The caller must manage synchronization.
func (*SeriesIDSet) Diff ¶
func (s *SeriesIDSet) Diff(other *SeriesIDSet)
Diff removes from s any elements also present in other.
func (*SeriesIDSet) Equals ¶
func (s *SeriesIDSet) Equals(other *SeriesIDSet) bool
Equals returns true if other and s are the same set of ids.
func (*SeriesIDSet) ForEach ¶
func (s *SeriesIDSet) ForEach(f func(id SeriesID))
ForEach calls f for each id in the set. The function is applied to the IDs in ascending order.
func (*SeriesIDSet) ForEachNoLock ¶
func (s *SeriesIDSet) ForEachNoLock(f func(id SeriesID))
ForEachNoLock calls f for each id in the set without taking a lock.
func (*SeriesIDSet) Iterator ¶
func (s *SeriesIDSet) Iterator() SeriesIDSetIterable
Iterator returns an iterator to the underlying bitmap. This iterator is not protected by a lock.
func (*SeriesIDSet) Merge ¶
func (s *SeriesIDSet) Merge(others ...*SeriesIDSet)
Merge merged the contents of others into s. The caller does not need to provide s as an argument, and the contents of s will always be present in s after Merge returns.
func (*SeriesIDSet) MergeInPlace ¶
func (s *SeriesIDSet) MergeInPlace(other *SeriesIDSet)
MergeInPlace merges other into s, modifying s in the process.
func (*SeriesIDSet) Remove ¶
func (s *SeriesIDSet) Remove(id SeriesID)
Remove removes the id from the set.
func (*SeriesIDSet) RemoveNoLock ¶
func (s *SeriesIDSet) RemoveNoLock(id SeriesID)
RemoveNoLock removes the id from the set. RemoveNoLock is not safe for use from multiple goroutines. The caller must manage synchronization.
func (*SeriesIDSet) SetCOW ¶
func (s *SeriesIDSet) SetCOW(b bool)
SetCOW sets the copy-on-write status of the underlying bitmap. When SetCOW(true) is called, modifications to the bitmap will result in copies of the relevant data structures being made, preventing consumers of clones of the bitmap from seeing those modifications.
func (*SeriesIDSet) Slice ¶
func (s *SeriesIDSet) Slice() []uint64
Slice returns a slice of series ids.
func (*SeriesIDSet) String ¶
func (s *SeriesIDSet) String() string
func (*SeriesIDSet) UnmarshalBinary ¶
func (s *SeriesIDSet) UnmarshalBinary(data []byte) error
UnmarshalBinary unmarshals data into the set.
func (*SeriesIDSet) UnmarshalBinaryUnsafe ¶
func (s *SeriesIDSet) UnmarshalBinaryUnsafe(data []byte) error
UnmarshalBinaryUnsafe unmarshals data into the set. References to the underlying data are used so data should not be reused by caller.
type SeriesIDSetIterable ¶
type SeriesIDSetIterator ¶
type SeriesIDSetIterator interface { SeriesIDIterator SeriesIDSet() *SeriesIDSet }
SeriesIDSetIterator represents an iterator that can produce a SeriesIDSet.
func NewSeriesIDSetIterator ¶
func NewSeriesIDSetIterator(ss *SeriesIDSet) SeriesIDSetIterator
func NewSeriesIDSetIterators ¶
func NewSeriesIDSetIterators(itrs []SeriesIDIterator) []SeriesIDSetIterator
NewSeriesIDSetIterators returns a slice of SeriesIDSetIterator if all itrs can be type casted. Otherwise returns nil.
type SeriesIDSliceIterator ¶
type SeriesIDSliceIterator struct {
// contains filtered or unexported fields
}
SeriesIDSliceIterator iterates over a slice of series ids.
func NewSeriesIDSliceIterator ¶
func NewSeriesIDSliceIterator(ids []SeriesID) *SeriesIDSliceIterator
NewSeriesIDSliceIterator returns a SeriesIDIterator that iterates over a slice.
func (*SeriesIDSliceIterator) Close ¶
func (itr *SeriesIDSliceIterator) Close() error
func (*SeriesIDSliceIterator) Next ¶
func (itr *SeriesIDSliceIterator) Next() (SeriesIDElem, error)
Next returns the next series id in the slice.
func (*SeriesIDSliceIterator) SeriesIDSet ¶
func (itr *SeriesIDSliceIterator) SeriesIDSet() *SeriesIDSet
SeriesIDSet returns a set of all remaining ids.
type SeriesIDTyped ¶
type SeriesIDTyped struct{ ID uint64 }
SeriesIDType represents a series id with a type. It is logically a uint64, but encoded as a struct so that we gain more type checking when changing operations on it. The field is exported only so that tests that use reflection based comparisons still work; no one should use the field directly.
func NewSeriesIDTyped ¶
func NewSeriesIDTyped(id uint64) SeriesIDTyped
NewSeriesIDTyped constructs a typed series id from the raw values.
func ReadSeriesEntry ¶
func ReadSeriesEntry(data []byte) (flag uint8, id SeriesIDTyped, key []byte, sz int64)
func (SeriesIDTyped) HasType ¶
func (s SeriesIDTyped) HasType() bool
HasType returns if the id actually contains a type.
func (SeriesIDTyped) IsZero ¶
func (s SeriesIDTyped) IsZero() bool
IsZero returns if the SeriesIDTyped is zero. It ignores any type information.
func (SeriesIDTyped) RawID ¶
func (s SeriesIDTyped) RawID() uint64
ID returns the raw id for the SeriesIDTyped.
func (SeriesIDTyped) SeriesID ¶
func (s SeriesIDTyped) SeriesID() SeriesID
SeriesID constructs a SeriesID, discarding any type information.
func (SeriesIDTyped) Type ¶
func (s SeriesIDTyped) Type() models.FieldType
Type returns the associated type.
type SeriesIndex ¶
type SeriesIndex struct {
// contains filtered or unexported fields
}
SeriesIndex represents an index of key-to-id & id-to-offset mappings.
func NewSeriesIndex ¶
func NewSeriesIndex(path string) *SeriesIndex
func (*SeriesIndex) Clone ¶
func (idx *SeriesIndex) Clone() *SeriesIndex
Clone returns a copy of idx for use during compaction. In-memory maps are not cloned.
func (*SeriesIndex) Close ¶
func (idx *SeriesIndex) Close() (err error)
Close unmaps the index file.
func (*SeriesIndex) Count ¶
func (idx *SeriesIndex) Count() uint64
Count returns the number of series in the index.
func (*SeriesIndex) Delete ¶
func (idx *SeriesIndex) Delete(id SeriesID)
Delete marks the series id as deleted.
func (*SeriesIndex) FindIDByNameTags ¶
func (idx *SeriesIndex) FindIDByNameTags(segments []*SeriesSegment, name []byte, tags models.Tags, buf []byte) SeriesIDTyped
func (*SeriesIndex) FindIDBySeriesKey ¶
func (idx *SeriesIndex) FindIDBySeriesKey(segments []*SeriesSegment, key []byte) SeriesIDTyped
func (*SeriesIndex) FindIDListByNameTags ¶
func (idx *SeriesIndex) FindIDListByNameTags(segments []*SeriesSegment, names [][]byte, tagsSlice []models.Tags, buf []byte) (ids []SeriesIDTyped, ok bool)
func (*SeriesIndex) FindOffsetByID ¶
func (idx *SeriesIndex) FindOffsetByID(id SeriesID) int64
func (*SeriesIndex) InMemCount ¶
func (idx *SeriesIndex) InMemCount() uint64
InMemCount returns the number of series in the in-memory index.
func (*SeriesIndex) InMemSize ¶
func (idx *SeriesIndex) InMemSize() uint64
InMemSize returns the heap size of the index in bytes. The returned value is an estimation and does not include include all allocated memory.
func (*SeriesIndex) Insert ¶
func (idx *SeriesIndex) Insert(key []byte, id SeriesIDTyped, offset int64)
func (*SeriesIndex) IsDeleted ¶
func (idx *SeriesIndex) IsDeleted(id SeriesID) bool
IsDeleted returns true if series id has been deleted.
func (*SeriesIndex) OnDiskCount ¶
func (idx *SeriesIndex) OnDiskCount() uint64
OnDiskCount returns the number of series in the on-disk index.
func (*SeriesIndex) OnDiskSize ¶
func (idx *SeriesIndex) OnDiskSize() uint64
OnDiskSize returns the on-disk size of the index in bytes.
func (*SeriesIndex) Open ¶
func (idx *SeriesIndex) Open() (err error)
Open memory-maps the index file.
func (*SeriesIndex) Recover ¶
func (idx *SeriesIndex) Recover(segments []*SeriesSegment) error
Recover rebuilds the in-memory index for all new entries.
type SeriesIndexHeader ¶
type SeriesIndexHeader struct { Version uint8 MaxSeriesID SeriesID MaxOffset int64 Count uint64 Capacity int64 KeyIDMap struct { Offset int64 Size int64 } IDOffsetMap struct { Offset int64 Size int64 } }
SeriesIndexHeader represents the header of a series index.
func NewSeriesIndexHeader ¶
func NewSeriesIndexHeader() SeriesIndexHeader
NewSeriesIndexHeader returns a new instance of SeriesIndexHeader.
func ReadSeriesIndexHeader ¶
func ReadSeriesIndexHeader(data []byte) (hdr SeriesIndexHeader, err error)
ReadSeriesIndexHeader returns the header from data.
type SeriesIterator ¶
type SeriesIterator interface { Close() error Next() (SeriesElem, error) }
SeriesIterator represents a iterator over a list of series.
func NewSeriesIteratorAdapter ¶
func NewSeriesIteratorAdapter(sfile *SeriesFile, itr SeriesIDIterator) SeriesIterator
NewSeriesIteratorAdapter returns an adapter for converting series ids to series.
type SeriesPartition ¶
type SeriesPartition struct { CompactThreshold int Logger *zap.Logger // contains filtered or unexported fields }
SeriesPartition represents a subset of series file data.
func NewSeriesPartition ¶
func NewSeriesPartition(id int, path string) *SeriesPartition
NewSeriesPartition returns a new instance of SeriesPartition.
func (*SeriesPartition) AppendSeriesIDs ¶
func (p *SeriesPartition) AppendSeriesIDs(a []SeriesID) []SeriesID
AppendSeriesIDs returns a list of all series ids.
func (*SeriesPartition) Close ¶
func (p *SeriesPartition) Close() (err error)
Close unmaps the data files.
func (*SeriesPartition) Compacting ¶
func (p *SeriesPartition) Compacting() bool
Compacting returns if the SeriesPartition is currently compacting.
func (*SeriesPartition) CreateSeriesListIfNotExists ¶
func (p *SeriesPartition) CreateSeriesListIfNotExists(collection *SeriesCollection, keyPartitionIDs []int) error
CreateSeriesListIfNotExists creates a list of series in bulk if they don't exist. The ids parameter is modified to contain series IDs for all keys belonging to this partition. If the type does not match the existing type for the key, a zero id is stored.
func (*SeriesPartition) DeleteSeriesID ¶
func (p *SeriesPartition) DeleteSeriesID(id SeriesID) error
DeleteSeriesID flags a series as permanently deleted. If the series is reintroduced later then it must create a new id.
func (*SeriesPartition) DisableCompactions ¶
func (p *SeriesPartition) DisableCompactions()
func (*SeriesPartition) DiskSize ¶
func (p *SeriesPartition) DiskSize() uint64
DiskSize returns the number of bytes taken up on disk by the partition.
func (*SeriesPartition) EnableCompactions ¶
func (p *SeriesPartition) EnableCompactions()
func (*SeriesPartition) FindIDBySeriesKey ¶
func (p *SeriesPartition) FindIDBySeriesKey(key []byte) SeriesID
FindIDBySeriesKey return the series id for the series key.
func (*SeriesPartition) FindIDTypedBySeriesKey ¶
func (p *SeriesPartition) FindIDTypedBySeriesKey(key []byte) SeriesIDTyped
FindIDTypedBySeriesKey return the typed series id for the series key.
func (*SeriesPartition) IndexPath ¶
func (p *SeriesPartition) IndexPath() string
IndexPath returns the path to the series index.
func (*SeriesPartition) IsDeleted ¶
func (p *SeriesPartition) IsDeleted(id SeriesID) bool
IsDeleted returns true if the ID has been deleted before.
func (*SeriesPartition) Open ¶
func (p *SeriesPartition) Open() error
Open memory maps the data file at the partition's path.
func (*SeriesPartition) Path ¶
func (p *SeriesPartition) Path() string
Path returns the path to the partition.
func (*SeriesPartition) Series ¶
func (p *SeriesPartition) Series(id SeriesID) ([]byte, models.Tags)
Series returns the parsed series name and tags for an offset.
func (*SeriesPartition) SeriesCount ¶
func (p *SeriesPartition) SeriesCount() uint64
SeriesCount returns the number of series.
func (*SeriesPartition) SeriesKey ¶
func (p *SeriesPartition) SeriesKey(id SeriesID) []byte
SeriesKey returns the series key for a given id.
type SeriesPartitionCompactor ¶
type SeriesPartitionCompactor struct {
// contains filtered or unexported fields
}
SeriesPartitionCompactor represents an object reindexes a series partition and optionally compacts segments.
func NewSeriesPartitionCompactor ¶
func NewSeriesPartitionCompactor() *SeriesPartitionCompactor
NewSeriesPartitionCompactor returns a new instance of SeriesPartitionCompactor.
func (*SeriesPartitionCompactor) Compact ¶
func (c *SeriesPartitionCompactor) Compact(p *SeriesPartition) (time.Duration, error)
Compact rebuilds the series partition index.
type SeriesSegment ¶
type SeriesSegment struct {
// contains filtered or unexported fields
}
SeriesSegment represents a log of series entries.
func CloneSeriesSegments ¶
func CloneSeriesSegments(a []*SeriesSegment) []*SeriesSegment
CloneSeriesSegments returns a copy of a slice of segments.
func CreateSeriesSegment ¶
func CreateSeriesSegment(id uint16, path string) (*SeriesSegment, error)
CreateSeriesSegment generates an empty segment at path.
func FindSegment ¶
func FindSegment(a []*SeriesSegment, id uint16) *SeriesSegment
FindSegment returns a segment by id.
func NewSeriesSegment ¶
func NewSeriesSegment(id uint16, path string) *SeriesSegment
NewSeriesSegment returns a new instance of SeriesSegment.
func (*SeriesSegment) AppendSeriesIDs ¶
func (s *SeriesSegment) AppendSeriesIDs(a []SeriesID) []SeriesID
AppendSeriesIDs appends all the segments ids to a slice. Returns the new slice.
func (*SeriesSegment) CanWrite ¶
func (s *SeriesSegment) CanWrite(data []byte) bool
CanWrite returns true if segment has space to write entry data.
func (*SeriesSegment) Clone ¶
func (s *SeriesSegment) Clone() *SeriesSegment
Clone returns a copy of the segment. Excludes the write handler, if set.
func (*SeriesSegment) CloseForWrite ¶
func (s *SeriesSegment) CloseForWrite() (err error)
func (*SeriesSegment) Flush ¶
func (s *SeriesSegment) Flush() error
Flush flushes the buffer to disk.
func (*SeriesSegment) ForEachEntry ¶
func (s *SeriesSegment) ForEachEntry(fn func(flag uint8, id SeriesIDTyped, offset int64, key []byte) error) error
ForEachEntry executes fn for every entry in the segment.
func (*SeriesSegment) ID ¶
func (s *SeriesSegment) ID() uint16
ID returns the id the segment was initialized with.
func (*SeriesSegment) InitForWrite ¶
func (s *SeriesSegment) InitForWrite() (err error)
InitForWrite initializes a write handle for the segment. This is only used for the last segment in the series file.
func (*SeriesSegment) MaxSeriesID ¶
func (s *SeriesSegment) MaxSeriesID() SeriesID
MaxSeriesID returns the highest series id in the segment.
func (*SeriesSegment) Open ¶
func (s *SeriesSegment) Open() error
Open memory maps the data file at the file's path.
func (*SeriesSegment) Size ¶
func (s *SeriesSegment) Size() int64
Size returns the size of the data in the segment. This is only populated once InitForWrite() is called.
func (*SeriesSegment) Slice ¶
func (s *SeriesSegment) Slice(pos uint32) []byte
Slice returns a byte slice starting at pos.
func (*SeriesSegment) WriteLogEntry ¶
func (s *SeriesSegment) WriteLogEntry(data []byte) (offset int64, err error)
WriteLogEntry writes entry data into the segment. Returns the offset of the beginning of the entry.
type SeriesSegmentHeader ¶
type SeriesSegmentHeader struct {
Version uint8
}
SeriesSegmentHeader represents the header of a series segment.
func NewSeriesSegmentHeader ¶
func NewSeriesSegmentHeader() SeriesSegmentHeader
NewSeriesSegmentHeader returns a new instance of SeriesSegmentHeader.
func ReadSeriesSegmentHeader ¶
func ReadSeriesSegmentHeader(data []byte) (hdr SeriesSegmentHeader, err error)
ReadSeriesSegmentHeader returns the header from data.
type ShardError ¶
type ShardError struct { Err error // contains filtered or unexported fields }
A ShardError implements the error interface, and contains extra context about the shard that generated the error.
func (ShardError) Error ¶
func (e ShardError) Error() string
Error returns the string representation of the error, to satisfy the error interface.
type StringArray ¶
type StringArray = cursors.StringArray
func NewStringArrayLen ¶
func NewStringArrayLen(sz int) *StringArray
type StringArrayCursor ¶
type StringArrayCursor = cursors.StringArrayCursor
type TagKeyIterator ¶
TagKeyIterator represents a iterator over a list of tag keys.
func MergeTagKeyIterators ¶
func MergeTagKeyIterators(itrs ...TagKeyIterator) TagKeyIterator
MergeTagKeyIterators returns an iterator that merges a set of iterators.
type TagKeyIterators ¶
type TagKeyIterators []TagKeyIterator
func (TagKeyIterators) Close ¶
func (a TagKeyIterators) Close() (err error)
type TagValueIterator ¶
TagValueIterator represents a iterator over a list of tag values.
func MergeTagValueIterators ¶
func MergeTagValueIterators(itrs ...TagValueIterator) TagValueIterator
MergeTagValueIterators returns an iterator that merges a set of iterators.
type TagValueIterators ¶
type TagValueIterators []TagValueIterator
func (TagValueIterators) Close ¶
func (a TagValueIterators) Close() (err error)
type UnsignedArray ¶
type UnsignedArray = cursors.UnsignedArray
func NewUnsignedArrayLen ¶
func NewUnsignedArrayLen(sz int) *UnsignedArray
type UnsignedArrayCursor ¶
type UnsignedArrayCursor = cursors.UnsignedArrayCursor
Source Files ¶
Directories ¶
Path | Synopsis |
---|---|
Package tsi1 provides a memory-mapped index implementation that supports high cardinality series.
|
Package tsi1 provides a memory-mapped index implementation that supports high cardinality series. |
Package tsm1 provides a TSDB in the Time Structured Merge tree format.
|
Package tsm1 provides a TSDB in the Time Structured Merge tree format. |