block

package
v1.5.0 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Apr 7, 2022 License: Apache-2.0 Imports: 13 Imported by: 64

Documentation

Overview

Package block is a generated GoMock package.

Index

Constants

This section is empty.

Variables

This section is empty.

Functions

This section is empty.

Types

type AccumulatorBlock added in v0.9.3

type AccumulatorBlock interface {
	Block
	// AddBlock adds a block to this accumulator.
	AddBlock(bl Block) error
}

AccumulatorBlock accumulates incoming blocks and presents them as a single Block.

func NewContainerBlock added in v0.9.3

func NewContainerBlock(blocks ...Block) (AccumulatorBlock, error)

NewContainerBlock creates a container block, which allows iterating across blocks incoming from multiple data sources, provided they have the same bounds.

type Block

type Block interface {
	io.Closer
	// StepIter returns a step-wise block iterator, giving consolidated values
	// across all series comprising the box at a single time step.
	StepIter() (StepIter, error)
	// SeriesIter returns a series-wise block iterator, giving unconsolidated
	// by series.
	SeriesIter() (SeriesIter, error)
	// MultiSeriesIter returns batched series iterators for the block based on
	// given concurrency.
	MultiSeriesIter(concurrency int) ([]SeriesIterBatch, error)
	// Meta returns the metadata for the block.
	Meta() Metadata
	// Info returns information about the block.
	Info() BlockInfo
}

Block represents a group of series across a time bound.

func NewEmptyBlock added in v0.11.0

func NewEmptyBlock(meta Metadata) Block

NewEmptyBlock creates an empty block with the given metadata.

func NewLazyBlock added in v0.9.2

func NewLazyBlock(block Block, opts LazyOptions) Block

NewLazyBlock creates a lazy block wrapping another block with lazy options.

func NewScalar added in v0.4.1

func NewScalar(
	val float64,
	meta Metadata,
) Block

NewScalar creates a scalar block whose value is given by the function over the metadata bounds.

type BlockInfo added in v0.11.0

type BlockInfo struct {
	// contains filtered or unexported fields
}

BlockInfo describes information about the block.

func NewBlockInfo added in v0.11.0

func NewBlockInfo(blockType BlockType) BlockInfo

NewBlockInfo creates a BlockInfo of the specified type.

func NewWrappedBlockInfo added in v0.11.0

func NewWrappedBlockInfo(
	blockType BlockType,
	wrap BlockInfo,
) BlockInfo

NewWrappedBlockInfo creates a BlockInfo of the specified type, wrapping an existing BlockInfo.

func (BlockInfo) BaseType added in v0.11.0

func (b BlockInfo) BaseType() BlockType

BaseType is the block type for the innermost block wrapped by this block, or the block itself if it doesn't wrap anything.

func (BlockInfo) InnerType added in v0.11.0

func (b BlockInfo) InnerType() BlockType

InnerType is the block type for any block wrapped by this block, or this block itself if it doesn't wrap anything.

func (BlockInfo) Type added in v0.11.0

func (b BlockInfo) Type() BlockType

Type is the block type for this block.

type BlockType added in v0.11.0

type BlockType uint8

BlockType describes a block type.

const (
	// BlockM3TSZCompressed is an M3TSZ compressed block.
	BlockM3TSZCompressed BlockType = iota
	// BlockDecompressed is a decompressed raw data block.
	BlockDecompressed
	// BlockScalar is a scalar block with a single value throughout its range.
	BlockScalar
	// BlockTime is a block with datapoint values given by a function of their
	// timestamps.
	BlockTime
	// BlockLazy is a wrapper for an inner block that lazily applies transforms.
	BlockLazy
	// BlockContainer is a block that contains multiple inner blocks that share
	// common metadata.
	BlockContainer
	// BlockEmpty is a block with metadata but no series or values.
	BlockEmpty
	// BlockTest is a block used for testing only.
	BlockTest
)

func (BlockType) String added in v0.11.0

func (t BlockType) String() string

String returns the block type as a string.

