Documentation
¶
Overview ¶
Copyright 2022 Huawei Cloud Computing Technologies Co., Ltd.
Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. You may obtain a copy of the License at
http://www.apache.org/licenses/LICENSE-2.0
Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the specific language governing permissions and limitations under the License.
Copyright 2022 Huawei Cloud Computing Technologies Co., Ltd.
Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. You may obtain a copy of the License at
http://www.apache.org/licenses/LICENSE-2.0
Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the specific language governing permissions and limitations under the License.
Index ¶
- Constants
- Variables
- func AddLocationsWithFirstTime(l *immutable.LocationCursor, files immutable.TableReaders, ...) (int64, error)
- func AddLocationsWithInit(l *immutable.LocationCursor, files immutable.TableReaders, ...) error
- func AddLocationsWithLimit(l *immutable.LocationCursor, files immutable.TableReaders, ...) (int64, error)
- func AppendColumnTimes(bitmap []bool, column executor.Column, columnTimes []int64, ...)
- func CanNotAggOnSeriesFunc(m map[string]*influxql.Call) bool
- func GetMaxTime(maxTime int64, rec *record.Record, isAscending bool) int64
- func GetMinTime(minTime int64, rec *record.Record, isAscending bool) int64
- func MatchPreAgg(schema *executor.QuerySchema, ctx *idKeyCursorContext) bool
- func NewAggregateCursor(input comm.KeyCursor, schema *executor.QuerySchema, ...) *aggregateCursor
- func NewChunkReader(outputRowDataType hybridqp.RowDataType, ops []hybridqp.ExprOptions, ...) executor.Processor
- func NewEngine(dataPath, walPath string, options netstorage.EngineOptions, ctx *meta.LoadCtx) (netstorage.Engine, error)
- func NewFileLoopCursor(ctx *idKeyCursorContext, span *tracing.Span, schema *executor.QuerySchema, ...) *fileLoopCursor
- func NewFloatColFloatHeapReducer(inOrdinal, outOrdinal int, auxProcessors []*auxProcessor, ...) *floatColFloatHeapReducer
- func NewIntegerColIntegerHeapReducer(inOrdinal, outOrdinal int, auxProcessors []*auxProcessor, ...) *integerColIntegerHeapReducer
- func NewLimitCursor(schema *executor.QuerySchema, ...) *limitCursor
- func NewRecordSchema(querySchema *executor.QuerySchema, auxTags []string, schema record.Schemas, ...) ([]string, record.Schemas)
- func NewSeriesInfoPool(num int64) *filesInfoPool
- func NewShard(dataPath string, walPath string, ident *meta.ShardIdentifier, ...) *shard
- func NewTagSetCursorForTest(schema *executor.QuerySchema, seriesN int) *tagSetCursor
- func NewTopNLinkedList(n int, ascending bool) *topNLinkedList
- func NewTsmMergeCursor(ctx *idKeyCursorContext, sid uint64, filter influxql.Expr, ...) (*tsmMergeCursor, error)
- func RecordCutNormal(start, end int, src, des *record.Record)
- func SetFullCompColdDuration(d time.Duration)
- type AggTagSetCursor
- func (s *AggTagSetCursor) Close() error
- func (s *AggTagSetCursor) EndSpan()
- func (s *AggTagSetCursor) GetSchema() record.Schemas
- func (s *AggTagSetCursor) Init()
- func (s *AggTagSetCursor) Name() string
- func (s *AggTagSetCursor) Next() (*record.Record, comm.SeriesInfoIntf, error)
- func (s *AggTagSetCursor) NextAggData() (*record.Record, *comm.FileInfo, error)
- func (s *AggTagSetCursor) RecordInit() error
- func (s *AggTagSetCursor) SetOps(ops []*comm.CallOption)
- func (s *AggTagSetCursor) SetSchema(schema record.Schemas)
- func (s *AggTagSetCursor) SinkPlan(plan hybridqp.QueryNode)
- func (s *AggTagSetCursor) StartSpan(span *tracing.Span)
- func (s *AggTagSetCursor) TagAuxHandler(re *record.Record, start, end int)
- func (s *AggTagSetCursor) TimeWindowsInit()
- func (s *AggTagSetCursor) UpdateRec2Window(index int, i int)
- type ChunkReader
- func (r *ChunkReader) Close()
- func (r *ChunkReader) Create(plan executor.LogicalPlan, opt query.ProcessorOptions) (executor.Processor, error)
- func (r *ChunkReader) Explain() []executor.ValuePair
- func (r *ChunkReader) GetInputNumber(executor.Port) int
- func (r *ChunkReader) GetInputs() executor.Ports
- func (r *ChunkReader) GetOutputNumber(executor.Port) int
- func (r *ChunkReader) GetOutputs() executor.Ports
- func (r *ChunkReader) IsSink() bool
- func (r *ChunkReader) Name() string
- func (r *ChunkReader) Release() error
- func (r *ChunkReader) Work(ctx context.Context) error
- type CoProcessor
- type CoProcessorImpl
- type Compactor
- func (c *Compactor) RegisterShard(sh *shard)
- func (c *Compactor) SetAllOutOfOrderMergeSwitch(en bool)
- func (c *Compactor) SetAllShardsCompactionSwitch(en bool)
- func (c *Compactor) SetSnapshotColdDuration(d time.Duration)
- func (c *Compactor) ShardCompactionSwitch(shid uint64, en bool)
- func (c *Compactor) ShardOutOfOrderMergeSwitch(shid uint64, en bool)
- func (c *Compactor) UnregisterShard(shardId uint64)
- type DBPTInfo
- func (dbPT *DBPTInfo) LoadAllShards(rp string, shardIDs []uint64) error
- func (dbPT *DBPTInfo) LockFile() string
- func (dbPT *DBPTInfo) NewShard(rp string, shardID uint64, timeRangeInfo *meta.ShardTimeRangeInfo) (Shard, error)
- func (dbPT *DBPTInfo) OpenIndexes(rp string) error
- func (dbPT *DBPTInfo) OpenShards(rp string, durationInfos map[uint64]*meta.ShardDurationInfo) error
- func (dbPT *DBPTInfo) SetOption(opt netstorage.EngineOptions)
- func (dbPT *DBPTInfo) Shard(id uint64) Shard
- type DataBlockInfo
- type EndPointPair
- type Engine
- func (e *Engine) ChangeShardTierToWarm(db string, ptId uint32, shardID uint64) error
- func (e *Engine) Close() error
- func (e *Engine) CreateDBPT(db string, pt uint32)
- func (e *Engine) CreateLogicalPlan(ctx context.Context, db string, ptId uint32, shardID uint64, ...) (hybridqp.QueryNode, error)
- func (e *Engine) CreateShard(db, rp string, ptId uint32, shardID uint64, ...) error
- func (e *Engine) DbPTRef(db string, ptId uint32) error
- func (e *Engine) DbPTUnref(db string, ptId uint32)
- func (e *Engine) DeleteDatabase(db string, ptId uint32) (err error)
- func (e *Engine) DeleteIndex(db string, ptId uint32, indexID uint64) error
- func (e *Engine) DeleteShard(db string, ptId uint32, shardID uint64) error
- func (e *Engine) DropMeasurement(db string, rp string, name string, shardIds []uint64) error
- func (e *Engine) DropRetentionPolicy(db string, rp string, ptId uint32) error
- func (e *Engine) DropSeries(database string, sources []influxql.Source, ptId []uint32, ...) (int, error)
- func (e *Engine) ExpiredIndexes() []*meta2.IndexIdentifier
- func (e *Engine) ExpiredShards() []*meta2.ShardIdentifier
- func (e *Engine) FetchShardsNeedChangeStore() (shardsToWarm, shardsToCold []*meta2.ShardIdentifier)
- func (e *Engine) ForceFlush()
- func (e *Engine) GetLockFile() string
- func (e *Engine) GetShardSplitPoints(db string, ptId uint32, shardID uint64, idxes []int64) ([]string, error)
- func (e *Engine) LogicalPlanCost(db string, ptId uint32, sources influxql.Sources, opt query.ProcessorOptions) (hybridqp.LogicalPlanCost, error)
- func (e *Engine) Open(ptIds []uint32, durationInfos map[uint64]*meta2.ShardDurationInfo) error
- func (e *Engine) SeriesCardinality(db string, ptIDs []uint32, measurements [][]byte, condition influxql.Expr) ([]meta2.MeasurementCardinalityInfo, error)
- func (e *Engine) SeriesExactCardinality(db string, ptIDs []uint32, measurements [][]byte, condition influxql.Expr) (map[string]uint64, error)
- func (e *Engine) SeriesKeys(db string, ptIDs []uint32, measurements [][]byte, condition influxql.Expr) ([]string, error)
- func (e *Engine) SetReadOnly(readonly bool)
- func (e *Engine) Statistics(buffer []byte) ([]byte, error)
- func (e *Engine) SysCtrl(req *netstorage.SysCtrlRequest) error
- func (e *Engine) TagValues(db string, ptIDs []uint32, tagKeys map[string][][]byte, ...) (netstorage.TablesTagSets, error)
- func (e *Engine) TagValuesCardinality(db string, ptIDs []uint32, tagKeys map[string][][]byte, ...) (map[string]uint64, error)
- func (e *Engine) UpdateShardDurationInfo(info *meta2.ShardDurationInfo) error
- func (e *Engine) WriteRows(db, rp string, ptId uint32, shardID uint64, rows []influx.Row, ...) error
- type FloatHeapItem
- type FloatPointItem
- type IntegerHeapItem
- type IntegerPointItem
- type LogWriter
- type PreAggTagSetCursor
- func (s *PreAggTagSetCursor) Close() error
- func (s *PreAggTagSetCursor) EndSpan()
- func (s *PreAggTagSetCursor) GetSchema() record.Schemas
- func (s *PreAggTagSetCursor) Name() string
- func (s *PreAggTagSetCursor) Next() (*record.Record, comm.SeriesInfoIntf, error)
- func (s *PreAggTagSetCursor) NextAggData() (*record.Record, *comm.FileInfo, error)
- func (s *PreAggTagSetCursor) RecordInitPreAgg() error
- func (s *PreAggTagSetCursor) SetOps(ops []*comm.CallOption)
- func (s *PreAggTagSetCursor) SetSchema(schema record.Schemas)
- func (s *PreAggTagSetCursor) SinkPlan(plan hybridqp.QueryNode)
- func (s *PreAggTagSetCursor) StartSpan(span *tracing.Span)
- func (s *PreAggTagSetCursor) TimeWindowsInit()
- type PtNNLock
- type Reducer
- type ReducerEndpoint
- type ReducerParams
- type Routine
- type RoutineImpl
- type SeriesIter
- type Shard
- type TagSetCursorItem
- type TierInfo
- type WAL
- type WalRecordType
- type Writer
Constants ¶
const ( Failpoint = "failpoint" Readonly = "readonly" )
const ( TierLeveMem = 1 // in memory TierLeveLocalDisk = 2 TierLeveObjectStorage = 3 )
const ( DefaultFileSize = 10 * 1024 * 1024 WALFileSuffixes = "wal" WalRecordHeadSize = 1 + 4 WalCompBufSize = 256 * 1024 WalCompMaxBufSize = 2 * 1024 * 1024 )
const DataDirectory = "data"
const IndexFileDirectory = "index"
const WalDirectory = "wal"
Variables ¶
var ( ErrDBNotFound = fmt.Errorf("database not found") ErrPTNotFound = fmt.Errorf("partition not found") ErrRPNotFound = fmt.Errorf("rp not found") ErrShardNotFound = fmt.Errorf("shard not found") ErrMMNotFound = fmt.Errorf("measurment not found") ErrShardClosed = fmt.Errorf("shard closed") ErrIndexNotFound = fmt.Errorf("index not found") ErrInvalidDir = fmt.Errorf("shard or index dir not valid") )
var ( AggPool = record.NewRecordPool() SeriesPool = record.NewRecordPool() TsmMergePool = record.NewRecordPool() )
var AppendManyNils map[int]func(colVal *record.ColVal, count int)
var (
ErrNoSuchParam = fmt.Errorf("no parameter find")
)
var (
FileCursorPool = record.NewRecordPool()
)
var (
RecordIteratorPool = &sync.Pool{}
)
Functions ¶
func AddLocationsWithFirstTime ¶
func AddLocationsWithFirstTime(l *immutable.LocationCursor, files immutable.TableReaders, ctx *idKeyCursorContext, sid uint64) (int64, error)
func AddLocationsWithInit ¶
func AddLocationsWithInit(l *immutable.LocationCursor, files immutable.TableReaders, ctx *idKeyCursorContext, sid uint64) error
func AddLocationsWithLimit ¶
func AddLocationsWithLimit(l *immutable.LocationCursor, files immutable.TableReaders, ctx *idKeyCursorContext, sid uint64) (int64, error)
func AppendColumnTimes ¶
func MatchPreAgg ¶
func MatchPreAgg(schema *executor.QuerySchema, ctx *idKeyCursorContext) bool
func NewAggregateCursor ¶
func NewAggregateCursor(input comm.KeyCursor, schema *executor.QuerySchema, globalPool *record.RecordPool, hasAuxTags bool) *aggregateCursor
func NewChunkReader ¶
func NewChunkReader(outputRowDataType hybridqp.RowDataType, ops []hybridqp.ExprOptions, seriesPlan hybridqp.QueryNode, source influxql.Sources, schema *executor.QuerySchema, cursors []interface{}) executor.Processor
func NewEngine ¶
func NewEngine(dataPath, walPath string, options netstorage.EngineOptions, ctx *meta.LoadCtx) (netstorage.Engine, error)
func NewFileLoopCursor ¶
func NewFileLoopCursor(ctx *idKeyCursorContext, span *tracing.Span, schema *executor.QuerySchema, tagSet *tsi.TagSetInfo, start, step int, s *shard) *fileLoopCursor
func NewFloatColFloatHeapReducer ¶
func NewFloatColFloatHeapReducer(inOrdinal, outOrdinal int, auxProcessors []*auxProcessor, floatHeapItem *FloatHeapItem) *floatColFloatHeapReducer
func NewIntegerColIntegerHeapReducer ¶
func NewIntegerColIntegerHeapReducer(inOrdinal, outOrdinal int, auxProcessors []*auxProcessor, integerHeapItem *IntegerHeapItem) *integerColIntegerHeapReducer
func NewLimitCursor ¶
func NewLimitCursor(schema *executor.QuerySchema, helper func(start, end int, src, des *record.Record)) *limitCursor
func NewRecordSchema ¶
func NewSeriesInfoPool ¶
func NewSeriesInfoPool(num int64) *filesInfoPool
func NewShard ¶
func NewShard(dataPath string, walPath string, ident *meta.ShardIdentifier, indexBuilder *tsi.IndexBuilder, durationInfo *meta.DurationDescriptor, tr *meta.TimeRangeInfo, options netstorage.EngineOptions) *shard
func NewTagSetCursorForTest ¶
func NewTagSetCursorForTest(schema *executor.QuerySchema, seriesN int) *tagSetCursor
NewTagSetCursorForTest for ut test, will remove later
func NewTopNLinkedList ¶
func NewTsmMergeCursor ¶
func RecordCutNormal ¶
func SetFullCompColdDuration ¶
Types ¶
type AggTagSetCursor ¶
type AggTagSetCursor struct {
// contains filtered or unexported fields
}
func NewAggTagSetCursor ¶
func NewAggTagSetCursor(schema *executor.QuerySchema, ctx *idKeyCursorContext, itr comm.KeyCursor) *AggTagSetCursor
func (*AggTagSetCursor) Close ¶
func (s *AggTagSetCursor) Close() error
func (*AggTagSetCursor) EndSpan ¶
func (s *AggTagSetCursor) EndSpan()
func (*AggTagSetCursor) GetSchema ¶
func (s *AggTagSetCursor) GetSchema() record.Schemas
func (*AggTagSetCursor) Init ¶
func (s *AggTagSetCursor) Init()
func (*AggTagSetCursor) Name ¶
func (s *AggTagSetCursor) Name() string
func (*AggTagSetCursor) Next ¶
func (s *AggTagSetCursor) Next() (*record.Record, comm.SeriesInfoIntf, error)
func (*AggTagSetCursor) NextAggData ¶
func (*AggTagSetCursor) RecordInit ¶
func (s *AggTagSetCursor) RecordInit() error
func (*AggTagSetCursor) SetOps ¶
func (s *AggTagSetCursor) SetOps(ops []*comm.CallOption)
func (*AggTagSetCursor) SetSchema ¶
func (s *AggTagSetCursor) SetSchema(schema record.Schemas)
func (*AggTagSetCursor) SinkPlan ¶
func (s *AggTagSetCursor) SinkPlan(plan hybridqp.QueryNode)
func (*AggTagSetCursor) StartSpan ¶
func (s *AggTagSetCursor) StartSpan(span *tracing.Span)
func (*AggTagSetCursor) TagAuxHandler ¶
func (s *AggTagSetCursor) TagAuxHandler(re *record.Record, start, end int)
func (*AggTagSetCursor) TimeWindowsInit ¶
func (s *AggTagSetCursor) TimeWindowsInit()
func (*AggTagSetCursor) UpdateRec2Window ¶
func (s *AggTagSetCursor) UpdateRec2Window(index int, i int)
type ChunkReader ¶
type ChunkReader struct {
executor.BaseProcessor
Output *executor.ChunkPort
ResultChunkPool *executor.CircularChunkPool
// contains filtered or unexported fields
}
func (*ChunkReader) Close ¶
func (r *ChunkReader) Close()
func (*ChunkReader) Create ¶
func (r *ChunkReader) Create(plan executor.LogicalPlan, opt query.ProcessorOptions) (executor.Processor, error)
func (*ChunkReader) Explain ¶
func (r *ChunkReader) Explain() []executor.ValuePair
func (*ChunkReader) GetInputNumber ¶
func (r *ChunkReader) GetInputNumber(executor.Port) int
func (*ChunkReader) GetInputs ¶
func (r *ChunkReader) GetInputs() executor.Ports
func (*ChunkReader) GetOutputNumber ¶
func (r *ChunkReader) GetOutputNumber(executor.Port) int
func (*ChunkReader) GetOutputs ¶
func (r *ChunkReader) GetOutputs() executor.Ports
func (*ChunkReader) IsSink ¶
func (r *ChunkReader) IsSink() bool
func (*ChunkReader) Name ¶
func (r *ChunkReader) Name() string
func (*ChunkReader) Release ¶
func (r *ChunkReader) Release() error
type CoProcessor ¶
type CoProcessor interface {
WorkOnRecord(*record.Record, *record.Record, *ReducerParams)
}
type CoProcessorImpl ¶
type CoProcessorImpl struct {
Routines []Routine
}
func NewCoProcessorImpl ¶
func NewCoProcessorImpl(routines ...Routine) *CoProcessorImpl
func (*CoProcessorImpl) AppendRoutine ¶
func (p *CoProcessorImpl) AppendRoutine(routines ...Routine)
func (*CoProcessorImpl) WorkOnRecord ¶
func (p *CoProcessorImpl) WorkOnRecord(in *record.Record, out *record.Record, params *ReducerParams)
type Compactor ¶
type Compactor struct {
// contains filtered or unexported fields
}
func NewCompactor ¶
func NewCompactor() *Compactor
func (*Compactor) RegisterShard ¶
func (c *Compactor) RegisterShard(sh *shard)
func (*Compactor) SetAllOutOfOrderMergeSwitch ¶
func (*Compactor) SetAllShardsCompactionSwitch ¶
func (*Compactor) SetSnapshotColdDuration ¶
func (*Compactor) ShardCompactionSwitch ¶
func (*Compactor) ShardOutOfOrderMergeSwitch ¶
func (*Compactor) UnregisterShard ¶
type DBPTInfo ¶
type DBPTInfo struct {
// contains filtered or unexported fields
}
func NewDBPTInfo ¶
func (*DBPTInfo) LoadAllShards ¶
func (*DBPTInfo) OpenIndexes ¶
func (*DBPTInfo) OpenShards ¶
func (*DBPTInfo) SetOption ¶
func (dbPT *DBPTInfo) SetOption(opt netstorage.EngineOptions)
type DataBlockInfo ¶
type DataBlockInfo struct {
// contains filtered or unexported fields
}
type EndPointPair ¶
type Engine ¶
type Engine struct {
ReadOnly bool
DBPartitions map[string]map[uint32]*DBPTInfo
// contains filtered or unexported fields
}
func (*Engine) ChangeShardTierToWarm ¶
func (*Engine) CreateDBPT ¶
func (*Engine) CreateLogicalPlan ¶
func (*Engine) CreateShard ¶
func (*Engine) DeleteIndex ¶
func (*Engine) DeleteShard ¶
todo:need confirm
func (*Engine) DropMeasurement ¶
func (*Engine) DropRetentionPolicy ¶
func (*Engine) DropSeries ¶
func (*Engine) ExpiredIndexes ¶
func (e *Engine) ExpiredIndexes() []*meta2.IndexIdentifier
func (*Engine) ExpiredShards ¶
func (e *Engine) ExpiredShards() []*meta2.ShardIdentifier
func (*Engine) FetchShardsNeedChangeStore ¶
func (e *Engine) FetchShardsNeedChangeStore() (shardsToWarm, shardsToCold []*meta2.ShardIdentifier)
func (*Engine) ForceFlush ¶
func (e *Engine) ForceFlush()
func (*Engine) GetLockFile ¶
func (*Engine) GetShardSplitPoints ¶
func (*Engine) LogicalPlanCost ¶
func (e *Engine) LogicalPlanCost(db string, ptId uint32, sources influxql.Sources, opt query.ProcessorOptions) (hybridqp.LogicalPlanCost, error)
func (*Engine) SeriesCardinality ¶
func (*Engine) SeriesExactCardinality ¶
func (*Engine) SeriesKeys ¶
func (*Engine) SetReadOnly ¶
func (*Engine) SysCtrl ¶
func (e *Engine) SysCtrl(req *netstorage.SysCtrlRequest) error
func (*Engine) TagValues ¶
func (e *Engine) TagValues(db string, ptIDs []uint32, tagKeys map[string][][]byte, condition influxql.Expr) (netstorage.TablesTagSets, error)
func (*Engine) TagValuesCardinality ¶
func (*Engine) UpdateShardDurationInfo ¶
func (e *Engine) UpdateShardDurationInfo(info *meta2.ShardDurationInfo) error
type FloatHeapItem ¶
type FloatHeapItem struct {
// contains filtered or unexported fields
}
func NewFloatHeapItem ¶
func NewFloatHeapItem(n int, cmpByValue, cmpByTime func(a, b *FloatPointItem) bool) *FloatHeapItem
func (*FloatHeapItem) Len ¶
func (f *FloatHeapItem) Len() int
func (*FloatHeapItem) Less ¶
func (f *FloatHeapItem) Less(i, j int) bool
func (*FloatHeapItem) Pop ¶
func (f *FloatHeapItem) Pop() interface{}
func (*FloatHeapItem) Push ¶
func (f *FloatHeapItem) Push(x interface{})
func (*FloatHeapItem) Reset ¶
func (f *FloatHeapItem) Reset()
func (*FloatHeapItem) Swap ¶
func (f *FloatHeapItem) Swap(i, j int)
type FloatPointItem ¶
type FloatPointItem struct {
// contains filtered or unexported fields
}
func NewFloatPointItem ¶
func NewFloatPointItem(time int64, value float64) *FloatPointItem
type IntegerHeapItem ¶
type IntegerHeapItem struct {
// contains filtered or unexported fields
}
func NewIntegerHeapItem ¶
func NewIntegerHeapItem(n int, cmpByValue, cmpByTime func(a, b *IntegerPointItem) bool) *IntegerHeapItem
func (*IntegerHeapItem) Len ¶
func (f *IntegerHeapItem) Len() int
func (*IntegerHeapItem) Less ¶
func (f *IntegerHeapItem) Less(i, j int) bool
func (*IntegerHeapItem) Pop ¶
func (f *IntegerHeapItem) Pop() interface{}
func (*IntegerHeapItem) Push ¶
func (f *IntegerHeapItem) Push(x interface{})
func (*IntegerHeapItem) Reset ¶
func (f *IntegerHeapItem) Reset()
func (*IntegerHeapItem) Swap ¶
func (f *IntegerHeapItem) Swap(i, j int)
type IntegerPointItem ¶
type IntegerPointItem struct {
// contains filtered or unexported fields
}
func NewIntegerPointItem ¶
func NewIntegerPointItem(time int64, value int64) *IntegerPointItem
type PreAggTagSetCursor ¶
type PreAggTagSetCursor struct {
// contains filtered or unexported fields
}
func NewPreAggTagSetCursor ¶
func NewPreAggTagSetCursor(schema *executor.QuerySchema, ctx *idKeyCursorContext, itr comm.KeyCursor) *PreAggTagSetCursor
func (*PreAggTagSetCursor) Close ¶
func (s *PreAggTagSetCursor) Close() error
func (*PreAggTagSetCursor) EndSpan ¶
func (s *PreAggTagSetCursor) EndSpan()
func (*PreAggTagSetCursor) GetSchema ¶
func (s *PreAggTagSetCursor) GetSchema() record.Schemas
func (*PreAggTagSetCursor) Name ¶
func (s *PreAggTagSetCursor) Name() string
func (*PreAggTagSetCursor) Next ¶
func (s *PreAggTagSetCursor) Next() (*record.Record, comm.SeriesInfoIntf, error)
func (*PreAggTagSetCursor) NextAggData ¶
func (*PreAggTagSetCursor) RecordInitPreAgg ¶
func (s *PreAggTagSetCursor) RecordInitPreAgg() error
func (*PreAggTagSetCursor) SetOps ¶
func (s *PreAggTagSetCursor) SetOps(ops []*comm.CallOption)
func (*PreAggTagSetCursor) SetSchema ¶
func (s *PreAggTagSetCursor) SetSchema(schema record.Schemas)
func (*PreAggTagSetCursor) SinkPlan ¶
func (s *PreAggTagSetCursor) SinkPlan(plan hybridqp.QueryNode)
func (*PreAggTagSetCursor) StartSpan ¶
func (s *PreAggTagSetCursor) StartSpan(span *tracing.Span)
func (*PreAggTagSetCursor) TimeWindowsInit ¶
func (s *PreAggTagSetCursor) TimeWindowsInit()
type Reducer ¶
type Reducer interface {
Aggregate(*ReducerEndpoint, *ReducerParams)
}
type ReducerEndpoint ¶
type ReducerEndpoint struct {
InputPoint EndPointPair
OutputPoint EndPointPair
}
type ReducerParams ¶
type ReducerParams struct {
// contains filtered or unexported fields
}
type Routine ¶
type Routine interface {
WorkOnRecord(*record.Record, *record.Record, *ReducerParams)
}
type RoutineImpl ¶
type RoutineImpl struct {
// contains filtered or unexported fields
}
func NewRoutineImpl ¶
func NewRoutineImpl(reducer Reducer, inOrdinal int, outOrdinal int) *RoutineImpl
func (*RoutineImpl) WorkOnRecord ¶
func (r *RoutineImpl) WorkOnRecord(in *record.Record, out *record.Record, params *ReducerParams)
type SeriesIter ¶
type SeriesIter struct {
// contains filtered or unexported fields
}
type Shard ¶
type Shard interface {
WriteRows(rows []influx.Row, binaryRows []byte) error
ForceFlush()
MaxTime() int64
Count() uint64
SeriesCount() int
Close() error
Ref()
UnRef()
CreateLogicalPlan(ctx context.Context, sources influxql.Sources, schema *executor.QuerySchema) (hybridqp.QueryNode, error)
LogicalPlanCost(sources influxql.Sources, opt query.ProcessorOptions) (hybridqp.LogicalPlanCost, error)
GetSplitPoints(idxes []int64) ([]string, error)
Expired() bool
TierDurationExpired() (tier uint64, expired bool)
RPName() string
GetIndexBuild() *tsi.IndexBuilder
GetID() uint64
Open() error
DataPath() string
WalPath() string
TableStore() immutable.TablesStore
Ident() *meta.ShardIdentifier
Duration() *meta.DurationDescriptor
ChangeShardTierToWarm()
SetWriteColdDuration(duration time.Duration)
SetMutableSizeLimit(size int64)
DropMeasurement(ctx context.Context, name string) error
Statistics(buffer []byte) ([]byte, error)
NewShardKeyIdx(shardType, dataPath string) error
}
type TagSetCursorItem ¶
type TagSetCursorItem struct {
// contains filtered or unexported fields
}
func (TagSetCursorItem) GetNewRecord ¶
func (c TagSetCursorItem) GetNewRecord() (*record.Record, error)