type Builder

type Builder interface {
	// AddCols adds the given number of columns to the block.
	AddCols(num int) error
	// SetRow sets a given block row to the given values and metadata.
	SetRow(idx int, values []float64, meta SeriesMeta) error
	// PopulateColumns sets all columns to the given size.
	PopulateColumns(size int)
	// AppendValue adds a single value to the column at the given index.
	AppendValue(idx int, value float64) error
	// AppendValues adds a slice of values to the column at the given index.
	AppendValues(idx int, values []float64) error
	// Build builds the block.
	Build() Block
	// BuildAsType builds the block, forcing it to the given BlockType.
	BuildAsType(blockType BlockType) Block
}

Builder builds Blocks.

func NewColumnBlockBuilder

func NewColumnBlockBuilder(
	queryCtx *models.QueryContext,
	meta Metadata,
	seriesMeta []SeriesMeta) Builder

NewColumnBlockBuilder creates a new column block builder

type ColStep

type ColStep struct {
	// contains filtered or unexported fields
}

ColStep is a single column containing data from multiple series at a given time step

func (ColStep) Time

func (c ColStep) Time() xtime.UnixNano

Time for the step

func (ColStep) Values

func (c ColStep) Values() []float64

Values for the column

type ColumnBlockBuilder

type ColumnBlockBuilder struct {
	// contains filtered or unexported fields
}

ColumnBlockBuilder builds a block optimized for column iteration.

func (ColumnBlockBuilder) AddCols

func (cb ColumnBlockBuilder) AddCols(num int) error

AddCols adds the given number of columns to the block.

func (ColumnBlockBuilder) AppendValue

func (cb ColumnBlockBuilder) AppendValue(idx int, value float64) error

AppendValue adds a value to a column at index

func (ColumnBlockBuilder) AppendValues added in v0.4.1

func (cb ColumnBlockBuilder) AppendValues(idx int, values []float64) error

AppendValues adds a slice of values to a column at index

func (ColumnBlockBuilder) Build

func (cb ColumnBlockBuilder) Build() Block

Build builds the block.

func (ColumnBlockBuilder) BuildAsType added in v0.11.0

func (cb ColumnBlockBuilder) BuildAsType(blockType BlockType) Block

BuildAsType builds the block, forcing it to the given BlockType.

func (ColumnBlockBuilder) PopulateColumns added in v0.15.0

func (cb ColumnBlockBuilder) PopulateColumns(size int)

PopulateColumns sets all columns to the given row size.

func (ColumnBlockBuilder) SetRow added in v0.15.0

func (cb ColumnBlockBuilder) SetRow(
	idx int,
	values []float64,
	meta SeriesMeta,
) error

SetRow sets a given block row to the given values and metadata.

type Iterator

type Iterator interface {
	// Next moves to the next item in the iterator. It will return false if there
	// are no more items, or if encountering an error.
	//
	// NB: it is important to check that Err() is nil after Next returns false, to
	// ensure that any errors during iteration are detected and accounted for.
	Next() bool
	// Err returns any error encountered during iteration.
	Err() error
	// Close frees up resources held by the iterator.
	Close()
}

Iterator is the base iterator.

type LazyOptions added in v0.9.2

type LazyOptions interface {
	// SetTimeTransform sets the time transform function.
	SetTimeTransform(TimeTransform) LazyOptions
	// TimeTransform returns the time transform function.
	TimeTransform() TimeTransform
	// SetValueTransform sets the value transform function.
	SetValueTransform(ValueTransform) LazyOptions
	// ValueTransform returns the value transform function.
	ValueTransform() ValueTransform
	// SetMetaTransform sets the meta transform function.
	SetMetaTransform(MetaTransform) LazyOptions
	// MetaTransform returns the meta transform function.
	MetaTransform() MetaTransform
	// SetSeriesMetaTransform sets the series meta transform function.
	SetSeriesMetaTransform(SeriesMetaTransform) LazyOptions
	// SeriesMetaTransform returns the series meta transform function.
	SeriesMetaTransform() SeriesMetaTransform
}

LazyOptions describes options for lazy blocks.

func NewLazyOptions added in v0.11.0

func NewLazyOptions() LazyOptions

NewLazyOptions creates LazyOpts with default values.

type MetaTransform added in v0.9.2

type MetaTransform func(meta Metadata) Metadata

MetaTransform transforms meta data.

type Metadata

type Metadata struct {
	// Bounds represents the time bounds for all series in the block.
	Bounds models.Bounds
	// Tags contains any tags common across all series in the block.
	Tags models.Tags
	// ResultMetadata contains metadata from any database access operations during
	// fetching block details.
	ResultMetadata ResultMetadata
}

Metadata is metadata for a block, describing size and common tags across constituent series.

func (Metadata) Equals added in v0.11.0

func (m Metadata) Equals(other Metadata) bool

Equals returns a boolean reporting whether the compared metadata has equal fields.

func (Metadata) String

func (m Metadata) String() string

String returns a string representation of metadata.

type MockBlock added in v0.4.1

type MockBlock struct {
	// contains filtered or unexported fields
}

MockBlock is a mock of Block interface.

func NewMockBlock added in v0.4.1

func NewMockBlock(ctrl *gomock.Controller) *MockBlock

NewMockBlock creates a new mock instance.

func (*MockBlock) Close added in v0.4.1

func (m *MockBlock) Close() error

Close mocks base method.

func (*MockBlock) EXPECT added in v0.4.1

func (m *MockBlock) EXPECT() *MockBlockMockRecorder

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockBlock) Info added in v0.11.0

func (m *MockBlock) Info() BlockInfo

Info mocks base method.

func (*MockBlock) Meta added in v0.11.0

func (m *MockBlock) Meta() Metadata

Meta mocks base method.

func (*MockBlock) MultiSeriesIter added in v0.15.0

func (m *MockBlock) MultiSeriesIter(arg0 int) ([]SeriesIterBatch, error)

MultiSeriesIter mocks base method.

func (*MockBlock) SeriesIter added in v0.4.1

func (m *MockBlock) SeriesIter() (SeriesIter, error)

SeriesIter mocks base method.

func (*MockBlock) StepIter added in v0.4.1

func (m *MockBlock) StepIter() (StepIter, error)

StepIter mocks base method.

type MockBlockMockRecorder added in v0.4.1

type MockBlockMockRecorder struct {
	// contains filtered or unexported fields
}

MockBlockMockRecorder is the mock recorder for MockBlock.

func (*MockBlockMockRecorder) Close added in v0.4.1

func (mr *MockBlockMockRecorder) Close() *gomock.Call

Close indicates an expected call of Close.

func (*MockBlockMockRecorder) Info added in v0.11.0

func (mr *MockBlockMockRecorder) Info() *gomock.Call

Info indicates an expected call of Info.

func (*MockBlockMockRecorder) Meta added in v0.11.0

func (mr *MockBlockMockRecorder) Meta() *gomock.Call

Meta indicates an expected call of Meta.

func (*MockBlockMockRecorder) MultiSeriesIter added in v0.15.0

func (mr *MockBlockMockRecorder) MultiSeriesIter(arg0 interface{}) *gomock.Call

MultiSeriesIter indicates an expected call of MultiSeriesIter.

func (*MockBlockMockRecorder) SeriesIter added in v0.4.1

func (mr *MockBlockMockRecorder) SeriesIter() *gomock.Call

SeriesIter indicates an expected call of SeriesIter.

func (*MockBlockMockRecorder) StepIter added in v0.4.1

func (mr *MockBlockMockRecorder) StepIter() *gomock.Call

StepIter indicates an expected call of StepIter.

type MockBuilder added in v0.4.1

type MockBuilder struct {
	// contains filtered or unexported fields
}

MockBuilder is a mock of Builder interface.

func NewMockBuilder added in v0.4.1

func NewMockBuilder(ctrl *gomock.Controller) *MockBuilder

NewMockBuilder creates a new mock instance.

func (*MockBuilder) AddCols added in v0.4.1

func (m *MockBuilder) AddCols(arg0 int) error

AddCols mocks base method.

func (*MockBuilder) AppendValue added in v0.4.1

func (m *MockBuilder) AppendValue(arg0 int, arg1 float64) error

AppendValue mocks base method.

func (*MockBuilder) AppendValues added in v0.4.1

func (m *MockBuilder) AppendValues(arg0 int, arg1 []float64) error

AppendValues mocks base method.

func (*MockBuilder) Build added in v0.4.1

func (m *MockBuilder) Build() Block

Build mocks base method.

func (*MockBuilder) BuildAsType added in v0.11.0

func (m *MockBuilder) BuildAsType(arg0 BlockType) Block

BuildAsType mocks base method.

func (*MockBuilder) EXPECT added in v0.4.1

func (m *MockBuilder) EXPECT() *MockBuilderMockRecorder

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockBuilder) PopulateColumns added in v0.15.0

func (m *MockBuilder) PopulateColumns(arg0 int)

PopulateColumns mocks base method.

func (*MockBuilder) SetRow added in v0.15.0

func (m *MockBuilder) SetRow(arg0 int, arg1 []float64, arg2 SeriesMeta) error

SetRow mocks base method.

type MockBuilderMockRecorder added in v0.4.1

type MockBuilderMockRecorder struct {
	// contains filtered or unexported fields
}

MockBuilderMockRecorder is the mock recorder for MockBuilder.

func (*MockBuilderMockRecorder) AddCols added in v0.4.1

func (mr *MockBuilderMockRecorder) AddCols(arg0 interface{}) *gomock.Call

AddCols indicates an expected call of AddCols.

func (*MockBuilderMockRecorder) AppendValue added in v0.4.1

func (mr *MockBuilderMockRecorder) AppendValue(arg0, arg1 interface{}) *gomock.Call

AppendValue indicates an expected call of AppendValue.

func (*MockBuilderMockRecorder) AppendValues added in v0.4.1

func (mr *MockBuilderMockRecorder) AppendValues(arg0, arg1 interface{}) *gomock.Call

AppendValues indicates an expected call of AppendValues.

func (*MockBuilderMockRecorder) Build added in v0.4.1

func (mr *MockBuilderMockRecorder) Build() *gomock.Call

Build indicates an expected call of Build.

func (*MockBuilderMockRecorder) BuildAsType added in v0.11.0

func (mr *MockBuilderMockRecorder) BuildAsType(arg0 interface{}) *gomock.Call

BuildAsType indicates an expected call of BuildAsType.

func (*MockBuilderMockRecorder) PopulateColumns added in v0.15.0

func (mr *MockBuilderMockRecorder) PopulateColumns(arg0 interface{}) *gomock.Call

PopulateColumns indicates an expected call of PopulateColumns.

func (*MockBuilderMockRecorder) SetRow added in v0.15.0

func (mr *MockBuilderMockRecorder) SetRow(arg0, arg1, arg2 interface{}) *gomock.Call

SetRow indicates an expected call of SetRow.

type MockSeriesIter added in v0.4.1

type MockSeriesIter struct {
	// contains filtered or unexported fields
}

MockSeriesIter is a mock of SeriesIter interface.

func NewMockSeriesIter added in v0.4.1

func NewMockSeriesIter(ctrl *gomock.Controller) *MockSeriesIter

NewMockSeriesIter creates a new mock instance.

func (*MockSeriesIter) Close added in v0.4.1

func (m *MockSeriesIter) Close()

Close mocks base method.

func (*MockSeriesIter) Current added in v0.4.1

func (m *MockSeriesIter) Current() UnconsolidatedSeries

Current mocks base method.

func (*MockSeriesIter) EXPECT added in v0.4.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockSeriesIter) Err added in v0.6.0

func (m *MockSeriesIter) Err() error

Err mocks base method.

func (*MockSeriesIter) Next added in v0.4.1

func (m *MockSeriesIter) Next() bool

Next mocks base method.

func (*MockSeriesIter) SeriesCount added in v0.4.1

func (m *MockSeriesIter) SeriesCount() int

SeriesCount mocks base method.

func (*MockSeriesIter) SeriesMeta added in v0.4.1

func (m *MockSeriesIter) SeriesMeta() []SeriesMeta

SeriesMeta mocks base method.

type MockSeriesIterMockRecorder added in v0.4.1

type MockSeriesIterMockRecorder struct {
	// contains filtered or unexported fields
}

MockSeriesIterMockRecorder is the mock recorder for MockSeriesIter.

func (*MockSeriesIterMockRecorder) Close added in v0.4.1

func (mr *MockSeriesIterMockRecorder) Close() *gomock.Call

Close indicates an expected call of Close.

func (*MockSeriesIterMockRecorder) Current added in v0.4.1

func (mr *MockSeriesIterMockRecorder) Current() *gomock.Call

Current indicates an expected call of Current.

func (*MockSeriesIterMockRecorder) Err added in v0.6.0

Err indicates an expected call of Err.

func (*MockSeriesIterMockRecorder) Next added in v0.4.1

Next indicates an expected call of Next.

func (*MockSeriesIterMockRecorder) SeriesCount added in v0.4.1

func (mr *MockSeriesIterMockRecorder) SeriesCount() *gomock.Call

SeriesCount indicates an expected call of SeriesCount.

func (*MockSeriesIterMockRecorder) SeriesMeta added in v0.4.1

func (mr *MockSeriesIterMockRecorder) SeriesMeta() *gomock.Call

SeriesMeta indicates an expected call of SeriesMeta.

type MockStep added in v0.4.1

type MockStep struct {
	// contains filtered or unexported fields
}

MockStep is a mock of Step interface.

func NewMockStep added in v0.4.1

func NewMockStep(ctrl *gomock.Controller) *MockStep

NewMockStep creates a new mock instance.

func (*MockStep) EXPECT added in v0.4.1

func (m *MockStep) EXPECT() *MockStepMockRecorder

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockStep) Time added in v0.4.1

func (m *MockStep) Time() time.UnixNano

Time mocks base method.

func (*MockStep) Values added in v0.4.1

func (m *MockStep) Values() []float64

Values mocks base method.

type MockStepIter added in v0.4.1

type MockStepIter struct {
	// contains filtered or unexported fields
}

MockStepIter is a mock of StepIter interface.

func NewMockStepIter added in v0.4.1

func NewMockStepIter(ctrl *gomock.Controller) *MockStepIter

NewMockStepIter creates a new mock instance.

func (*MockStepIter) Close added in v0.4.1

func (m *MockStepIter) Close()

Close mocks base method.

func (*MockStepIter) Current added in v0.4.1

func (m *MockStepIter) Current() Step

Current mocks base method.

func (*MockStepIter) EXPECT added in v0.4.1

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockStepIter) Err added in v0.6.0

func (m *MockStepIter) Err() error

Err mocks base method.

func (*MockStepIter) Next added in v0.4.1

func (m *MockStepIter) Next() bool

Next mocks base method.

func (*MockStepIter) SeriesMeta added in v0.4.1

func (m *MockStepIter) SeriesMeta() []SeriesMeta

SeriesMeta mocks base method.

func (*MockStepIter) StepCount added in v0.4.1

func (m *MockStepIter) StepCount() int

StepCount mocks base method.

type MockStepIterMockRecorder added in v0.4.1

type MockStepIterMockRecorder struct {
	// contains filtered or unexported fields
}

MockStepIterMockRecorder is the mock recorder for MockStepIter.

func (*MockStepIterMockRecorder) Close added in v0.4.1

func (mr *MockStepIterMockRecorder) Close() *gomock.Call

Close indicates an expected call of Close.

func (*MockStepIterMockRecorder) Current added in v0.4.1

func (mr *MockStepIterMockRecorder) Current() *gomock.Call

Current indicates an expected call of Current.

func (*MockStepIterMockRecorder) Err added in v0.6.0

Err indicates an expected call of Err.

func (*MockStepIterMockRecorder) Next added in v0.4.1

func (mr *MockStepIterMockRecorder) Next() *gomock.Call

Next indicates an expected call of Next.

func (*MockStepIterMockRecorder) SeriesMeta added in v0.4.1

func (mr *MockStepIterMockRecorder) SeriesMeta() *gomock.Call

SeriesMeta indicates an expected call of SeriesMeta.

func (*MockStepIterMockRecorder) StepCount added in v0.4.1

func (mr *MockStepIterMockRecorder) StepCount() *gomock.Call

StepCount indicates an expected call of StepCount.

type MockStepMockRecorder added in v0.4.1

type MockStepMockRecorder struct {
	// contains filtered or unexported fields
}

MockStepMockRecorder is the mock recorder for MockStep.

func (*MockStepMockRecorder) Time added in v0.4.1

func (mr *MockStepMockRecorder) Time() *gomock.Call

Time indicates an expected call of Time.

func (*MockStepMockRecorder) Values added in v0.4.1

func (mr *MockStepMockRecorder) Values() *gomock.Call

Values indicates an expected call of Values.

type Result

type Result struct {
	// Blocks is a list of blocks, optionally split across time boundaries.
	Blocks []Block
	// Metadata contains information on fetch status.
	Metadata ResultMetadata
}

Result is a fetch result containing multiple blocks optionally split across time boundaries.

type ResultMetadata added in v0.14.0

type ResultMetadata struct {

	// FetchedResponses is the number of M3 RPC fetch responses received.
	FetchedResponses int
	// FetchedBytesEstimate is the estimated number of bytes fetched.
	FetchedBytesEstimate int
	// LocalOnly indicates that this query was executed only on the local store.
	LocalOnly bool
	// Exhaustive indicates whether the underlying data set presents a full
	// collection of retrieved data.
	Exhaustive bool
	// Warnings is a list of warnings that indicate potentially partial or
	// incomplete results.
	Warnings Warnings
	// Resolutions is a list of resolutions for series obtained by this query.
	Resolutions []time.Duration
	// KeepNaNs indicates if NaNs should be kept when returning results.
	KeepNaNs bool
	// WaitedIndex counts how many times index querying had to wait for permits.
	WaitedIndex int
	// WaitedSeriesRead counts how many times series being read had to wait for permits.
	WaitedSeriesRead int
	// FetchedSeriesCount is the total number of series that were fetched to compute
	// this result.
	FetchedSeriesCount int
	// FetchedMetadataCount is the total amount of metadata that was fetched to compute
	// this result.
	FetchedMetadataCount int
	// contains filtered or unexported fields
}

ResultMetadata describes metadata common to each type of query results, indicating any additional information about the result.

func NewResultMetadata added in v0.14.0

func NewResultMetadata() ResultMetadata

NewResultMetadata creates a new result metadata.

func (*ResultMetadata) AddNamespace added in v1.4.2

func (m *ResultMetadata) AddNamespace(namespace string)

AddNamespace adds a namespace to the namespace set, initializing the underlying map if necessary.

func (*ResultMetadata) AddWarning added in v0.14.0

func (m *ResultMetadata) AddWarning(name string, message string)

AddWarning adds a warning to the result metadata. NB: warnings are expected to be small in general, so it's better to iterate over the array rather than introduce a map.

func (*ResultMetadata) AddWarnings added in v1.2.0

func (m *ResultMetadata) AddWarnings(warnings ...Warning)

AddWarnings adds several warnings to the result metadata.

func (*ResultMetadata) ByName added in v1.4.2

func (m *ResultMetadata) ByName(nameTag []byte) *ResultMetricMetadata

ByName returns the ResultMetricMetadata for a given metric name.

func (ResultMetadata) CombineMetadata added in v0.14.0

func (m ResultMetadata) CombineMetadata(other ResultMetadata) ResultMetadata

CombineMetadata combines two result metadatas.

func (ResultMetadata) Equals added in v0.15.2

func (m ResultMetadata) Equals(n ResultMetadata) bool

Equals determines if two result metadatas are equal.

func (ResultMetadata) GetNamespaces added in v1.4.2

func (m ResultMetadata) GetNamespaces() []string

GetNamespaces returns an array representing the set of namespaces added via AddNamespace.

func (ResultMetadata) IsDefault added in v0.14.0

func (m ResultMetadata) IsDefault() bool

IsDefault returns true if this result metadata matches the unchanged default.

func (ResultMetadata) MetadataByNameMerged added in v1.4.2

func (m ResultMetadata) MetadataByNameMerged() ResultMetricMetadata

MetadataByNameMerged returns the metadataByName map values merged into one.

func (ResultMetadata) TopMetadataByName added in v1.4.2

func (m ResultMetadata) TopMetadataByName(max int) map[string]*ResultMetricMetadata

TopMetadataByName returns the top `max` ResultMetricMetadatas by the sum of their contained counters.

func (*ResultMetadata) VerifyTemporalRange added in v0.15.16

func (m *ResultMetadata) VerifyTemporalRange(step time.Duration)

VerifyTemporalRange will verify that each resolution seen is below the given step size, adding warning headers if it is not.

func (ResultMetadata) WarningStrings added in v0.15.0

func (m ResultMetadata) WarningStrings() []string

WarningStrings converts warnings to a slice of strings for presentation.

type ResultMetricMetadata added in v1.4.2

type ResultMetricMetadata struct {
	// NoSamples is the total number of series that were fetched to compute
	// this result but had no samples.
	NoSamples int
	// WithSamples is the total number of series that were fetched to compute
	// this result and had samples.
	WithSamples int
	// Aggregated is the total number of aggregated series that were fetched to
	// compute this result.
	Aggregated int
	// Unaggregated is the total number of unaggregated series that were fetched to
	// compute this result.
	Unaggregated int
}

ResultMetricMetadata describes metadata on a per metric-name basis.

func (ResultMetricMetadata) Equals added in v1.4.2

Equals determines if two result metric metadatas are equal.

func (*ResultMetricMetadata) Merge added in v1.4.2

Merge takes another ResultMetricMetadata and merges it into this one.

type Scalar added in v0.4.1

type Scalar struct {
	// contains filtered or unexported fields
}

Scalar is a block containing a single value over a certain bound This represents constant values; it greatly simplifies downstream operations by allowing them to treat this as a regular block, while at the same time having an option to optimize by accessing the scalar value directly instead.

func (*Scalar) Close added in v0.4.1

func (b *Scalar) Close() error

Close closes the block; this is a no-op for scalar block.

func (*Scalar) Info added in v0.11.0

func (b *Scalar) Info() BlockInfo

Info returns information about the block.

func (*Scalar) Meta added in v0.11.0

func (b *Scalar) Meta() Metadata

Meta returns the metadata for the block.

func (*Scalar) MultiSeriesIter added in v0.15.0

func (b *Scalar) MultiSeriesIter(_ int) ([]SeriesIterBatch, error)

MultiSeriesIter is invalid for a scalar block.

func (*Scalar) SeriesIter added in v0.4.1

func (b *Scalar) SeriesIter() (SeriesIter, error)

SeriesIter is invalid for a scalar block.

func (*Scalar) StepIter added in v0.4.1

func (b *Scalar) StepIter() (StepIter, error)

StepIter returns a step-wise block iterator, giving consolidated values across all series comprising the box at a single time step.

func (*Scalar) Value added in v0.4.1

func (b *Scalar) Value() float64

Value yields the constant value this scalar is set to.

type Series

type Series struct {
	Meta SeriesMeta
	// contains filtered or unexported fields
}

Series is a single series within a block.

func NewSeries

func NewSeries(values []float64, meta SeriesMeta) Series

NewSeries creates a new series.

func (Series) Len

func (s Series) Len() int

Len returns the number of datapoints in the series.

func (Series) ValueAtStep

func (s Series) ValueAtStep(idx int) float64

ValueAtStep returns the datapoint value at a step index.

func (Series) Values

func (s Series) Values() []float64

Values returns the internal values slice.

type SeriesIter

type SeriesIter interface {
	Iterator
	// SeriesMeta returns the metadata for each series in the block.
	SeriesMeta() []SeriesMeta
	// SeriesCount returns the number of series.
	SeriesCount() int
	// Current returns the current series for the block.
	Current() UnconsolidatedSeries
}

SeriesIter iterates through a block horizontally.

func NewUnconsolidatedSeriesIter added in v1.0.0

func NewUnconsolidatedSeriesIter(
	series []UnconsolidatedSeries,
) SeriesIter

NewUnconsolidatedSeriesIter returns a new unconsolidated series iterator.

type SeriesIterBatch added in v0.15.0

type SeriesIterBatch struct {
	// Iter is the series iterator.
	Iter SeriesIter
	// Size is the batch size.
	Size int
}

SeriesIterBatch is a batch of SeriesIterators.

type SeriesMeta

type SeriesMeta struct {
	Tags models.Tags
	Name []byte
}

SeriesMeta is metadata data for the series.

type SeriesMetaTransform added in v0.14.0

type SeriesMetaTransform func(meta []SeriesMeta) []SeriesMeta

SeriesMetaTransform transforms series meta data.

type Step

type Step interface {
	Time() xtime.UnixNano
	Values() []float64
}

Step is a single time step within a block.

func NewColStep

func NewColStep(t xtime.UnixNano, values []float64) Step

NewColStep creates a new column step

type StepIter

type StepIter interface {
	Iterator
	// SeriesMeta returns the metadata for each series in the block.
	SeriesMeta() []SeriesMeta
	// StepCount returns the number of steps.
	StepCount() int
	// Current returns the current step for the block.
	Current() Step
}

StepIter iterates through a block vertically.

type TimeTransform added in v0.9.2

type TimeTransform func(xtime.UnixNano) xtime.UnixNano

TimeTransform transforms a timestamp.

type UnconsolidatedSeries added in v0.4.6

type UnconsolidatedSeries struct {
	Meta SeriesMeta
	// contains filtered or unexported fields
}

UnconsolidatedSeries is the series with raw datapoints.

func NewUnconsolidatedSeries added in v0.4.6

func NewUnconsolidatedSeries(
	datapoints ts.Datapoints,
	meta SeriesMeta,
	stats UnconsolidatedSeriesStats,
) UnconsolidatedSeries

NewUnconsolidatedSeries creates a new series with raw datapoints.

func (UnconsolidatedSeries) Datapoints added in v0.4.6

func (s UnconsolidatedSeries) Datapoints() ts.Datapoints

Datapoints returns the internal datapoints slice.

func (UnconsolidatedSeries) Len added in v0.4.6

func (s UnconsolidatedSeries) Len() int

Len returns the number of datapoints slices in the series.

func (UnconsolidatedSeries) Stats added in v0.15.0

Stats returns statistics about the unconsolidated series if they were supplied.

type UnconsolidatedSeriesStats added in v0.15.0

type UnconsolidatedSeriesStats struct {
	Enabled        bool
	DecodeDuration time.Duration
}

UnconsolidatedSeriesStats is stats about an unconsolidated series.

type ValueTransform added in v0.9.2

type ValueTransform func(float64) float64

ValueTransform transform a float64.

type Warning added in v0.14.0

type Warning struct {
	// Name is the name of the store originating the warning.
	Name string
	// Message is the content of the warning message.
	Message string
}

Warning is a message that indicates potential partial or incomplete results.

func (Warning) Header added in v0.14.0

func (w Warning) Header() string

Header formats the warning into a format to send in a response header.

type Warnings added in v0.14.0

type Warnings []Warning

Warnings is a slice of warnings.

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL