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. nolint
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. nolint
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. nolint
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. nolint
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 AbsentMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
- func AbsentReduce(c Chunk, values []int64, ordinal, start, end int) (int, int64, bool)
- func AbsentWithOutDataAlive(opt *query.ProcessorOptions, outChunk Chunk)
- func AbsoluteDiffFunc[T util.NumberOnly](prev, curr T) T
- func AddRule(mapDescToRule map[string]OptRule, rule OptRule) (bool, map[string]OptRule)
- func AdjustNils(dst Column, src Column, low int, high int)
- func AppendRowValue(column Column, value interface{})
- func B2ui64(b bool) uint64
- func BehindDiffFunc[T util.NumberOnly](prev, curr T) T
- func BinOpADD(lVal, rVal float64) (float64, bool)
- func BinOpATAN2(lVal, rVal float64) (float64, bool)
- func BinOpDIV(lVal, rVal float64) (float64, bool)
- func BinOpEQLC(lVal, rVal float64) (float64, bool)
- func BinOpGTE(lVal, rVal float64) (float64, bool)
- func BinOpGTR(lVal, rVal float64) (float64, bool)
- func BinOpLSS(lVal, rVal float64) (float64, bool)
- func BinOpLTE(lVal, rVal float64) (float64, bool)
- func BinOpMOD(lVal, rVal float64) (float64, bool)
- func BinOpMUL(lVal, rVal float64) (float64, bool)
- func BinOpNEQ(lVal, rVal float64) (float64, bool)
- func BinOpPOW(lVal, rVal float64) (float64, bool)
- func BinOpSUB(lVal, rVal float64) (float64, bool)
- func BooleanAscendingAuxHelper(x, y Column, i, j int) (bool, bool)
- func BooleanAuxHelpFunc(input, output Column, rowIdx ...int)
- func BooleanDescendingAuxHelper(x, y Column, i, j int) (bool, bool)
- func BooleanFirstMerge(prevPoint, currPoint *Point[bool])
- func BooleanFirstReduce(c Chunk, values []bool, ordinal, start, end int) (int, bool, bool)
- func BooleanFirstTimeColFastReduce(c Chunk, values []bool, ordinal, start, end int) (int, bool, bool)
- func BooleanFirstTimeColReduce(c Chunk, values []bool, ordinal, start, end int) (int, bool, bool)
- func BooleanFirstTimeColSlowReduce(c Chunk, values []bool, ordinal, start, end int) (int, bool, bool)
- func BooleanLastMerge(prevPoint, currPoint *Point[bool])
- func BooleanLastReduce(c Chunk, values []bool, ordinal, start, end int) (int, bool, bool)
- func BooleanLastTimeColFastReduce(c Chunk, values []bool, ordinal, start, end int) (int, bool, bool)
- func BooleanLastTimeColReduce(c Chunk, values []bool, ordinal, start, end int) (int, bool, bool)
- func BooleanLastTimeColSlowReduce(c Chunk, values []bool, ordinal, start, end int) (int, bool, bool)
- func BooleanMaxMerge(prevPoint, currPoint *Point[bool])
- func BooleanMaxReduce(c Chunk, values []bool, ordinal, start, end int) (int, bool, bool)
- func BooleanMinMerge(prevPoint, currPoint *Point[bool])
- func BooleanMinReduce(c Chunk, values []bool, ordinal, start, end int) (int, bool, bool)
- func BottomCmpByTimeReduce[T util.NumberOnly](a, b *PointItem[T]) bool
- func BottomCmpByValueReduce[T util.NumberOnly](a, b *PointItem[T]) bool
- func BottomCmpByValueReduceProm[T util.NumberOnly](a, b *PointItem[T]) bool
- func BuildBinOpQueryPlan(ctx context.Context, qc query.LogicalPlanCreator, ...) (hybridqp.QueryNode, error)
- func BuildFullJoinQueryPlan(ctx context.Context, qc query.LogicalPlanCreator, ...) (hybridqp.QueryNode, error)
- func BuildHeuristicPlanner() hybridqp.Planner
- func BuildHeuristicPlannerForStore() hybridqp.Planner
- func BuildInConditionPlan(ctx context.Context, qc query.LogicalPlanCreator, ...) (hybridqp.QueryNode, hybridqp.Catalog, error)
- func BuildSources(ctx context.Context, qc query.LogicalPlanCreator, sources influxql.Sources, ...) (hybridqp.QueryNode, error)
- func CalcChange(preValues []float64, currValues []float64) float64
- func CalcHoltWinters(preV []float64, curV []float64, sf, tf float64) float64
- func CalcLastTwoPoints(preTimes []int64, currTimes []int64, preValues []float64, currValues []float64) (int64, int64, float64, float64)
- func CalcLog2(value float64) int
- func CalcMad(values []float64) float64
- func CalcMad2(preValues []float64, currValues []float64) float64
- func CalcQuantile(q float64, values []float64) float64
- func CalcQuantile2(q float64, preValues []float64, currValues []float64) float64
- func CalcReduceResult(prevT, currT []int64, prevV, currV []float64, isCounter bool) (int64, int64, float64, float64, float64)
- func CalcResets(preV []float64, curV []float64) float64
- func CastorReduce(in []Chunk, out Chunk, args ...interface{}) error
- func ChangeCallExprForTimestamp(call *influxql.Call)
- func ChangeOpsForTimestamp(ops []hybridqp.ExprOptions) []hybridqp.ExprOptions
- func ChunkToArrowRecords(chunks []Chunk, taskId string, args []influxql.Expr) ([]arrow.Record, *errno.Error)
- func ColumnStringValue(c Column, rowLoc int) string
- func CompareBreakPoint(name string, time int64, tag ChunkTags, b *BreakPoint, ...) bool
- func CompareSortedAppendBreakPoint(item Item, in int, tag ChunkTags, b *SortedBreakPoint, ...) bool
- func CompareSortedMergeBreakPoint(item Item, in int, tag ChunkTags, b *SortedBreakPoint, ...) bool
- func Connect(from Port, to Port) error
- func ContainDim(des []string, src string) bool
- func ContainsSameTagset(chunk Chunk) bool
- func CopyArrowRecordToChunk(r arrow.Record, c Chunk, fields map[string]struct{}) *errno.Error
- func CountMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
- func CountReduce(c Chunk, values []int64, ordinal, start, end int) (int, int64, bool)
- func DecodeBytes(bytes []byte) []byte
- func DoCalcChange(curV []float64, prev float64, changes int) (float64, int)
- func DoCalcResets(prevV []float64, prev float64, resets int) (float64, int)
- func EnableFileCursor(en bool)
- func ExpandColumnOffsets(col Column, stringBytes []byte, offsets []uint32) ([]byte, []uint32)
- func ExprWalk(v influxql.Fields, node influxql.Node)
- func FirstMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
- func FirstReduce[T util.ExceptBool](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func FirstTimeColFastReduce[T util.ExceptBool](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func FirstTimeColMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
- func FirstTimeColReduce[T util.ExceptBool](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func FirstTimeColSlowReduce[T util.ExceptBool](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func Float64AscendingAuxHelper(x, y Column, i, j int) (bool, bool)
- func Float64DescendingAuxHelper(x, y Column, i, j int) (bool, bool)
- func Float64Equal(a, b float64) bool
- func FloatAuxHelpFunc(input, output Column, rowIdx ...int)
- func FloatCountPromMerge(prevPoint, currPoint *Point[float64])
- func FloatCountPromReduce(c Chunk, values []float64, ordinal, start, end int) (int, float64, bool)
- func FrontDiffFunc[T util.NumberOnly](prev, curr T) T
- func GetEnableFileCursor() bool
- func GetFieldInfo(chunks []Chunk) (map[string]map[string]*fieldInfo, *errno.Error)
- func GetInnerDimensions(outer, inner []string) []string
- func GetMaxNumsOfGroups() int
- func GetOrdinal(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (int, int)
- func GetPlanSliceByTree(plan hybridqp.QueryNode) []hybridqp.QueryNode
- func GetPlanSliceByTreeDFS(plan hybridqp.QueryNode, dstPlan *[]hybridqp.QueryNode) error
- func GetPromTimeFuncInstance() map[string]PromTimeFunction
- func GetStorePlanTemplate(shardNum int, planType PlanType) []hybridqp.QueryNode
- func GetType(i interface{}) string
- func GetTypeName(i interface{}) string
- func GroupMerge(prevPoint, currPoint *Point[float64])
- func GroupReduce(c Chunk, values []float64, ordinal, start, end int) (int, float64, bool)
- func IndexUnion(index1, index2 []int) []int
- func InitLocalStoreTemplatePlan()
- func InitMstName(item *AppendHeapItems) string
- func IntegerAscendingAuxHelper(x, y Column, i, j int) (bool, bool)
- func IntegerAuxHelpFunc(input, output Column, rowIdx ...int)
- func IntegerDescendingAuxHelper(x, y Column, i, j int) (bool, bool)
- func IntervalIndexGen(ck Chunk, opt *query.ProcessorOptions)
- func IrateFastReduce[T util.NumberOnly](c Chunk, values []T, ordinal, start, end int) (int, int, T, T, bool)
- func IrateFinalReduce[T util.NumberOnly](ft int64, st int64, fv T, sv T, interval *hybridqp.Interval) (float64, bool)
- func IrateMerge[T util.NumberOnly](prevPoints [2]*Point[T], interval *hybridqp.Interval) (float64, bool)
- func IrateMiddleReduce[T util.NumberOnly](c Chunk, values []T, ordinal, start, end int) (int, int, T, T, bool)
- func IrateSlowReduce[T util.NumberOnly](c Chunk, values []T, ordinal, start, end int) (int, int, T, T, bool)
- func IrateUpdate[T util.NumberOnly](prevPoints, currPoints [2]*Point[T])
- func IsEnableFileCursor(schema hybridqp.Catalog) bool
- func IsSubTreeEqual(node hybridqp.QueryNode, comparedNode hybridqp.QueryNode) bool
- func KahanSumInc(inc, sum, c float64) (newSum, newC float64)
- func LastMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
- func LastReduce[T util.ExceptBool](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func LastTimeColFastReduce[T util.ExceptBool](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func LastTimeColMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
- func LastTimeColReduce[T util.ExceptBool](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func LastTimeColSlowReduce[T util.ExceptBool](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func Marshal(plan LogicalPlaner, extMarshal func(pb *internal.QueryNode), ...) ([]byte, error)
- func MarshalBinary(q hybridqp.QueryNode) ([]byte, error)
- func MarshalPtQuerys(ptQuerys []PtQuery) []*proto2.PtQuery
- func MarshalQueryNode(node hybridqp.QueryNode) ([]byte, error)
- func MarshalShardInfos(shardInfos []ShardInfo) []*proto2.ShardInfo
- func MaxMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
- func MaxPromMerge(prevPoint, currPoint *Point[float64])
- func MaxPromReduce(c Chunk, values []float64, ordinal, start, end int) (int, float64, bool)
- func MaxReduce[T util.NumberOnly](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func MinMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
- func MinPromMerge(prevPoint, currPoint *Point[float64])
- func MinPromReduce(c Chunk, values []float64, ordinal, start, end int) (int, float64, bool)
- func MinReduce[T util.NumberOnly](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func NewAggFunc(aggType AggFuncType, fn NewAggOperator, inIdx int, outIdx int, p any) *aggFunc
- func NewAnalyzeResponse(trace *tracing.Trace) *rpc.Message
- func NewBoolSortEle() sortEleMsg
- func NewBooleanModeReduce(BooleanSliceItem *BooleanSliceItem) (int, int64, float64, bool)
- func NewChunkResponse(chunk Chunk) *rpc.Message
- func NewCountFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewCountOperator() aggOperator
- func NewCountPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewCountPromOperator() aggOperator
- func NewErrorMessage(errCode errno.Errno, err string) *rpc.Message
- func NewFinishMessage(queryIndexState int32) *rpc.Message
- func NewFirstBooleanOperator() aggOperator
- func NewFirstFloatOperator() aggOperator
- func NewFirstFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewFirstIntegerOperator() aggOperator
- func NewFirstStringOperator() aggOperator
- func NewFloatSortEle() sortEleMsg
- func NewGroupPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewGroupPromOperator() aggOperator
- func NewHeapFloatOperator() aggOperator
- func NewHeapFunc(inRowDataType, outRowDataType hybridqp.RowDataType, ...) (*aggFunc, error)
- func NewHeapIntegerOperator() aggOperator
- func NewHeapParam(topN int64, sortFuncs []func() sortEleMsg, sorKeyIdx []int, sortAsc []bool, ...) *heapParam
- func NewHeapStringOperator() aggOperator
- func NewHoltWintersReducer(h, m int, includeFitData bool, interval time.Duration) *holtWintersReducer
- func NewIncQueryFinishMessage(isIncQuery, getFailed bool, queryID string, iterMaxNum int32, rowCount int64) *rpc.Message
- func NewIntegerSortEle() sortEleMsg
- func NewInvalidTypeError(exp string, data interface{}) error
- func NewLastBooleanOperator() aggOperator
- func NewLastFloatOperator() aggOperator
- func NewLastFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewLastIntegerOperator() aggOperator
- func NewLastStringOperator() aggOperator
- func NewLocalStoreSqlPlanTypePool(planType PlanType) ([]hybridqp.QueryNode, error)
- func NewMaxBooleanOperator() aggOperator
- func NewMaxFloatOperator() aggOperator
- func NewMaxFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewMaxIntegerOperator() aggOperator
- func NewMaxPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewMaxPromOperator() aggOperator
- func NewMedianReduce[T util.NumberOnly](si *SliceItem[T]) (int, int64, float64, bool)
- func NewMinBooleanOperator() aggOperator
- func NewMinFloatOperator() aggOperator
- func NewMinFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewMinIntegerOperator() aggOperator
- func NewMinPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewMinPromOperator() aggOperator
- func NewModeReduce[T util.ExceptBool](si *SliceItem[T]) (int, int64, float64, bool)
- func NewOneShardStorePlanTypePool(planType PlanType) []hybridqp.QueryNode
- func NewPercentileFloatOperator() aggOperator
- func NewPercentileFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewPercentileIntegerOperator() aggOperator
- func NewPlanBySchemaAndSrcPlan(schema hybridqp.Catalog, srcPlan []hybridqp.QueryNode, eTrait []hybridqp.Trait, ...) (hybridqp.QueryNode, error)
- func NewPreparedStatement(stmt *influxql.SelectStatement, opt hybridqp.Options, shards interface{ ... }, ...) *preparedStatement
- func NewPrevValuesFunc(rowDataType hybridqp.RowDataType) []func(prev Chunk, prevValues []interface{}, ordinal int)
- func NewPrevWindowFunc(rowDataType hybridqp.RowDataType) ([]func(prev Chunk, window *prevWindow, ordinal int), ...)
- func NewProcessors(inRowDataType, outRowDataType hybridqp.RowDataType, ...) (*processorResults, error)
- func NewPromFunc(inRowDataType hybridqp.RowDataType, typ AggFuncType, op func() aggOperator, ...) (*aggFunc, error)
- func NewRPCMessage(typ uint8) transport.Codec
- func NewSortPartition(i int, sortKeysIdxs []int, ascending []bool) *sortPartition
- func NewSortRowMsg(eles []sortEleMsg) *sortRowMsg
- func NewSqlPlanTypePool(planType PlanType) ([]hybridqp.QueryNode, error)
- func NewStdPromOperator(flag bool) aggOperator
- func NewStddevPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewStdvarPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewStorePlanTypePool(planType PlanType) []hybridqp.QueryNode
- func NewStringSortEle() sortEleMsg
- func NewSumFloatOperator() aggOperator
- func NewSumFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
- func NewSumIntegerOperator() aggOperator
- func NewfloatTuple(tuple []float64) *floatTuple
- func PrintPlan(planName string, plan hybridqp.QueryNode)
- func PutIncAggChunk(queryID string, iterID int32, chunk Chunk)
- func PutIncHashAggItem(queryID string, item *IncHashAggItem)
- func RateFastReduce[T util.NumberOnly](c Chunk, values []T, ordinal, start, end int) (int, int, T, T, bool)
- func RateFinalReduce[T util.NumberOnly](firstTime int64, lastTime int64, firstValue T, lastValue T, ...) (float64, bool)
- func RateLowReduce[T util.NumberOnly](c Chunk, values []T, ordinal, start, end int) (int, int, T, T, bool)
- func RateMerge[T util.NumberOnly](prevPoints [2]*Point[T], interval *hybridqp.Interval) (float64, bool)
- func RateMiddleReduce[T util.NumberOnly](c Chunk, values []T, ordinal, start, end int) (int, int, T, T, bool)
- func RateUpdate[T util.NumberOnly](prevPoints, currPoints [2]*Point[T])
- func ReWriteArgs(best hybridqp.QueryNode, isUnifyPlan bool)
- func RebuildAggNodes(plan hybridqp.QueryNode)
- func RebuildColumnStorePlan(plan hybridqp.QueryNode) []hybridqp.QueryNode
- func RegistryAggOp(name string, aggOp AggOperator)
- func RegistryLabelFunction(name string, labelFunc LabelFunction)
- func RegistryPromTimeFunction(name string, timeFunc PromTimeFunction)
- func RegistryReaderCreator(plan LogicalPlan, creator ReaderCreator) bool
- func RegistryTransformCreator(plan LogicalPlan, creator TransformCreator) bool
- func RemoveCommonValues(prev, curr [][]interface{}) [][]interface{}
- func ReplaceSortAggMergeWithHashAgg(plan hybridqp.QueryNode) []hybridqp.QueryNode
- func ReplaceSortAggWithHashAgg(plan hybridqp.QueryNode) []hybridqp.QueryNode
- func ReplaceSortMergeWithHashMerge(plan hybridqp.QueryNode) []hybridqp.QueryNode
- func ResetTime(srcCk, dstCk Chunk, ts int64)
- func ResetTimeForProm(srcCk, dstCk Chunk, ts int64)
- func Select(ctx context.Context, stmt *influxql.SelectStatement, ...) (hybridqp.Executor, error)
- func SetLocalStorageForQuery(storage hybridqp.StoreEngine)
- func SetMaxGroupsNums(numsOfGroups int)
- func SetTimeZero(schema *QuerySchema) bool
- func SlidingWindowMergeFunc[T util.ExceptString](prevWindow, currWindow *SlidingWindow[T], fpm PointMerge[T])
- func SortByTimeAsc[T util.NumberOnly](f *HeapItem[T])
- func SortByValueDsc[T util.NumberOnly](f *HeapItem[T])
- func Str2bytes(s string) []byte
- func StrFunc(srcStr string, subStr string) bool
- func StrLenFunc(srcStr string) int64
- func StringAscendingAuxHelper(x, y Column, i, j int) (bool, bool)
- func StringAuxHelpFunc(input, output Column, rowIdx ...int)
- func StringDescendingAuxHelper(x, y Column, i, j int) (bool, bool)
- func StringFirstMerge(prevPoint, currPoint *StringPoint)
- func StringLastMerge(prevPoint, currPoint *StringPoint)
- func SubStrThreeParaFunc(srcStr string, start, subStrLen int64) string
- func SubStrTwoParaFunc(srcStr string, start int64) string
- func SumMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
- func SumReduce[T util.NumberOnly](c Chunk, values []T, ordinal, start, end int) (int, T, bool)
- func TopCmpByTimeReduce[T util.NumberOnly](a, b *PointItem[T]) bool
- func TopCmpByValueReduce[T util.NumberOnly](a, b *PointItem[T]) bool
- func TopCmpByValueReduceProm[T util.NumberOnly](a, b *PointItem[T]) bool
- func TransMath(c *influxql.Call) (func(dst Column, src Chunk, index []int), error)
- func TransparentForwardBoolean(dst Column, src Chunk, index []int)
- func TransparentForwardBooleanColumn(dst Column, src Column)
- func TransparentForwardFloat(dst Column, src Chunk, index []int)
- func TransparentForwardFloatColumn(dst Column, src Column)
- func TransparentForwardInteger(dst Column, src Chunk, index []int)
- func TransparentForwardIntegerColumn(dst Column, src Column)
- func TransparentForwardString(dst Column, src Chunk, index []int)
- func TransparentForwardStringColumn(dst Column, src Column)
- func TranverseBinTreeForTimestamp(expr influxql.Expr)
- func UnionBitMapArray(b1, b2 []uint16) []uint16
- func UnionColumns(cols ...Column) []uint16
- func UnmarshalBinary(buf []byte, schema hybridqp.Catalog) (hybridqp.QueryNode, error)
- func UnmarshalBinaryNode(pb *internal.QueryNode, schema hybridqp.Catalog) (hybridqp.QueryNode, error)
- func UnmarshalQueryNode(buf []byte, shardNum int, opt hybridqp.Options) (hybridqp.QueryNode, error)
- func UpdateHashBooleanMaxFast(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashBooleanMaxSlow(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashBooleanMinFast(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashBooleanMinSlow(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashFloatMaxFast(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashFloatMaxSlow(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashFloatMinFast(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashFloatMinSlow(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashFloatSumFast(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashFloatSumSlow(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashInterMaxFast(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashInterMaxSlow(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashInterMinFast(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashInterMinSlow(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashInterSumFast(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateHashInterSumSlow(dstChunk, srcChunk Chunk, dstCol, srcCol, dstRow, srcRow int, bitmap *Bitmap)
- func UpdateIncAggFunc(_, _ cache.Entry) bool
- func UpdateIncHashAggFunc(_, _ cache.Entry) bool
- func ValidRpcMessageType(typ byte) bool
- func ValidateFieldsFromPlans(plans []hybridqp.QueryNode) bool
- func Walk(v LogicalPlanVisitor, plan hybridqp.QueryNode)
- type Abort
- type AbortProcessor
- type AbsentIterator
- type AggCallFuncParams
- type AggFactory
- type AggFuncType
- type AggLevel
- type AggOperator
- type AggOperatorMsgs
- type AggPushDownToColumnStoreReaderRule
- type AggPushDownToSubQueryRule
- type AggPushdownToExchangeRule
- type AggPushdownToReaderRule
- type AggPushdownToSeriesRule
- type AggSpreadToExchangeRule
- type AggSpreadToReaderRule
- type AggSpreadToSortAppendRule
- type AggToProjectInSubQueryRule
- type AlignTransform
- func (trans *AlignTransform) Close()
- func (trans *AlignTransform) Explain() []ValuePair
- func (trans *AlignTransform) GetInputNumber(port Port) int
- func (trans *AlignTransform) GetInputs() Ports
- func (trans *AlignTransform) GetOutputNumber(port Port) int
- func (trans *AlignTransform) GetOutputs() Ports
- func (trans *AlignTransform) Name() string
- func (trans *AlignTransform) SendChunk()
- func (trans *AlignTransform) Work(ctx context.Context) error
- type AlignTransformCreator
- type AnalyzeResponse
- type AppendHeapItems
- func (h *AppendHeapItems) GetBreakPoint() BaseBreakPoint
- func (h *AppendHeapItems) GetOption() *query.ProcessorOptions
- func (h *AppendHeapItems) Len() int
- func (h *AppendHeapItems) Less(i, j int) bool
- func (h *AppendHeapItems) Pop() interface{}
- func (h *AppendHeapItems) Push(x interface{})
- func (h *AppendHeapItems) Swap(i, j int)
- type AttachedFrags
- type AttachedIndexInfo
- type AuxProcessor
- type BaseBreakPoint
- type BaseFrags
- func (s *BaseFrags) AddFragCount(fragCount int64)
- func (s *BaseFrags) AppendFragRanges(frs ...fragment.FragmentRanges)
- func (s *BaseFrags) BasePath() string
- func (s *BaseFrags) FileMode() FileMode
- func (s *BaseFrags) FragCount() int64
- func (s *BaseFrags) FragRanges() []fragment.FragmentRanges
- func (s *BaseFrags) GetErr() error
- func (s *BaseFrags) SetErr(err error)
- func (s *BaseFrags) Size() int
- type BaseHeapItems
- type BaseMergeIterator
- type BaseProcessor
- func (bp *BaseProcessor) Abort()
- func (bp *BaseProcessor) Analyze(span *tracing.Span)
- func (bp *BaseProcessor) BaseSpan() *tracing.Span
- func (bp *BaseProcessor) FinishSpan()
- func (bp *BaseProcessor) Interrupt()
- func (bp *BaseProcessor) InterruptWithoutMark()
- func (bp *BaseProcessor) IsSink() bool
- func (bp *BaseProcessor) Once(fn func())
- func (bp *BaseProcessor) Release() error
- func (bp *BaseProcessor) StartSpan(name string, withPP bool) *tracing.Span
- type BasePromOp
- type BaseTransData
- type BatchMPool
- type BinOpTransform
- func (trans *BinOpTransform) AddResult(secondaryChunk Chunk) error
- func (trans *BinOpTransform) AddResultSimple(secondaryChunk Chunk)
- func (trans *BinOpTransform) BinOpHelperConditionBoth(ctx context.Context, errs *errno.Errs)
- func (trans *BinOpTransform) BinOpHelperConditionSingle(ctx context.Context, errs *errno.Errs)
- func (trans *BinOpTransform) BinOpHelperConditionSingleExpr(ctx context.Context, errs *errno.Errs)
- func (trans *BinOpTransform) BinOpHelperOperator(ctx context.Context, errs *errno.Errs)
- func (trans *BinOpTransform) Close()
- func (trans *BinOpTransform) ComputeResultTags(pTagKeys, pTagValues, sTagKeys, sTagValues []string) ([]string, []string, string)
- func (trans *BinOpTransform) Explain() []ValuePair
- func (trans *BinOpTransform) GetInputNumber(_ Port) int
- func (trans *BinOpTransform) GetInputs() Ports
- func (trans *BinOpTransform) GetOutputNumber(_ Port) int
- func (trans *BinOpTransform) GetOutputs() Ports
- func (trans *BinOpTransform) Name() string
- func (trans *BinOpTransform) SendChunk()
- func (trans *BinOpTransform) Work(ctx context.Context) error
- type BinOpTransformCreator
- type Bitmap
- func (b *Bitmap) Clear()
- func (b *Bitmap) CopyTo(dst *Bitmap)
- func (b *Bitmap) GetArray() []uint16
- func (b *Bitmap) GetBit() []byte
- func (b *Bitmap) GetLength() int
- func (b *Bitmap) Instance() transport.Codec
- func (b *Bitmap) Marshal(buf []byte) ([]byte, error)
- func (b *Bitmap) Reverse()
- func (b *Bitmap) SetArray(arr []uint16)
- func (b *Bitmap) SetLen(len int)
- func (b *Bitmap) SetNilCount(nilCount int)
- func (b *Bitmap) Size() int
- func (b *Bitmap) String() string
- func (b *Bitmap) Unmarshal(buf []byte) error
- func (b *Bitmap) UpdateBitWithArray(dat []bool)
- type BlockChunkPool
- type BooleanAlignIterator
- type BooleanAppendIterator
- type BooleanColBooleanDistinctIterator
- type BooleanColBooleanSampleIterator
- type BooleanColBooleanSliceIterator
- type BooleanColBooleanWindowReduce
- type BooleanColReduceSliceReduce
- type BooleanDistinctItem
- type BooleanFieldValuer
- type BooleanIntervalIterator
- type BooleanIterator
- type BooleanLimitIterator
- type BooleanLinearFillProcessor
- type BooleanMergeIterator
- type BooleanNullFillProcessor
- type BooleanNumberFillProcessor
- type BooleanPreviousFillProcessor
- type BooleanReduce
- type BooleanSliceItem
- type BooleanTimeColBooleanIterator
- type BooleanTimeColBooleanMerge
- type BooleanTimeColBooleanReduce
- type BreakPoint
- type BufEle
- type Byte
- type CONTEXT_IDENTIFIER
- type CSIndexInfo
- type CallFn
- type CancelOnlySource
- func (source *CancelOnlySource) Close()
- func (source *CancelOnlySource) Explain() []ValuePair
- func (source *CancelOnlySource) GetInputNumber(_ Port) int
- func (source *CancelOnlySource) GetInputs() Ports
- func (source *CancelOnlySource) GetOutputNumber(_ Port) int
- func (source *CancelOnlySource) GetOutputs() Ports
- func (source *CancelOnlySource) Name() string
- func (source *CancelOnlySource) Work(ctx context.Context) error
- type CastorAggCutRule
- type Chunk
- type ChunkBuilder
- type ChunkImpl
- func (c *ChunkImpl) AddColumn(cols ...Column)
- func (c *ChunkImpl) AddDim(cols ...Column)
- func (c *ChunkImpl) AddDims(dimsVals []string)
- func (c *ChunkImpl) AddIntervalIndex(i int)
- func (c *ChunkImpl) AddTagAndIndex(tag ChunkTags, i int)
- func (c *ChunkImpl) AppendIntervalFullRows(start, step int64, num int, tag ChunkTags)
- func (c *ChunkImpl) AppendIntervalIndex(intervalIndex int)
- func (c *ChunkImpl) AppendIntervalIndexes(intervalIndex []int)
- func (c *ChunkImpl) AppendTagsAndIndex(tag ChunkTags, tagIndex int)
- func (c *ChunkImpl) AppendTagsAndIndexes(tags []ChunkTags, tagIndex []int)
- func (c *ChunkImpl) AppendTime(t int64)
- func (c *ChunkImpl) AppendTimes(ts []int64)
- func (c *ChunkImpl) CheckChunk()
- func (c *ChunkImpl) Clone() Chunk
- func (c *ChunkImpl) Column(i int) Column
- func (c *ChunkImpl) Columns() []Column
- func (c *ChunkImpl) CopyByRowDataType(dst Chunk, fromRt hybridqp.RowDataType, dstRt hybridqp.RowDataType) error
- func (c *ChunkImpl) CopyGroup(dst Chunk, tagLoc, start, end int) Chunk
- func (c *ChunkImpl) CopyTags(dst Chunk, tagLoc int) Chunk
- func (c *ChunkImpl) CopyTo(dstChunk Chunk)
- func (c *ChunkImpl) CreatePointRowIterator(name string, valuer *FieldsValuer) PointRowIterator
- func (c *ChunkImpl) Dim(i int) Column
- func (c *ChunkImpl) Dims() []Column
- func (c *ChunkImpl) GetRecord() *record.Record
- func (c *ChunkImpl) InitTimeWindow(minTime, maxTime, intervalTime int64, hasInterval, ascending bool, ...)
- func (c *ChunkImpl) Instance() transport.Codec
- func (c *ChunkImpl) IntervalIndex() []int
- func (c *ChunkImpl) IntervalLen() int
- func (c *ChunkImpl) IsNil() booldeprecated
- func (c *ChunkImpl) Len() int
- func (c *ChunkImpl) Marshal(buf []byte) ([]byte, error)
- func (c *ChunkImpl) Name() string
- func (c *ChunkImpl) NewDims(size int)
- func (c *ChunkImpl) NumberOfCols() int
- func (c *ChunkImpl) NumberOfRows() int
- func (c *ChunkImpl) PromStepInvariant(typ PromStepInvariantType, preGroup []byte, nextGroup []byte, ...) Chunk
- func (c *ChunkImpl) PromStepInvariantOnlyLastGroup(preGroup []byte, nextGroup []byte, step, startT, endT int64) Chunk
- func (c *ChunkImpl) PromStepInvariantSkipLastGroup(preGroup []byte, step, startT, endT int64, dst Chunk) Chunk
- func (c *ChunkImpl) Release()
- func (c *ChunkImpl) Reset()
- func (c *ChunkImpl) ResetIntervalIndex(intervalIndex ...int)
- func (c *ChunkImpl) ResetTagsAndIndexes(tags []ChunkTags, tagIndex []int)
- func (c *ChunkImpl) ResetTime(idx int, time int64)
- func (c *ChunkImpl) RowDataType() hybridqp.RowDataType
- func (c *ChunkImpl) SetColumn(col Column, i int)
- func (c *ChunkImpl) SetDim(col Column, i int)
- func (c *ChunkImpl) SetName(name string)
- func (c *ChunkImpl) SetRowDataType(r hybridqp.RowDataType)
- func (c *ChunkImpl) SetTime(time []int64)
- func (c *ChunkImpl) Size() int
- func (c *ChunkImpl) SlimChunk(ridIdx []int) Chunk
- func (c *ChunkImpl) String() string
- func (c *ChunkImpl) TagIndex() []int
- func (c *ChunkImpl) TagLen() int
- func (c *ChunkImpl) Tags() []ChunkTags
- func (c *ChunkImpl) Time() []int64
- func (c *ChunkImpl) TimeByIndex(i int) int64
- func (c *ChunkImpl) TruncateTime(idx int)
- func (c *ChunkImpl) Unmarshal(buf []byte) error
- type ChunkIterator
- type ChunkPort
- type ChunkPorts
- type ChunkTags
- func NewChunkTags(pts influx.PointTags, dimensions []string) *ChunkTags
- func NewChunkTagsByBytes(bytes []byte) *ChunkTags
- func NewChunkTagsByTagKVs(k []string, v []string) *ChunkTags
- func NewChunkTagsDeepCopy(subset []byte, offsets []uint16) *ChunkTags
- func NewChunkTagsV2(subset []byte) *ChunkTags
- func NewChunkTagsWithoutDims(pts influx.PointTags, withoutDims []string) *ChunkTags
- func (ct *ChunkTags) DecodeTagsWithoutTag(tagName string) ([]byte, string)
- func (ct *ChunkTags) GetChunkTagAndValues() ([]string, []string)
- func (ct *ChunkTags) GetChunkTagValue(name string) (string, bool)
- func (c *ChunkTags) GetOffsets() []uint16
- func (ct *ChunkTags) GetTag() []byte
- func (ct *ChunkTags) Instance() transport.Codec
- func (ct *ChunkTags) KeepKeys(keys []string) *ChunkTags
- func (ct *ChunkTags) KeyValues() map[string]string
- func (ct *ChunkTags) Marshal(buf []byte) ([]byte, error)
- func (ct *ChunkTags) PointTags() influx.PointTags
- func (ct *ChunkTags) RemoveKeys(keys []string) *ChunkTags
- func (ct *ChunkTags) Reset()
- func (ct *ChunkTags) Size() int
- func (ct *ChunkTags) Subset(keys []string) []byte
- func (ct *ChunkTags) Unmarshal(buf []byte) error
- type ChunkValuer
- func (c *ChunkValuer) AtChunkRow(chunk Chunk, index int)
- func (c *ChunkValuer) SetValueFnOnlyPromTime()
- func (c *ChunkValuer) SetValuer(_ influxql.Valuer, _ int)
- func (c *ChunkValuer) Value(key string) (interface{}, bool)
- func (c *ChunkValuer) ValueNormal(key string) (interface{}, bool)
- func (c *ChunkValuer) ValueProm(key string) (interface{}, bool)
- func (c *ChunkValuer) ValuePromTime(key string) (interface{}, bool)
- type ChunkWriter
- type CircularChunkPool
- type Cluster
- type ClusterPool
- type ClusterSet
- type CoProcessor
- func AppendColumnsIteratorHelper(rowDataType hybridqp.RowDataType) CoProcessor
- func FixedColumnsIteratorHelper(rowDataType hybridqp.RowDataType) CoProcessor
- func FixedMergeColumnsIteratorHelper(rowDataType hybridqp.RowDataType) CoProcessor
- func NewAlignCoProcessor(rowDataType hybridqp.RowDataType) CoProcessor
- func NewIntervalCoProcessor(rowDataType hybridqp.RowDataType) CoProcessor
- func NewSlidingWindowProcessors(inRowDataType, outRowDataType hybridqp.RowDataType, ...) (CoProcessor, int, int)
- func NewWideProcessorImpl(inRowDataType, outRowDataType hybridqp.RowDataType, ...) (CoProcessor, error)
- type CoProcessorImpl
- type ColMergeFunc
- type ColReduceFunc
- type Column
- type ColumnImpl
- func (c *ColumnImpl) AppendBooleanValue(value bool)
- func (c *ColumnImpl) AppendBooleanValues(values []bool)
- func (c *ColumnImpl) AppendColumnTime(value int64)
- func (c *ColumnImpl) AppendColumnTimes(values []int64)
- func (c *ColumnImpl) AppendFloatTuple(tuple floatTuple)
- func (c *ColumnImpl) AppendFloatTuples(tuples []floatTuple)
- func (c *ColumnImpl) AppendFloatValue(value float64)
- func (c *ColumnImpl) AppendFloatValues(values []float64)
- func (c *ColumnImpl) AppendIntegerValue(value int64)
- func (c *ColumnImpl) AppendIntegerValues(values []int64)
- func (c *ColumnImpl) AppendManyNil(num int)
- func (c *ColumnImpl) AppendManyNotNil(num int)
- func (c *ColumnImpl) AppendNil()
- func (c *ColumnImpl) AppendNilsV2(dat ...bool)
- func (c *ColumnImpl) AppendNotNil()
- func (c *ColumnImpl) AppendStringBytes(val []byte, offset []uint32)
- func (c *ColumnImpl) AppendStringValue(value string)deprecated
- func (c *ColumnImpl) AppendStringValues(values []string)deprecated
- func (c *ColumnImpl) BitMap() *Bitmap
- func (c *ColumnImpl) BooleanValue(idx int) bool
- func (c *ColumnImpl) BooleanValues() []bool
- func (c *ColumnImpl) CheckColumn(length int)
- func (c *ColumnImpl) CloneStringValues(val []byte, offset []uint32)
- func (c *ColumnImpl) ColumnTime(idx int) int64
- func (c *ColumnImpl) ColumnTimes() []int64
- func (c *ColumnImpl) DataType() influxql.DataType
- func (c *ColumnImpl) FloatTuple(idx int) floatTuple
- func (c *ColumnImpl) FloatTuples() []floatTuple
- func (c *ColumnImpl) FloatValue(idx int) float64
- func (c *ColumnImpl) FloatValues() []float64
- func (c *ColumnImpl) GetRangeValueIndexV2(bmStart, bmEnd int) (int, int)
- func (c *ColumnImpl) GetStringBytes() ([]byte, []uint32)
- func (c *ColumnImpl) GetStringValueBytes(valueBits []byte, value []string, start, end int) ([]byte, []string)
- func (c *ColumnImpl) GetTimeIndex(valIdx int) int
- func (c *ColumnImpl) GetValueIndexV2(start int) int
- func (c *ColumnImpl) Instance() transport.Codec
- func (c *ColumnImpl) IntegerValue(idx int) int64
- func (c *ColumnImpl) IntegerValues() []int64
- func (c *ColumnImpl) IsEmpty() bool
- func (c *ColumnImpl) IsNilV2(idx int) bool
- func (c *ColumnImpl) Length() int
- func (c *ColumnImpl) Marshal(buf []byte) ([]byte, error)
- func (c *ColumnImpl) NilCount() int
- func (c *ColumnImpl) NilsV2() *Bitmap
- func (c *ColumnImpl) Reset()
- func (c *ColumnImpl) SetBooleanValues(values []bool)
- func (c *ColumnImpl) SetColumnTimes(values []int64)
- func (c *ColumnImpl) SetFloatTuples(tuples []floatTuple)
- func (c *ColumnImpl) SetFloatValues(values []float64)
- func (c *ColumnImpl) SetIntegerValues(values []int64)
- func (c *ColumnImpl) SetNilsBitmap(new *Bitmap)
- func (c *ColumnImpl) SetStringValues(val []byte, offset []uint32)
- func (c *ColumnImpl) Size() int
- func (c *ColumnImpl) StringValue(idx int) string
- func (c *ColumnImpl) StringValuesRange(dst []string, start, end int) []string
- func (c *ColumnImpl) StringValuesRangeV2(dst []string, start, end int) []string
- func (c *ColumnImpl) StringValuesV2(dst []string) []string
- func (c *ColumnImpl) StringValuesWithOffset(start, end int, offsets []uint32) ([]byte, []uint32)
- func (c *ColumnImpl) Unmarshal(buf []byte) error
- func (c *ColumnImpl) UpdateBooleanValueFast(v bool, row int)
- func (c *ColumnImpl) UpdateFloatValueFast(v float64, row int)
- func (c *ColumnImpl) UpdateIntegerValueFast(v int64, row int)
- type ConditionExprVisitor
- type ContextKey
- type CountValuesIterator
- type CountValuesOp
- type Crash
- type CsStoreExchangeTraits
- type DAG
- func (dag *DAG) AddEdge(edges Edges, edge *Edge, from Processor, to Processor) (Edges, error)
- func (dag *DAG) AddEdges(id VertexId, inputmap map[uintptr]VertexId, outputmap map[uintptr]VertexId) error
- func (dag *DAG) CyclicGraph() bool
- func (dag *DAG) Explain(fn func(*DAG, *strings.Builder) VertexWriter) VertexWriter
- func (dag *DAG) OrphanVertexs() []VertexId
- func (dag *DAG) Path() int
- func (dag *DAG) Processors() Processors
- func (dag *DAG) SinkVertexs() []VertexId
- func (dag *DAG) Size() int
- func (dag *DAG) SourceVertexs() []VertexId
- func (dag *DAG) Span() int
- func (dag *DAG) Walk(id VertexId, backward bool, fn WalkFn, m map[VertexId]int) error
- type DAGBuilder
- type DeleteClusterSet
- type DetachedFrags
- type DetachedIndexInfo
- type DistinctItem
- type DownSampleState
- type DownSampleStatePort
- func (p *DownSampleStatePort) Close()
- func (p *DownSampleStatePort) Connect(to Port)
- func (p *DownSampleStatePort) ConnectStateReserve(to Port)
- func (p *DownSampleStatePort) ConnectionId() uintptr
- func (p *DownSampleStatePort) Equal(to Port) bool
- func (p *DownSampleStatePort) Redirect(to Port)
- func (p *DownSampleStatePort) Release()
- type Edge
- type Edges
- type ElapsedItem
- func (f *ElapsedItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *ElapsedItem) AppendItemFastFunc(c Chunk, _ int, start, end int, sameInterval bool)
- func (f *ElapsedItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *ElapsedItem) GetBaseTransData() BaseTransData
- func (f *ElapsedItem) Len() int
- func (f *ElapsedItem) PrevNil() bool
- func (f *ElapsedItem) Reset()
- func (f *ElapsedItem) ResetPrev()
- type EndPointPair
- type EquivalenceExprRewriter
- type Error
- type Exchange
- type ExchangeRole
- type ExchangeType
- type ExecutorBuilder
- func NewColStoreScanExecutorBuilder(traits *StoreExchangeTraits, indexInfo interface{}, info *IndexScanExtraInfo) *ExecutorBuilder
- func NewCsStoreExecutorBuilder(traits *CsStoreExchangeTraits, s hybridqp.StoreEngine, req *RemoteQuery, ...) *ExecutorBuilder
- func NewIndexScanExecutorBuilder(traits *StoreExchangeTraits, enableBinaryTreeMerge int64) *ExecutorBuilder
- func NewMocStoreExecutorBuilder(traits *StoreExchangeTraits, csTraits *CsStoreExchangeTraits, ...) *ExecutorBuilder
- func NewQueryExecutorBuilder(enableBinaryTreeMerge int64) *ExecutorBuilder
- func NewScannerStoreExecutorBuilder(traits *StoreExchangeTraits, s hybridqp.StoreEngine, req *RemoteQuery, ...) *ExecutorBuilder
- func NewSparseIndexScanExecutorBuilder(frags *ShardsFragmentsGroups, info *IndexScanExtraInfo) *ExecutorBuilder
- func NewStoreExecutorBuilder(traits *StoreExchangeTraits, enableBinaryTreeMerge int64) *ExecutorBuilder
- func (builder *ExecutorBuilder) Analyze(span *tracing.Span)
- func (builder *ExecutorBuilder) Build(node hybridqp.QueryNode) (hybridqp.Executor, error)
- func (builder *ExecutorBuilder) CanOptimizeExchange(node hybridqp.QueryNode, children []*TransformVertex) (*TransformVertex, bool)
- func (builder *ExecutorBuilder) IsMultiMstPlanNode(node hybridqp.QueryNode) bool
- func (builder *ExecutorBuilder) NextInfo()
- func (builder *ExecutorBuilder) NextMst()
- func (builder *ExecutorBuilder) SetInfo(info *IndexScanExtraInfo)
- func (builder *ExecutorBuilder) SetInfosAndTraits(mstsReqs []*MultiMstReqs, ctx context.Context)
- func (builder *ExecutorBuilder) SetMultiMstInfosForLocalStore(t []*IndexScanExtraInfo)
- func (builder *ExecutorBuilder) SetMultiMstTraitsForLocalStore(t []*StoreExchangeTraits)
- func (builder *ExecutorBuilder) SetTraits(t *StoreExchangeTraits)
- type ExprRewriteRule
- type ExprRewriteRules
- type FieldValuer
- type FieldsValuer
- type FileFragment
- type FileFragmentImpl
- func (f *FileFragmentImpl) AppendFragmentRange(frs fragment.FragmentRanges)
- func (f *FileFragmentImpl) CutTo(num int64) FileFragment
- func (f *FileFragmentImpl) FragmentCount() int64
- func (f *FileFragmentImpl) GetFile() immutable.TSSPFile
- func (f *FileFragmentImpl) GetFragmentRange(i int) *fragment.FragmentRange
- func (f *FileFragmentImpl) GetFragmentRanges() fragment.FragmentRanges
- type FileFragments
- type FileMode
- type FillItem
- type FillProcessor
- func NewFillProcessor(rowDataType hybridqp.RowDataType, schema *QuerySchema) ([]FillProcessor, error)
- func NewLinearFillProcessor(rowDataType hybridqp.RowDataType) []FillProcessor
- func NewNullFillProcessor(rowDataType hybridqp.RowDataType, schema *QuerySchema) []FillProcessor
- func NewNumberFillProcessor(rowDataType hybridqp.RowDataType) []FillProcessor
- func NewPreviousFillProcessor(rowDataType hybridqp.RowDataType) []FillProcessor
- type FillTransform
- func (trans *FillTransform) Close()
- func (trans *FillTransform) Explain() []ValuePair
- func (trans *FillTransform) GetInputNumber(port Port) int
- func (trans *FillTransform) GetInputs() Ports
- func (trans *FillTransform) GetOutputNumber(port Port) int
- func (trans *FillTransform) GetOutputs() Ports
- func (trans *FillTransform) Name() string
- func (trans *FillTransform) NextChunk()
- func (trans *FillTransform) Work(ctx context.Context) error
- type FillTransformCreator
- type FilterBlankTransform
- func (trans *FilterBlankTransform) Close()
- func (trans *FilterBlankTransform) Explain() []ValuePair
- func (trans *FilterBlankTransform) GetInputNumber(port Port) int
- func (trans *FilterBlankTransform) GetInputs() Ports
- func (trans *FilterBlankTransform) GetOutputNumber(port Port) int
- func (trans *FilterBlankTransform) GetOutputs() Ports
- func (trans *FilterBlankTransform) Name() string
- func (trans *FilterBlankTransform) Work(ctx context.Context) error
- type FilterBlankTransformCreator
- type FilterTransform
- func (trans *FilterTransform) Close()
- func (trans *FilterTransform) Explain() []ValuePair
- func (trans *FilterTransform) GetInputNumber(port Port) int
- func (trans *FilterTransform) GetInputs() Ports
- func (trans *FilterTransform) GetOutputNumber(port Port) int
- func (trans *FilterTransform) GetOutputs() Ports
- func (trans *FilterTransform) Name() string
- func (trans *FilterTransform) Release() error
- func (trans *FilterTransform) Work(ctx context.Context) error
- type FilterTransformCreator
- type Finish
- type Float64AppendIterator
- type Float64LimitIterator
- type Float64MergeIterator
- type FloatAlignIterator
- type FloatColFloatDistinctIterator
- type FloatColFloatHeapIterator
- type FloatColFloatHistogramIterator
- type FloatColFloatRateIterator
- type FloatColFloatSampleIterator
- type FloatColFloatSliceIterator
- type FloatColReduceHistogramReduce
- type FloatCountPromOp
- type FloatCumulativeSumItem
- func (f *FloatCumulativeSumItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatCumulativeSumItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatCumulativeSumItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatCumulativeSumItem) GetBaseTransData() BaseTransData
- func (f *FloatCumulativeSumItem) Len() int
- func (f *FloatCumulativeSumItem) PrevNil() bool
- func (f *FloatCumulativeSumItem) Reset()
- func (f *FloatCumulativeSumItem) ResetPrev()
- type FloatDerivativeItem
- func (f *FloatDerivativeItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatDerivativeItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatDerivativeItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatDerivativeItem) GetBaseTransData() BaseTransData
- func (f *FloatDerivativeItem) Len() int
- func (f *FloatDerivativeItem) PrevNil() bool
- func (f *FloatDerivativeItem) Reset()
- func (f *FloatDerivativeItem) ResetPrev()
- type FloatDifferenceItem
- func (f *FloatDifferenceItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatDifferenceItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatDifferenceItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatDifferenceItem) GetBaseTransData() BaseTransData
- func (f *FloatDifferenceItem) Len() int
- func (f *FloatDifferenceItem) PrevNil() bool
- func (f *FloatDifferenceItem) Reset()
- func (f *FloatDifferenceItem) ResetPrev()
- type FloatFieldValuer
- type FloatIntegralIterator
- type FloatIntervalIterator
- type FloatIterator
- type FloatLinearFillProcessor
- type FloatMovingAverageItem
- func (f *FloatMovingAverageItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatMovingAverageItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatMovingAverageItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *FloatMovingAverageItem) GetBaseTransData() BaseTransData
- func (f *FloatMovingAverageItem) Len() int
- func (f *FloatMovingAverageItem) PrevNil() bool
- func (f *FloatMovingAverageItem) Reset()
- func (f *FloatMovingAverageItem) ResetPrev()
- type FloatNullFillProcessor
- type FloatNumberFillProcessor
- type FloatOGSketchInsertItem
- type FloatOGSketchPercentileItem
- type FloatPercentileApproxItem
- type FloatPreviousFillProcessor
- type FloatTimeColFloatIterator
- type FloatTransIterator
- type FloatTupleMergeIterator
- type FrequentResult
- type FullJoinTransform
- func (trans *FullJoinTransform) Close()
- func (trans *FullJoinTransform) Explain() []ValuePair
- func (trans *FullJoinTransform) GetInputNumber(_ Port) int
- func (trans *FullJoinTransform) GetInputs() Ports
- func (trans *FullJoinTransform) GetOutputNumber(_ Port) int
- func (trans *FullJoinTransform) GetOutputs() Ports
- func (trans *FullJoinTransform) Name() string
- func (trans *FullJoinTransform) NewChunkElem(chunk Chunk, seriesKeyLoc int, seriesValLoc int) *chunkElem
- func (trans *FullJoinTransform) SendChunk()
- func (trans *FullJoinTransform) Work(ctx context.Context) error
- type FullJoinTransformCreator
- type GraphIterator
- type GroupByTransform
- func (trans *GroupByTransform) Close()
- func (trans *GroupByTransform) Explain() []ValuePair
- func (trans *GroupByTransform) GetInputNumber(_ Port) int
- func (trans *GroupByTransform) GetInputs() Ports
- func (trans *GroupByTransform) GetOutputNumber(_ Port) int
- func (trans *GroupByTransform) GetOutputs() Ports
- func (trans *GroupByTransform) Name() string
- func (trans *GroupByTransform) Release() error
- func (trans *GroupByTransform) Work(ctx context.Context) error
- type GroupByTransformCreator
- type GroupKeysMPool
- func (gkp *GroupKeysMPool) AllocGroupKeys(size int) [][]byte
- func (gkp *GroupKeysMPool) AllocGroupTags(size int) []*ChunkTags
- func (gkp *GroupKeysMPool) AllocValues(size int) []uint64
- func (gkp *GroupKeysMPool) AllocZValues(size int) []int64
- func (gkp *GroupKeysMPool) FreeGroupKeys(groupKeys [][]byte)
- func (gkp *GroupKeysMPool) FreeGroupTags(groupTags []*ChunkTags)
- func (gkp *GroupKeysMPool) FreeValues(values []uint64)
- func (gkp *GroupKeysMPool) FreeZValue(spillState []int64)
- type GroupLocs
- type Handler
- type HashAggTransform
- func (trans *HashAggTransform) Close()
- func (trans *HashAggTransform) Explain() []ValuePair
- func (trans *HashAggTransform) GetFuncs() []aggFunc
- func (trans *HashAggTransform) GetInputNumber(_ Port) int
- func (trans *HashAggTransform) GetInputs() Ports
- func (trans *HashAggTransform) GetOutputNumber(_ Port) int
- func (trans *HashAggTransform) GetOutputs() Ports
- func (trans *HashAggTransform) InitFuncs(inRowDataType, outRowDataType hybridqp.RowDataType, ...) error
- func (trans *HashAggTransform) Name() string
- func (trans *HashAggTransform) Work(ctx context.Context) error
- type HashAggTransformCreator
- type HashAggType
- type HashMergeBooleanColumn
- type HashMergeColumn
- type HashMergeFloatColumn
- type HashMergeIntegerColumn
- type HashMergeMsg
- type HashMergeResult
- type HashMergeStringColumn
- type HashMergeTransform
- func NewHashMergeHashTypeTransform(inRowDataType, outRowDataType []hybridqp.RowDataType, s *QuerySchema) (*HashMergeTransform, error)
- func NewHashMergeStreamTypeTransform(inRowDataType, outRowDataType []hybridqp.RowDataType, s *QuerySchema) (*HashMergeTransform, error)
- func NewHashMergeTransform(inRowDataType, outRowDataType []hybridqp.RowDataType, s *QuerySchema) (*HashMergeTransform, error)
- func (trans *HashMergeTransform) Close()
- func (trans *HashMergeTransform) Explain() []ValuePair
- func (trans *HashMergeTransform) GetInputNumber(_ Port) int
- func (trans *HashMergeTransform) GetInputs() Ports
- func (trans *HashMergeTransform) GetOutputNumber(_ Port) int
- func (trans *HashMergeTransform) GetOutputs() Ports
- func (trans *HashMergeTransform) Name() string
- func (trans *HashMergeTransform) Work(ctx context.Context) error
- type HashMergeTransformCreator
- type HashMergeType
- type HeapItem
- type HeapItems
- type HeuDag
- func (dag *HeuDag) AddEdge(from *HeuVertex, to *HeuVertex) bool
- func (dag *HeuDag) AddVerteix(vertex *HeuVertex) bool
- func (dag *HeuDag) AllParents(vertex *HeuVertex) []*HeuVertex
- func (dag *HeuDag) Contains(vertex *HeuVertex) bool
- func (dag *HeuDag) DigestSize() int
- func (dag *HeuDag) EdgeSize() int
- func (dag *HeuDag) GetGraphIterator(vertex *HeuVertex, matchOrder HeuMatchOrder) *GraphIterator
- func (dag *HeuDag) GetVertexByDigest(digest string) (*HeuVertex, bool)
- func (dag *HeuDag) RemoveEdge(from *HeuVertex, to *HeuVertex)
- func (dag *HeuDag) RemoveVertex(vertex *HeuVertex)
- func (dag *HeuDag) UpdateVerteix(vertex *HeuVertex, node hybridqp.QueryNode)
- func (dag *HeuDag) VertexSize() int
- func (dag *HeuDag) WalkHeuDag(visitor HeuDagVisitor, vertex *HeuVertex)
- type HeuDagVisitor
- type HeuEdge
- type HeuInstruction
- type HeuMatchOrder
- type HeuPlanner
- type HeuPlannerImpl
- func (p *HeuPlannerImpl) AddRule(rule OptRule) bool
- func (p *HeuPlannerImpl) ExecuteInstruction(instruction HeuInstruction)
- func (p *HeuPlannerImpl) FindBestExp() hybridqp.QueryNode
- func (p *HeuPlannerImpl) SetRoot(root hybridqp.QueryNode)
- func (p *HeuPlannerImpl) Transformations() int
- func (p *HeuPlannerImpl) Vertex(node hybridqp.QueryNode) (*HeuVertex, bool)
- func (p *HeuPlannerImpl) Visit(node hybridqp.QueryNode) hybridqp.QueryNodeVisitor
- type HeuProgram
- type HeuVertex
- func (v *HeuVertex) ApplyTrait(trait hybridqp.Trait)
- func (v *HeuVertex) Children() []hybridqp.QueryNode
- func (v *HeuVertex) Clone() hybridqp.QueryNode
- func (v *HeuVertex) DeriveOperations()
- func (v *HeuVertex) Digest() string
- func (v *HeuVertex) Dummy() bool
- func (v *HeuVertex) Equals(rhs *HeuVertex) bool
- func (v *HeuVertex) GetParentVertex(vertex *HeuVertex) *HeuVertex
- func (v *HeuVertex) ID() uint64
- func (v *HeuVertex) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (v *HeuVertex) Node() hybridqp.QueryNode
- func (v *HeuVertex) ReplaceChild(ordinal int, child hybridqp.QueryNode)
- func (v *HeuVertex) ReplaceChildren(children []hybridqp.QueryNode)
- func (v *HeuVertex) ReplaceNode(node hybridqp.QueryNode)
- func (v *HeuVertex) RowDataType() hybridqp.RowDataType
- func (v *HeuVertex) RowExprOptions() []hybridqp.ExprOptions
- func (v *HeuVertex) Schema() hybridqp.Catalog
- func (v *HeuVertex) SetInputs(_ []hybridqp.QueryNode)
- func (v *HeuVertex) SetSchema(schema hybridqp.Catalog)
- func (v *HeuVertex) String() string
- func (v *HeuVertex) SubTreeEqual(vertex *HeuVertex) bool
- func (v *HeuVertex) Trait() hybridqp.Trait
- func (v *HeuVertex) Type() string
- type HeuVertexInfo
- type HeuVertexWriter
- type HeuVertexs
- type HistogramQuantileOp
- type HoltWintersTransform
- func (trans *HoltWintersTransform) Close()
- func (trans *HoltWintersTransform) Explain() []ValuePair
- func (trans *HoltWintersTransform) GetInputNumber(port Port) int
- func (trans *HoltWintersTransform) GetInputs() Ports
- func (trans *HoltWintersTransform) GetOutputNumber(port Port) int
- func (trans *HoltWintersTransform) GetOutputs() Ports
- func (trans *HoltWintersTransform) Name() string
- func (trans *HoltWintersTransform) Work(ctx context.Context) error
- type HoltWintersTransformCreator
- type HttpChunkSender
- type HttpSenderHintTransform
- func (trans *HttpSenderHintTransform) AbortSinkTransform()
- func (trans *HttpSenderHintTransform) Close()
- func (trans *HttpSenderHintTransform) Explain() []ValuePair
- func (trans *HttpSenderHintTransform) GetInputNumber(_ Port) int
- func (trans *HttpSenderHintTransform) GetInputs() Ports
- func (trans *HttpSenderHintTransform) GetOutputNumber(_ Port) int
- func (trans *HttpSenderHintTransform) GetOutputs() Ports
- func (trans *HttpSenderHintTransform) Name() string
- func (trans *HttpSenderHintTransform) SetDag(dag *TransformDag)
- func (trans *HttpSenderHintTransform) SetVertex(vertex *TransformVertex)
- func (trans *HttpSenderHintTransform) Visit(vertex *TransformVertex) TransformVertexVisitor
- func (trans *HttpSenderHintTransform) Work(ctx context.Context) error
- type HttpSenderHintTransformCreator
- type HttpSenderTransform
- func (trans *HttpSenderTransform) AbortSinkTransform()
- func (trans *HttpSenderTransform) Close()
- func (trans *HttpSenderTransform) Explain() []ValuePair
- func (trans *HttpSenderTransform) GetInputNumber(_ Port) int
- func (trans *HttpSenderTransform) GetInputs() Ports
- func (trans *HttpSenderTransform) GetOutputNumber(_ Port) int
- func (trans *HttpSenderTransform) GetOutputs() Ports
- func (trans *HttpSenderTransform) Name() string
- func (trans *HttpSenderTransform) Release() error
- func (trans *HttpSenderTransform) SetDag(dag *TransformDag)
- func (trans *HttpSenderTransform) SetVertex(vertex *TransformVertex)
- func (trans *HttpSenderTransform) Visit(vertex *TransformVertex) TransformVertexVisitor
- func (trans *HttpSenderTransform) Work(ctx context.Context) error
- type HttpSenderTransformCreator
- type IncAggEntry
- type IncAggItem
- type IncAggRule
- type IncAggTransform
- func (trans *IncAggTransform) Close()
- func (trans *IncAggTransform) Explain() []ValuePair
- func (trans *IncAggTransform) GetIndex(t int64) int64
- func (trans *IncAggTransform) GetInputNumber(port Port) int
- func (trans *IncAggTransform) GetInputs() Ports
- func (trans *IncAggTransform) GetOutputNumber(port Port) int
- func (trans *IncAggTransform) GetOutputs() Ports
- func (trans *IncAggTransform) Name() string
- func (trans *IncAggTransform) Work(ctx context.Context) error
- type IncAggTransformCreator
- type IncHashAggEntry
- type IncHashAggItem
- type IncHashAggRule
- type IncHashAggTransform
- func (trans *IncHashAggTransform) Close()
- func (trans *IncHashAggTransform) Explain() []ValuePair
- func (trans *IncHashAggTransform) GetIndex(t int64) int64
- func (trans *IncHashAggTransform) GetInputNumber(port Port) int
- func (trans *IncHashAggTransform) GetInputs() Ports
- func (trans *IncHashAggTransform) GetOutputNumber(port Port) int
- func (trans *IncHashAggTransform) GetOutputs() Ports
- func (trans *IncHashAggTransform) Name() string
- func (trans *IncHashAggTransform) Work(ctx context.Context) error
- type IncHashAggTransformCreator
- type IncQueryFinish
- type IndexFrags
- type IndexScanExtraInfo
- type IndexScanTransform
- func (trans *IndexScanTransform) Abort()
- func (trans *IndexScanTransform) BuildDownSamplePlan(s hybridqp.Catalog) (hybridqp.QueryNode, error)
- func (trans *IndexScanTransform) BuildDownSampleSchema(schema hybridqp.Catalog) *QuerySchema
- func (trans *IndexScanTransform) BuildPlan(downSampleLevel int) (*QuerySchema, hybridqp.QueryNode, error)
- func (trans *IndexScanTransform) CanDownSampleRewrite(downSampleLevel int) bool
- func (trans *IndexScanTransform) Close()
- func (trans *IndexScanTransform) CursorsClose(plan hybridqp.QueryNode)
- func (trans *IndexScanTransform) Explain() []ValuePair
- func (trans *IndexScanTransform) FreeResFromAllocator()
- func (trans *IndexScanTransform) GetInputNumber(_ Port) int
- func (trans *IndexScanTransform) GetInputs() Ports
- func (trans *IndexScanTransform) GetOutputNumber(_ Port) int
- func (trans *IndexScanTransform) GetOutputs() Ports
- func (trans *IndexScanTransform) GetResFromAllocator()
- func (trans *IndexScanTransform) Interrupt()
- func (trans *IndexScanTransform) IsSink() bool
- func (trans *IndexScanTransform) Name() string
- func (trans *IndexScanTransform) Release() error
- func (trans *IndexScanTransform) RewriteChunk(c Chunk) Chunk
- func (trans *IndexScanTransform) Running(ctx context.Context) bool
- func (trans *IndexScanTransform) SetDownSampleLevel(l int)
- func (trans *IndexScanTransform) SetIndexScanErr(err bool)
- func (trans *IndexScanTransform) SetPipelineExecutor(exec *PipelineExecutor)
- func (trans *IndexScanTransform) Work(ctx context.Context) error
- func (trans *IndexScanTransform) WorkHelper(ctx context.Context) (error, bool)
- type IndexScanTransformCreator
- type Int64AppendIterator
- type Int64LimitIterator
- type Int64MergeIterator
- type IntegerAlignIterator
- type IntegerColFloatRateIterator
- type IntegerColIntegerDistinctIterator
- type IntegerColIntegerHeapIterator
- type IntegerColIntegerSampleIterator
- type IntegerColIntegerSliceIterator
- type IntegerCumulativeSumItem
- func (f *IntegerCumulativeSumItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerCumulativeSumItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerCumulativeSumItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerCumulativeSumItem) GetBaseTransData() BaseTransData
- func (f *IntegerCumulativeSumItem) Len() int
- func (f *IntegerCumulativeSumItem) PrevNil() bool
- func (f *IntegerCumulativeSumItem) Reset()
- func (f *IntegerCumulativeSumItem) ResetPrev()
- type IntegerDerivativeItem
- func (f *IntegerDerivativeItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerDerivativeItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerDerivativeItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerDerivativeItem) GetBaseTransData() BaseTransData
- func (f *IntegerDerivativeItem) Len() int
- func (f *IntegerDerivativeItem) PrevNil() bool
- func (f *IntegerDerivativeItem) Reset()
- func (f *IntegerDerivativeItem) ResetPrev()
- type IntegerDifferenceItem
- func (f *IntegerDifferenceItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerDifferenceItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerDifferenceItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerDifferenceItem) GetBaseTransData() BaseTransData
- func (f *IntegerDifferenceItem) Len() int
- func (f *IntegerDifferenceItem) PrevNil() bool
- func (f *IntegerDifferenceItem) Reset()
- func (f *IntegerDifferenceItem) ResetPrev()
- type IntegerFieldValuer
- type IntegerIntegralIterator
- type IntegerIntervalIterator
- type IntegerIterator
- type IntegerLinearFillProcessor
- type IntegerMovingAverageItem
- func (f *IntegerMovingAverageItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerMovingAverageItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerMovingAverageItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
- func (f *IntegerMovingAverageItem) GetBaseTransData() BaseTransData
- func (f *IntegerMovingAverageItem) Len() int
- func (f *IntegerMovingAverageItem) PrevNil() bool
- func (f *IntegerMovingAverageItem) Reset()
- func (f *IntegerMovingAverageItem) ResetPrev()
- type IntegerNullFillProcessor
- type IntegerNumberFillProcessor
- type IntegerOGSketchInsertItem
- type IntegerOGSketchPercentileItem
- type IntegerPercentileApproxItem
- type IntegerPreviousFillProcessor
- type IntegerTimeColIntegerIterator
- type IntegerTransIterator
- type IntegralItem
- func (f *IntegralItem[T]) AppendItem(c Chunk, values []T, ordinal int, start, end int, sameInterval, sameTag bool)
- func (f *IntegralItem[T]) AppendItemFastFunc(c Chunk, values []T, start, end int, sameInterval bool, sameTag bool)
- func (f *IntegralItem[T]) AppendItemSlowFunc(c Chunk, values []T, ordinal int, vs, ve int, sameInterval, sameTag bool)
- func (f *IntegralItem[T]) CalculateUnit(index int, time int64, value float64)
- func (f *IntegralItem[T]) Len() int
- func (f *IntegralItem[T]) Nil() bool
- func (f *IntegralItem[T]) Reset()
- func (f *IntegralItem[T]) StartNewInterval(time int64)
- type IntervalKeysMPool
- type IntervalToProjectInSubQueryRule
- type IntervalTransform
- func (trans *IntervalTransform) Close()
- func (trans *IntervalTransform) Explain() []ValuePair
- func (trans *IntervalTransform) GetInputNumber(port Port) int
- func (trans *IntervalTransform) GetInputs() Ports
- func (trans *IntervalTransform) GetOutputNumber(port Port) int
- func (trans *IntervalTransform) GetOutputs() Ports
- func (trans *IntervalTransform) Name() string
- func (trans *IntervalTransform) Work(ctx context.Context) error
- type IntervalTransformCreator
- type Item
- type Iterator
- type IteratorEndpoint
- type IteratorParams
- type LabelFunction
- type LabelValuer
- type LimitPushdownToExchangeRule
- type LimitPushdownToReaderRule
- type LimitPushdownToSeriesRule
- type LimitTransform
- func (trans *LimitTransform) AppendPoint(chunk Chunk, in int)
- func (trans *LimitTransform) AppendPoints(chunk Chunk, in int)
- func (trans *LimitTransform) Close()
- func (trans *LimitTransform) Explain() []ValuePair
- func (trans *LimitTransform) GetInputNumber(port Port) int
- func (trans *LimitTransform) GetInputs() Ports
- func (trans *LimitTransform) GetMultiRowsIndexPara() int
- func (trans *LimitTransform) GetOutputNumber(port Port) int
- func (trans *LimitTransform) GetOutputs() Ports
- func (trans *LimitTransform) GetSingleRowPara() int
- func (trans *LimitTransform) IntervalIndexGen()
- func (trans *LimitTransform) MultipleRowsIgnoreTagLimitHelper()
- func (trans *LimitTransform) MultipleRowsLimitHelper()
- func (trans *LimitTransform) Name() string
- func (trans *LimitTransform) SameGroup(i int) bool
- func (trans *LimitTransform) SendChunk()
- func (trans *LimitTransform) SetDag(dag *TransformDag)
- func (trans *LimitTransform) SetVertex(vertex *TransformVertex)
- func (trans *LimitTransform) SingleRowIgnoreTagLimitHelper()
- func (trans *LimitTransform) SingleRowLimitHelper()
- func (trans *LimitTransform) Visit(vertex *TransformVertex) TransformVertexVisitor
- func (trans *LimitTransform) Work(ctx context.Context) error
- type LimitTransformCreator
- type LimitTransformParameters
- type Loc
- type LogicalAggregate
- func (p *LogicalAggregate) Clone() hybridqp.QueryNode
- func (p *LogicalAggregate) CountToSum()
- func (p *LogicalAggregate) DeriveOperations()
- func (p *LogicalAggregate) Digest() string
- func (p *LogicalAggregate) Explain(writer LogicalPlanWriter)
- func (p *LogicalAggregate) ForwardCallArgs()
- func (p *LogicalAggregate) LogicPlanType() internal.LogicPlanType
- func (p *LogicalAggregate) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalAggregate) String() string
- func (p *LogicalAggregate) Type() string
- type LogicalAlign
- func (p *LogicalAlign) Clone() hybridqp.QueryNode
- func (p *LogicalAlign) DeriveOperations()
- func (p *LogicalAlign) Digest() string
- func (p *LogicalAlign) Explain(writer LogicalPlanWriter)
- func (p *LogicalAlign) LogicPlanType() internal.LogicPlanType
- func (p *LogicalAlign) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalAlign) String() string
- func (p *LogicalAlign) Type() string
- type LogicalBinOp
- func (p *LogicalBinOp) Children() []hybridqp.QueryNode
- func (p *LogicalBinOp) Clone() hybridqp.QueryNode
- func (p *LogicalBinOp) DeriveOperations()
- func (p *LogicalBinOp) Digest() string
- func (p *LogicalBinOp) Explain(writer LogicalPlanWriter)
- func (p *LogicalBinOp) LogicPlanType() internal.LogicPlanType
- func (p *LogicalBinOp) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalBinOp) ReplaceChild(ordinal int, child hybridqp.QueryNode)
- func (p *LogicalBinOp) ReplaceChildren(children []hybridqp.QueryNode)
- func (p *LogicalBinOp) String() string
- func (p *LogicalBinOp) Type() string
- type LogicalColumnStoreReader
- func (p *LogicalColumnStoreReader) Clone() hybridqp.QueryNode
- func (p *LogicalColumnStoreReader) DeriveOperations()
- func (p *LogicalColumnStoreReader) Digest() string
- func (p *LogicalColumnStoreReader) Explain(writer LogicalPlanWriter)
- func (p *LogicalColumnStoreReader) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalColumnStoreReader) LogicPlanType() internal.LogicPlanType
- func (p *LogicalColumnStoreReader) MstName() string
- func (p *LogicalColumnStoreReader) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalColumnStoreReader) String() string
- func (p *LogicalColumnStoreReader) Type() string
- type LogicalDedupe
- func (p *LogicalDedupe) Clone() hybridqp.QueryNode
- func (p *LogicalDedupe) DeriveOperations()
- func (p *LogicalDedupe) Digest() string
- func (p *LogicalDedupe) Explain(writer LogicalPlanWriter)
- func (p *LogicalDedupe) LogicPlanType() internal.LogicPlanType
- func (p *LogicalDedupe) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalDedupe) String() string
- func (p *LogicalDedupe) Type() string
- type LogicalDummyShard
- func (p *LogicalDummyShard) Children() []hybridqp.QueryNode
- func (p *LogicalDummyShard) Clone() hybridqp.QueryNode
- func (p *LogicalDummyShard) Digest() string
- func (p *LogicalDummyShard) Explain(writer LogicalPlanWriter)
- func (p *LogicalDummyShard) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalDummyShard) GetIndexInfo() comm.TSIndexInfo
- func (p *LogicalDummyShard) LogicPlanType() internal.LogicPlanType
- func (p *LogicalDummyShard) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalDummyShard) ReplaceChild(ordinal int, child hybridqp.QueryNode)
- func (p *LogicalDummyShard) ReplaceChildren(children []hybridqp.QueryNode)
- func (p *LogicalDummyShard) String() string
- func (p *LogicalDummyShard) Type() string
- type LogicalExchange
- func (p *LogicalExchange) AddTrait(trait interface{})
- func (p *LogicalExchange) Clone() hybridqp.QueryNode
- func (p *LogicalExchange) DeriveOperations()
- func (p *LogicalExchange) Digest() string
- func (p *LogicalExchange) Explain(writer LogicalPlanWriter)
- func (p *LogicalExchange) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalExchange) LogicPlanType() internal.LogicPlanType
- func (p *LogicalExchange) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalExchange) Schema() hybridqp.Catalog
- func (p *LogicalExchange) String() string
- func (p *LogicalExchange) Type() string
- type LogicalExchangeBase
- type LogicalFill
- func (p *LogicalFill) Clone() hybridqp.QueryNode
- func (p *LogicalFill) DeriveOperations()
- func (p *LogicalFill) Digest() string
- func (p *LogicalFill) Explain(writer LogicalPlanWriter)
- func (p *LogicalFill) LogicPlanType() internal.LogicPlanType
- func (p *LogicalFill) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalFill) String() string
- func (p *LogicalFill) Type() string
- type LogicalFilter
- func (p *LogicalFilter) Clone() hybridqp.QueryNode
- func (p *LogicalFilter) DeriveOperations()
- func (p *LogicalFilter) Digest() string
- func (p *LogicalFilter) Explain(writer LogicalPlanWriter)
- func (p *LogicalFilter) LogicPlanType() internal.LogicPlanType
- func (p *LogicalFilter) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalFilter) String() string
- func (p *LogicalFilter) Type() string
- type LogicalFilterBlank
- func (p *LogicalFilterBlank) Clone() hybridqp.QueryNode
- func (p *LogicalFilterBlank) DeriveOperations()
- func (p *LogicalFilterBlank) Digest() string
- func (p *LogicalFilterBlank) Explain(writer LogicalPlanWriter)
- func (p *LogicalFilterBlank) LogicPlanType() internal.LogicPlanType
- func (p *LogicalFilterBlank) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalFilterBlank) String() string
- func (p *LogicalFilterBlank) Type() string
- type LogicalFullJoin
- func (p *LogicalFullJoin) Children() []hybridqp.QueryNode
- func (p *LogicalFullJoin) Clone() hybridqp.QueryNode
- func (p *LogicalFullJoin) DeriveOperations()
- func (p *LogicalFullJoin) Digest() string
- func (p *LogicalFullJoin) Explain(writer LogicalPlanWriter)
- func (p *LogicalFullJoin) LogicPlanType() internal.LogicPlanType
- func (p *LogicalFullJoin) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalFullJoin) ReplaceChild(ordinal int, child hybridqp.QueryNode)
- func (p *LogicalFullJoin) ReplaceChildren(children []hybridqp.QueryNode)
- func (p *LogicalFullJoin) String() string
- func (p *LogicalFullJoin) Type() string
- type LogicalGroupBy
- func (p *LogicalGroupBy) Clone() hybridqp.QueryNode
- func (p *LogicalGroupBy) DeriveOperations()
- func (p *LogicalGroupBy) Digest() string
- func (p *LogicalGroupBy) Explain(writer LogicalPlanWriter)
- func (p *LogicalGroupBy) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalGroupBy) LogicPlanType() internal.LogicPlanType
- func (p *LogicalGroupBy) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalGroupBy) String() string
- func (p *LogicalGroupBy) Type() string
- type LogicalHashAgg
- func (p *LogicalHashAgg) AddTrait(trait interface{})
- func (p *LogicalHashAgg) Clone() hybridqp.QueryNode
- func (p *LogicalHashAgg) CountToSum()
- func (p *LogicalHashAgg) DeriveOperations()
- func (p *LogicalHashAgg) Digest() string
- func (p *LogicalHashAgg) Explain(writer LogicalPlanWriter)
- func (p *LogicalHashAgg) ForwardCallArgs()
- func (p *LogicalHashAgg) LogicPlanType() internal.LogicPlanType
- func (p *LogicalHashAgg) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalHashAgg) Schema() hybridqp.Catalog
- func (p *LogicalHashAgg) String() string
- func (p *LogicalHashAgg) Type() string
- type LogicalHashMerge
- func (p *LogicalHashMerge) AddTrait(trait interface{})
- func (p *LogicalHashMerge) Clone() hybridqp.QueryNode
- func (p *LogicalHashMerge) DeriveOperations()
- func (p *LogicalHashMerge) Digest() string
- func (p *LogicalHashMerge) Explain(writer LogicalPlanWriter)
- func (p *LogicalHashMerge) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalHashMerge) LogicPlanType() internal.LogicPlanType
- func (p *LogicalHashMerge) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalHashMerge) String() string
- func (p *LogicalHashMerge) Type() string
- type LogicalHoltWinters
- func (p *LogicalHoltWinters) Clone() hybridqp.QueryNode
- func (p *LogicalHoltWinters) DeriveOperations()
- func (p *LogicalHoltWinters) Digest() string
- func (p *LogicalHoltWinters) Explain(writer LogicalPlanWriter)
- func (p *LogicalHoltWinters) LogicPlanType() internal.LogicPlanType
- func (p *LogicalHoltWinters) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalHoltWinters) String() string
- func (p *LogicalHoltWinters) Type() string
- type LogicalHttpSender
- func (p *LogicalHttpSender) Clone() hybridqp.QueryNode
- func (p *LogicalHttpSender) DeriveOperations()
- func (p *LogicalHttpSender) Digest() string
- func (p *LogicalHttpSender) Explain(writer LogicalPlanWriter)
- func (p *LogicalHttpSender) LogicPlanType() internal.LogicPlanType
- func (p *LogicalHttpSender) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalHttpSender) String() string
- func (p *LogicalHttpSender) Type() string
- type LogicalHttpSenderHint
- func (p *LogicalHttpSenderHint) Clone() hybridqp.QueryNode
- func (p *LogicalHttpSenderHint) DeriveOperations()
- func (p *LogicalHttpSenderHint) Digest() string
- func (p *LogicalHttpSenderHint) Explain(writer LogicalPlanWriter)
- func (p *LogicalHttpSenderHint) LogicPlanType() internal.LogicPlanType
- func (p *LogicalHttpSenderHint) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalHttpSenderHint) String() string
- func (p *LogicalHttpSenderHint) Type() string
- type LogicalIncAgg
- func (p *LogicalIncAgg) Clone() hybridqp.QueryNode
- func (p *LogicalIncAgg) CountToSum()
- func (p *LogicalIncAgg) DeriveOperations()
- func (p *LogicalIncAgg) Digest() string
- func (p *LogicalIncAgg) Explain(writer LogicalPlanWriter)
- func (p *LogicalIncAgg) ForwardCallArgs()
- func (p *LogicalIncAgg) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalIncAgg) String() string
- func (p *LogicalIncAgg) Type() string
- type LogicalIncHashAgg
- func (p *LogicalIncHashAgg) Clone() hybridqp.QueryNode
- func (p *LogicalIncHashAgg) CountToSum()
- func (p *LogicalIncHashAgg) DeriveOperations()
- func (p *LogicalIncHashAgg) Digest() string
- func (p *LogicalIncHashAgg) Explain(writer LogicalPlanWriter)
- func (p *LogicalIncHashAgg) ForwardCallArgs()
- func (p *LogicalIncHashAgg) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalIncHashAgg) String() string
- func (p *LogicalIncHashAgg) Type() string
- type LogicalIndexScan
- func (p *LogicalIndexScan) Clone() hybridqp.QueryNode
- func (p *LogicalIndexScan) DeriveOperations()
- func (p *LogicalIndexScan) Digest() string
- func (p *LogicalIndexScan) Explain(writer LogicalPlanWriter)
- func (p *LogicalIndexScan) GetOneShardState() bool
- func (p *LogicalIndexScan) LogicPlanType() internal.LogicPlanType
- func (p *LogicalIndexScan) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalIndexScan) SetOneShardState(enable bool)
- func (p *LogicalIndexScan) String() string
- func (p *LogicalIndexScan) Type() string
- type LogicalInterval
- func (p *LogicalInterval) Clone() hybridqp.QueryNode
- func (p *LogicalInterval) DeriveOperations()
- func (p *LogicalInterval) Digest() string
- func (p *LogicalInterval) Explain(writer LogicalPlanWriter)
- func (p *LogicalInterval) LogicPlanType() internal.LogicPlanType
- func (p *LogicalInterval) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalInterval) String() string
- func (p *LogicalInterval) Type() string
- type LogicalJoin
- func (p *LogicalJoin) Clone() hybridqp.QueryNode
- func (p *LogicalJoin) DeriveOperations()
- func (p *LogicalJoin) Digest() string
- func (p *LogicalJoin) Explain(writer LogicalPlanWriter)
- func (p *LogicalJoin) LogicPlanType() internal.LogicPlanType
- func (p *LogicalJoin) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalJoin) String() string
- func (p *LogicalJoin) Type() string
- type LogicalLimit
- func (p *LogicalLimit) Clone() hybridqp.QueryNode
- func (p *LogicalLimit) DeriveOperations()
- func (p *LogicalLimit) Digest() string
- func (p *LogicalLimit) Explain(writer LogicalPlanWriter)
- func (p *LogicalLimit) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalLimit) LogicPlanType() internal.LogicPlanType
- func (p *LogicalLimit) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalLimit) String() string
- func (p *LogicalLimit) Type() string
- type LogicalMerge
- func (p *LogicalMerge) Clone() hybridqp.QueryNode
- func (p *LogicalMerge) DeriveOperations()
- func (p *LogicalMerge) Digest() string
- func (p *LogicalMerge) Explain(writer LogicalPlanWriter)
- func (p *LogicalMerge) LogicPlanType() internal.LogicPlanType
- func (p *LogicalMerge) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalMerge) String() string
- func (p *LogicalMerge) Type() string
- type LogicalMst
- func (p *LogicalMst) Children() []hybridqp.QueryNode
- func (p *LogicalMst) Clone() hybridqp.QueryNode
- func (p *LogicalMst) Digest() string
- func (p *LogicalMst) Dummy() bool
- func (p *LogicalMst) Explain(writer LogicalPlanWriter)
- func (p *LogicalMst) LogicPlanType() internal.LogicPlanType
- func (p *LogicalMst) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalMst) ReplaceChild(ordinal int, child hybridqp.QueryNode)
- func (p *LogicalMst) ReplaceChildren(children []hybridqp.QueryNode)
- func (p *LogicalMst) String() string
- func (p *LogicalMst) Type() string
- type LogicalOrderBy
- func (p *LogicalOrderBy) Clone() hybridqp.QueryNode
- func (p *LogicalOrderBy) DeriveOperations()
- func (p *LogicalOrderBy) Digest() string
- func (p *LogicalOrderBy) Explain(writer LogicalPlanWriter)
- func (p *LogicalOrderBy) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalOrderBy) LogicPlanType() internal.LogicPlanType
- func (p *LogicalOrderBy) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalOrderBy) String() string
- func (p *LogicalOrderBy) Type() string
- type LogicalPlan
- type LogicalPlanBase
- func (p *LogicalPlanBase) ApplyTrait(trait hybridqp.Trait)
- func (p *LogicalPlanBase) Children() []hybridqp.QueryNode
- func (p *LogicalPlanBase) DeriveOperations()
- func (p *LogicalPlanBase) Dummy() bool
- func (p *LogicalPlanBase) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalPlanBase) ForwardInit(input hybridqp.QueryNode)
- func (p *LogicalPlanBase) ID() uint64
- func (p *LogicalPlanBase) InitRef(input hybridqp.QueryNode)
- func (p *LogicalPlanBase) PreAggInit()
- func (p *LogicalPlanBase) RowDataType() hybridqp.RowDataType
- func (p *LogicalPlanBase) RowExprOptions() []hybridqp.ExprOptions
- func (p *LogicalPlanBase) Schema() hybridqp.Catalog
- func (p *LogicalPlanBase) SetInputs(inputs []hybridqp.QueryNode)
- func (p *LogicalPlanBase) SetSchema(schema hybridqp.Catalog)
- func (p *LogicalPlanBase) Trait() hybridqp.Trait
- type LogicalPlanBuilder
- type LogicalPlanBuilderImpl
- func (b *LogicalPlanBuilderImpl) Aggregate() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Build() (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CountDistinct() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) CreateAggregate(input hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateColStoreCursorPlan() (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateColStoreReaderPlan(seriesPlan hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateInterval(input hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateLimit(input hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateMeasurementPlan(seriesPlan hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateNodePlan(shardPlan hybridqp.QueryNode, eTraits []hybridqp.Trait) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreatePartitionPlan(scanPlan hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateProject(input hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateScanPlan(mstPlan hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateSegmentPlan(schema hybridqp.Catalog) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateSeriesPlan() (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateShardPlan(scanPlan hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateSlideWindow(input hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) CreateSparseIndexScanPlan(plan hybridqp.QueryNode) (hybridqp.QueryNode, error)
- func (b *LogicalPlanBuilderImpl) Dedupe() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Exchange(eType ExchangeType, eTraits []hybridqp.Trait) LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Fill() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Filter() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) FilterBlank() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) GroupBy() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) HashAgg() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) HashMerge(eType ExchangeType, eTraits []hybridqp.Trait) LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) HoltWinters() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) HttpSender() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) HttpSenderHint() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) IncAgg() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) IncHashAgg() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) IndexScan() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Interval() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Limit(para LimitTransformParameters) LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Merge() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) OrderBy() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Project() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) PromSort() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) PromSubquery(call *influxql.PromSubCall) LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Push(node hybridqp.QueryNode) LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Reader(engineType config.EngineType) LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Rewrite() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Series() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) SlidingWindow() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Sort() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) SparseIndexScan() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) SplitGroup() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) SubQuery() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) TagSetAggregate() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) TagSubset() LogicalPlanBuilder
- func (b *LogicalPlanBuilderImpl) Target(mst *influxql.Measurement) LogicalPlanBuilder
- type LogicalPlanMulti
- type LogicalPlanRewriter
- type LogicalPlanRewriterImpl
- type LogicalPlanSingle
- type LogicalPlanVisitor
- type LogicalPlanWriter
- type LogicalPlanWriterImpl
- type LogicalPlaner
- type LogicalProject
- func (p *LogicalProject) Clone() hybridqp.QueryNode
- func (p *LogicalProject) DeriveOperations()
- func (p *LogicalProject) Digest() string
- func (p *LogicalProject) Explain(writer LogicalPlanWriter)
- func (p *LogicalProject) LogicPlanType() internal.LogicPlanType
- func (p *LogicalProject) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalProject) String() string
- func (p *LogicalProject) Type() string
- type LogicalPromSort
- func (p *LogicalPromSort) Clone() hybridqp.QueryNode
- func (p *LogicalPromSort) DeriveOperations()
- func (p *LogicalPromSort) Digest() string
- func (p *LogicalPromSort) Explain(writer LogicalPlanWriter)
- func (p *LogicalPromSort) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalPromSort) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalPromSort) String() string
- func (p *LogicalPromSort) Type() string
- type LogicalPromSubquery
- func (p *LogicalPromSubquery) Children() []hybridqp.QueryNode
- func (p *LogicalPromSubquery) Clone() hybridqp.QueryNode
- func (p *LogicalPromSubquery) DeriveOperations()
- func (p *LogicalPromSubquery) Digest() string
- func (p *LogicalPromSubquery) Explain(writer LogicalPlanWriter)
- func (p *LogicalPromSubquery) LogicPlanType() internal.LogicPlanType
- func (p *LogicalPromSubquery) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalPromSubquery) ReplaceChild(ordinal int, child hybridqp.QueryNode)
- func (p *LogicalPromSubquery) ReplaceChildren(children []hybridqp.QueryNode)
- func (p *LogicalPromSubquery) String() string
- func (p *LogicalPromSubquery) Type() string
- type LogicalReader
- func (p *LogicalReader) Clone() hybridqp.QueryNode
- func (p *LogicalReader) Cursors() []interface{}
- func (p *LogicalReader) DeriveOperations()
- func (p *LogicalReader) Digest() string
- func (p *LogicalReader) Explain(writer LogicalPlanWriter)
- func (p *LogicalReader) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalReader) GetOneReaderState() bool
- func (p *LogicalReader) HasPreAgg() bool
- func (p *LogicalReader) LogicPlanType() internal.LogicPlanType
- func (p *LogicalReader) MstName() string
- func (p *LogicalReader) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalReader) SetCursor(cursor []interface{})
- func (p *LogicalReader) SetOneReaderState(state bool)
- func (p *LogicalReader) String() string
- func (p *LogicalReader) Type() string
- type LogicalSequenceAggregate
- func (p *LogicalSequenceAggregate) Clone() hybridqp.QueryNode
- func (p *LogicalSequenceAggregate) DeriveOperations()
- func (p *LogicalSequenceAggregate) Digest() string
- func (p *LogicalSequenceAggregate) Explain(writer LogicalPlanWriter)
- func (p *LogicalSequenceAggregate) LogicPlanType() internal.LogicPlanType
- func (p *LogicalSequenceAggregate) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalSequenceAggregate) String() string
- func (p *LogicalSequenceAggregate) Type() string
- type LogicalSeries
- func (p *LogicalSeries) Children() []hybridqp.QueryNode
- func (p *LogicalSeries) Clone() hybridqp.QueryNode
- func (p *LogicalSeries) DeriveOperations()
- func (p *LogicalSeries) Digest() string
- func (p *LogicalSeries) Explain(writer LogicalPlanWriter)
- func (p *LogicalSeries) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalSeries) LogicPlanType() internal.LogicPlanType
- func (p *LogicalSeries) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalSeries) ReplaceChild(ordinal int, child hybridqp.QueryNode)
- func (p *LogicalSeries) ReplaceChildren(children []hybridqp.QueryNode)
- func (p *LogicalSeries) String() string
- func (p *LogicalSeries) Type() string
- type LogicalSlidingWindow
- func (p *LogicalSlidingWindow) Clone() hybridqp.QueryNode
- func (p *LogicalSlidingWindow) CountToSum()
- func (p *LogicalSlidingWindow) DeriveOperations()
- func (p *LogicalSlidingWindow) Digest() string
- func (p *LogicalSlidingWindow) Explain(writer LogicalPlanWriter)
- func (p *LogicalSlidingWindow) ForwardCallArgs()
- func (p *LogicalSlidingWindow) LogicPlanType() internal.LogicPlanType
- func (p *LogicalSlidingWindow) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalSlidingWindow) String() string
- func (p *LogicalSlidingWindow) Type() string
- type LogicalSort
- func (p *LogicalSort) Clone() hybridqp.QueryNode
- func (p *LogicalSort) DeriveOperations()
- func (p *LogicalSort) Digest() string
- func (p *LogicalSort) Explain(writer LogicalPlanWriter)
- func (p *LogicalSort) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalSort) LogicPlanType() internal.LogicPlanType
- func (p *LogicalSort) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalSort) String() string
- func (p *LogicalSort) Type() string
- type LogicalSortAppend
- func (p *LogicalSortAppend) Clone() hybridqp.QueryNode
- func (p *LogicalSortAppend) DeriveOperations()
- func (p *LogicalSortAppend) Digest() string
- func (p *LogicalSortAppend) Explain(writer LogicalPlanWriter)
- func (p *LogicalSortAppend) LogicPlanType() internal.LogicPlanType
- func (p *LogicalSortAppend) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalSortAppend) String() string
- func (p *LogicalSortAppend) Type() string
- type LogicalSortMerge
- func (p *LogicalSortMerge) Clone() hybridqp.QueryNode
- func (p *LogicalSortMerge) DeriveOperations()
- func (p *LogicalSortMerge) Digest() string
- func (p *LogicalSortMerge) Explain(writer LogicalPlanWriter)
- func (p *LogicalSortMerge) LogicPlanType() internal.LogicPlanType
- func (p *LogicalSortMerge) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalSortMerge) String() string
- func (p *LogicalSortMerge) Type() string
- type LogicalSparseIndexScan
- func (p *LogicalSparseIndexScan) Clone() hybridqp.QueryNode
- func (p *LogicalSparseIndexScan) DeriveOperations()
- func (p *LogicalSparseIndexScan) Digest() string
- func (p *LogicalSparseIndexScan) Explain(writer LogicalPlanWriter)
- func (p *LogicalSparseIndexScan) LogicPlanType() internal.LogicPlanType
- func (p *LogicalSparseIndexScan) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalSparseIndexScan) String() string
- func (p *LogicalSparseIndexScan) Type() string
- type LogicalSplitGroup
- func (p *LogicalSplitGroup) Clone() hybridqp.QueryNode
- func (p *LogicalSplitGroup) DeriveOperations()
- func (p *LogicalSplitGroup) Digest() string
- func (p *LogicalSplitGroup) Explain(writer LogicalPlanWriter)
- func (p *LogicalSplitGroup) LogicPlanType() internal.LogicPlanType
- func (p *LogicalSplitGroup) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalSplitGroup) String() string
- func (p *LogicalSplitGroup) Type() string
- type LogicalSubQuery
- func (p *LogicalSubQuery) Clone() hybridqp.QueryNode
- func (p *LogicalSubQuery) DeriveOperations()
- func (p *LogicalSubQuery) Digest() string
- func (p *LogicalSubQuery) Explain(writer LogicalPlanWriter)
- func (p *LogicalSubQuery) LogicPlanType() internal.LogicPlanType
- func (p *LogicalSubQuery) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalSubQuery) String() string
- func (p *LogicalSubQuery) Type() string
- type LogicalTSSPScan
- func (p *LogicalTSSPScan) Children() []hybridqp.QueryNode
- func (p *LogicalTSSPScan) Clone() hybridqp.QueryNode
- func (p *LogicalTSSPScan) DeriveOperations()
- func (p *LogicalTSSPScan) Digest() string
- func (p *LogicalTSSPScan) Explain(writer LogicalPlanWriter)
- func (p *LogicalTSSPScan) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalTSSPScan) GetFiles() *immutable.TSSPFiles
- func (p *LogicalTSSPScan) GetNewSeqs() []uint64
- func (p *LogicalTSSPScan) LogicPlanType() internal.LogicPlanType
- func (p *LogicalTSSPScan) MstName() string
- func (p *LogicalTSSPScan) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalTSSPScan) ReplaceChild(ordinal int, child hybridqp.QueryNode)
- func (p *LogicalTSSPScan) ReplaceChildren(children []hybridqp.QueryNode)
- func (p *LogicalTSSPScan) SetFiles(files *immutable.TSSPFiles)
- func (p *LogicalTSSPScan) SetNewSeqs(seqs []uint64)
- func (p *LogicalTSSPScan) String() string
- func (p *LogicalTSSPScan) Type() string
- type LogicalTagSubset
- func (p *LogicalTagSubset) Clone() hybridqp.QueryNode
- func (p *LogicalTagSubset) DeriveOperations()
- func (p *LogicalTagSubset) Digest() string
- func (p *LogicalTagSubset) Explain(writer LogicalPlanWriter)
- func (p *LogicalTagSubset) LogicPlanType() internal.LogicPlanType
- func (p *LogicalTagSubset) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalTagSubset) String() string
- func (p *LogicalTagSubset) Type() string
- type LogicalTarget
- func (p *LogicalTarget) Clone() hybridqp.QueryNode
- func (p *LogicalTarget) DeriveOperations()
- func (p *LogicalTarget) Digest() string
- func (p *LogicalTarget) Explain(writer LogicalPlanWriter)
- func (p *LogicalTarget) LogicPlanType() internal.LogicPlanType
- func (p *LogicalTarget) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalTarget) String() string
- func (p *LogicalTarget) TargetMeasurement() *influxql.Measurement
- func (p *LogicalTarget) Type() string
- type LogicalWriteIntoStorage
- func (p *LogicalWriteIntoStorage) Clone() hybridqp.QueryNode
- func (p *LogicalWriteIntoStorage) DeriveOperations()
- func (p *LogicalWriteIntoStorage) Digest() string
- func (p *LogicalWriteIntoStorage) Explain(writer LogicalPlanWriter)
- func (p *LogicalWriteIntoStorage) ExplainIterms(writer LogicalPlanWriter)
- func (p *LogicalWriteIntoStorage) GetMmsTables() *immutable.MmsTables
- func (p *LogicalWriteIntoStorage) LogicPlanType() internal.LogicPlanType
- func (p *LogicalWriteIntoStorage) MstName() string
- func (p *LogicalWriteIntoStorage) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
- func (p *LogicalWriteIntoStorage) ReplaceChild(ordinal int, child hybridqp.QueryNode)
- func (p *LogicalWriteIntoStorage) ReplaceChildren(children []hybridqp.QueryNode)
- func (p *LogicalWriteIntoStorage) SetMmsTables(m *immutable.MmsTables)
- func (p *LogicalWriteIntoStorage) String() string
- func (p *LogicalWriteIntoStorage) Type() string
- type MaterializeTransform
- func (trans *MaterializeTransform) Close()
- func (trans *MaterializeTransform) ColumnMapInit()
- func (trans *MaterializeTransform) Explain() []ValuePair
- func (trans *MaterializeTransform) GetInputNumber(_ Port) int
- func (trans *MaterializeTransform) GetInputs() Ports
- func (trans *MaterializeTransform) GetOutputNumber(_ Port) int
- func (trans *MaterializeTransform) GetOutputs() Ports
- func (trans *MaterializeTransform) Name() string
- func (trans *MaterializeTransform) ResetTransparents()
- func (trans *MaterializeTransform) Work(ctx context.Context) error
- type MaterializeTransformCreator
- type MaxOp
- type MaxPromOp
- type MergeTransf
- func (t *MergeTransf) CostName() string
- func (t *MergeTransf) GetType() MergeTransformType
- func (t *MergeTransf) InitColumnsIteratorHelper(rt hybridqp.RowDataType) CoProcessor
- func (t *MergeTransf) InitHeapItems(inRowDataLen int, _ hybridqp.RowDataType, schema *QuerySchema) BaseHeapItems
- func (t *MergeTransf) Name() string
- type MergeTransform
- func NewBaseMergeTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, ...) *MergeTransform
- func NewMergeTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, ...) *MergeTransform
- func NewSortAppendTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, ...) *MergeTransform
- func NewSortedMergeTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, ...) *MergeTransform
- func (trans *MergeTransform) AddIntervalIndex(chunk Chunk, i int, opt *query.ProcessorOptions, flag bool) bool
- func (trans *MergeTransform) AddTagAndIndexes(tag ChunkTags, iLen int, i int, flag bool)
- func (trans *MergeTransform) AppendToHeap(in int, c Chunk)
- func (trans *MergeTransform) Close()
- func (trans *MergeTransform) CostName() string
- func (trans *MergeTransform) Explain() []ValuePair
- func (trans *MergeTransform) GetInputNumber(port Port) int
- func (trans *MergeTransform) GetInputs() Ports
- func (trans *MergeTransform) GetMstName() string
- func (trans *MergeTransform) GetOutputNumber(port Port) int
- func (trans *MergeTransform) GetOutputs() Ports
- func (trans *MergeTransform) InitHeapItems(inRowDataLen int, rt hybridqp.RowDataType, schema *QuerySchema)
- func (trans *MergeTransform) IsNewMstName() bool
- func (trans *MergeTransform) Merge(ctx context.Context, errs *errno.Errs)
- func (trans *MergeTransform) Name() string
- func (trans *MergeTransform) SendChunk()
- func (trans *MergeTransform) UpdateWithSingleChunk()
- func (trans *MergeTransform) Work(ctx context.Context) error
- type MergeTransformCreator
- type MergeTransformType
- type MergeType
- type MinOp
- type MinPromOp
- type MultiMstReqs
- type NewAggOperator
- type NilSink
- func (sink *NilSink) Close()
- func (sink *NilSink) Explain() []ValuePair
- func (sink *NilSink) GetInputNumber(_ Port) int
- func (sink *NilSink) GetInputs() Ports
- func (sink *NilSink) GetOutputNumber(_ Port) int
- func (sink *NilSink) GetOutputs() Ports
- func (sink *NilSink) Name() string
- func (sink *NilSink) Work(ctx context.Context) error
- type NilTransform
- func (trans *NilTransform) Close()
- func (trans *NilTransform) Explain() []ValuePair
- func (trans *NilTransform) GetInputNumber(port Port) int
- func (trans *NilTransform) GetInputs() Ports
- func (trans *NilTransform) GetOutputNumber(port Port) int
- func (trans *NilTransform) GetOutputs() Ports
- func (trans *NilTransform) Name() string
- func (trans *NilTransform) Work(ctx context.Context) error
- type OGSketch
- type OGSketchImpl
- func (s *OGSketchImpl) Clusters() ClusterSet
- func (s *OGSketchImpl) DeleteClusters(cluster ...floatTuple)
- func (s *OGSketchImpl) DeletePoints(m ...float64)
- func (s *OGSketchImpl) DemarcationHistogram(begin, width float64, binsNum, binsType int) []int64
- func (s *OGSketchImpl) EquiHeightHistogram(binNum int, begin float64, end float64) []float64
- func (s *OGSketchImpl) InsertClusters(cluster ...floatTuple)
- func (s *OGSketchImpl) InsertPoints(m ...float64)
- func (s *OGSketchImpl) Len() int
- func (s *OGSketchImpl) Merge(s1 *OGSketchImpl)
- func (s *OGSketchImpl) Percentile(q float64) float64
- func (s *OGSketchImpl) Rank(Q float64) int64
- func (s *OGSketchImpl) Reset()
- type OGSketchItem
- type OGSketchIterator
- type OGSketchMergeItem
- type OptRule
- type OptRuleBase
- type OptRuleCall
- type OptRuleCatagory
- type OptRuleOperand
- type OptRuleOperandBase
- func (ob *OptRuleOperandBase) Children() []OptRuleOperand
- func (ob *OptRuleOperandBase) Equals(rhs OptRuleOperand) bool
- func (ob *OptRuleOperandBase) Matches(node hybridqp.QueryNode) bool
- func (ob *OptRuleOperandBase) Parent() OptRuleOperand
- func (ob *OptRuleOperandBase) Policy() OptRuleOperandChildPolicy
- func (ob *OptRuleOperandBase) Rule() OptRule
- func (ob *OptRuleOperandBase) SetOrdinalInParent(ordinal int)
- func (ob *OptRuleOperandBase) SetOrdinalInRule(ordinal int)
- func (ob *OptRuleOperandBase) SetParent(parent OptRuleOperand)
- func (ob *OptRuleOperandBase) SetRule(rule OptRule)
- type OptRuleOperandBuilder
- type OptRuleOperandBuilderBase
- func (builder *OptRuleOperandBuilderBase) AfterInput(planType string)
- func (builder *OptRuleOperandBuilderBase) AnyInput(planType string)
- func (builder *OptRuleOperandBuilderBase) Inputs(planType string, inputs ...OptRuleOperand)
- func (builder *OptRuleOperandBuilderBase) NoInput(planType string)
- func (builder *OptRuleOperandBuilderBase) OneInput(planType string, input OptRuleOperand)
- func (builder *OptRuleOperandBuilderBase) Operand() OptRuleOperand
- func (builder *OptRuleOperandBuilderBase) Operands() []OptRuleOperand
- func (builder *OptRuleOperandBuilderBase) UnorderedInputs(planType string, inputs ...OptRuleOperand)
- func (builder *OptRuleOperandBuilderBase) WildCardInput(planType string, input OptRuleOperand)
- type OptRuleOperandChildPolicy
- type OptRuleOperands
- type OrderByTransform
- func (trans *OrderByTransform) Close()
- func (trans *OrderByTransform) Explain() []ValuePair
- func (trans *OrderByTransform) GetCurrTags(i int) string
- func (trans *OrderByTransform) GetInputNumber(_ Port) int
- func (trans *OrderByTransform) GetInputs() Ports
- func (trans *OrderByTransform) GetOutputNumber(_ Port) int
- func (trans *OrderByTransform) GetOutputs() Ports
- func (trans *OrderByTransform) GetTagAndIndexes(chunk Chunk)
- func (trans *OrderByTransform) GetTagsResetTagIndexes(chunk Chunk)
- func (trans *OrderByTransform) IntervalIndexReGen()
- func (trans *OrderByTransform) Name() string
- func (trans *OrderByTransform) OrderTime()
- func (trans *OrderByTransform) RebuildChunk()
- func (trans *OrderByTransform) Release() error
- func (trans *OrderByTransform) SendChunk()
- func (trans *OrderByTransform) TagAndTagIndexHandler()
- func (trans *OrderByTransform) Work(ctx context.Context) error
- type OrderByTransformCreator
- type Para
- type ParaPointers
- type PercentileApproxOp
- type PipelineExecutor
- func (exec *PipelineExecutor) Abort()
- func (exec *PipelineExecutor) Aborted() bool
- func (exec *PipelineExecutor) Crash()
- func (exec *PipelineExecutor) Crashed() bool
- func (exec *PipelineExecutor) Execute(ctx context.Context) error
- func (exec *PipelineExecutor) ExecuteExecutor(ctx context.Context) error
- func (exec *PipelineExecutor) GetProcessors() Processors
- func (exec *PipelineExecutor) GetRoot() *TransformVertex
- func (exec *PipelineExecutor) InitContext(ctx context.Context) error
- func (exec *PipelineExecutor) NoMarkCrash()
- func (exec *PipelineExecutor) Release()
- func (exec *PipelineExecutor) SetDag(d *TransformDag)
- func (exec *PipelineExecutor) SetProcessors(pro Processors)
- func (exec *PipelineExecutor) SetRoot(r *TransformVertex)
- func (exec *PipelineExecutor) Visit(vertex *TransformVertex) TransformVertexVisitor
- type PlanFrame
- type PlanTemplate
- type PlanType
- func MatchAggGroup(schema hybridqp.Catalog) PlanType
- func MatchAggInterval(schema hybridqp.Catalog) PlanType
- func MatchAggIntervalLimit(schema hybridqp.Catalog) PlanType
- func MatchNoAggNoGroup(schema hybridqp.Catalog) PlanType
- func MatchNoAggNoGroupLimit(schema hybridqp.Catalog) PlanType
- func NilGetPlanType(schema hybridqp.Catalog, stmt *influxql.SelectStatement) PlanType
- func NormalGetPlanType(schema hybridqp.Catalog, stmt *influxql.SelectStatement) PlanType
- type PlanTypeInitShard
- func (pts *PlanTypeInitShard) Close() error
- func (pts *PlanTypeInitShard) CreateLogicalPlan(ctx context.Context, sources influxql.Sources, schema hybridqp.Catalog) (hybridqp.QueryNode, error)
- func (pts *PlanTypeInitShard) FieldDimensions(m *influxql.Measurement) (map[string]influxql.DataType, map[string]struct{}, *influxql.Schema, error)
- func (pts *PlanTypeInitShard) GetETraits(ctx context.Context, sources influxql.Sources, schema hybridqp.Catalog) ([]hybridqp.Trait, error)
- func (pts *PlanTypeInitShard) GetSeriesKey() []byte
- func (pts *PlanTypeInitShard) GetSources(sources influxql.Sources) influxql.Sources
- func (pts *PlanTypeInitShard) LogicalPlanCost(source *influxql.Measurement, opt query.ProcessorOptions) (hybridqp.LogicalPlanCost, error)
- func (pts *PlanTypeInitShard) MapType(m *influxql.Measurement, field string) influxql.DataType
- func (pts *PlanTypeInitShard) MapTypeBatch(m *influxql.Measurement, fields map[string]*influxql.FieldNameSpace, ...) error
- type PlanTypeInitShardMapper
- type Point
- type PointItem
- type PointMerge
- type PointRowIterator
- type Port
- type Ports
- type PreAggregateCallMapping
- type PrePoint
- type PrepareStmtBuilderCreator
- type Processor
- type Processors
- type PromAbsentOp
- type PromGroupOp
- type PromInstantVectorTransform
- func (trans *PromInstantVectorTransform) Close()
- func (trans *PromInstantVectorTransform) Explain() []ValuePair
- func (trans *PromInstantVectorTransform) GetGroupRange(i int, chunk Chunk) (int, int)
- func (trans *PromInstantVectorTransform) GetInputNumber(_ Port) int
- func (trans *PromInstantVectorTransform) GetInputs() Ports
- func (trans *PromInstantVectorTransform) GetOutputNumber(_ Port) int
- func (trans *PromInstantVectorTransform) GetOutputs() Ports
- func (trans *PromInstantVectorTransform) GroupCall(startIdx, endIdx int)
- func (trans *PromInstantVectorTransform) Name() string
- func (trans *PromInstantVectorTransform) RangeCall(startCurrLoc, endCurrLoc int, start, rangeMaxt int64)
- func (trans *PromInstantVectorTransform) UpdateLoc(startCurrLoc, endCurrLoc int)
- func (trans *PromInstantVectorTransform) Work(ctx context.Context) error
- func (trans *PromInstantVectorTransform) WorkHelper(ctx context.Context, errs *errno.Errs)
- type PromInstantVectorTransformCreator
- type PromQuantileOp
- type PromRangeVectorTransform
- func (trans *PromRangeVectorTransform) Close()
- func (trans *PromRangeVectorTransform) Explain() []ValuePair
- func (trans *PromRangeVectorTransform) GetGroupRange(i int, chunk Chunk) (int, int)
- func (trans *PromRangeVectorTransform) GetInputNumber(_ Port) int
- func (trans *PromRangeVectorTransform) GetInputs() Ports
- func (trans *PromRangeVectorTransform) GetOutputNumber(_ Port) int
- func (trans *PromRangeVectorTransform) GetOutputs() Ports
- func (trans *PromRangeVectorTransform) GroupCall(startIdx, endIdx int)
- func (trans *PromRangeVectorTransform) Name() string
- func (trans *PromRangeVectorTransform) NewPromSubqueryCallFunc(call *influxql.PromSubCall) (CallFn, error)
- func (trans *PromRangeVectorTransform) RangeCall(startPreLoc, endPreLoc, startCurrLoc, endCurrLoc int, start, rangeMaxt int64)
- func (trans *PromRangeVectorTransform) UpdateLoc(startPreLoc, endPreLoc, startCurrLoc, endCurrLoc int)
- func (trans *PromRangeVectorTransform) Work(ctx context.Context) error
- func (trans *PromRangeVectorTransform) WorkHelper(ctx context.Context, errs *errno.Errs)
- type PromRangeVectorTransformCreator
- type PromScalarOp
- type PromSortGroups
- type PromSortSeries
- type PromSortTransform
- func (trans *PromSortTransform) Close()
- func (trans *PromSortTransform) Explain() []ValuePair
- func (trans *PromSortTransform) GetInputNumber(_ Port) int
- func (trans *PromSortTransform) GetInputs() Ports
- func (trans *PromSortTransform) GetOutputNumber(_ Port) int
- func (trans *PromSortTransform) GetOutputs() Ports
- func (trans *PromSortTransform) Name() string
- func (trans *PromSortTransform) Work(ctx context.Context) error
- func (trans *PromSortTransform) WorkHelper(ctx context.Context, errs *errno.Errs)
- type PromSortTransformCreator
- type PromStdOp
- type PromStepInvariantType
- type PromTimeFunction
- type PromTimeValuer
- type PtQuery
- type QueryNodeStack
- type QuerySchema
- func NewQuerySchema(fields influxql.Fields, columnNames []string, opt hybridqp.Options, ...) *QuerySchema
- func NewQuerySchemaWithJoinCase(fields influxql.Fields, sources influxql.Sources, columnNames []string, ...) *QuerySchema
- func NewQuerySchemaWithSources(fields influxql.Fields, sources influxql.Sources, columnNames []string, ...) *QuerySchema
- func (qs *QuerySchema) AddHoltWinters(call *influxql.Call, alias string)
- func (qs *QuerySchema) AddLabelCalls(key string, labelCalls *influxql.Call)
- func (qs *QuerySchema) AddMath(key string, math *influxql.Call)
- func (qs *QuerySchema) AddPromTimeCalls(key string, promTimeCalls *influxql.Call)
- func (qs *QuerySchema) AddSlidingWindow(key string, str *influxql.Call)
- func (qs *QuerySchema) AddString(key string, str *influxql.Call)
- func (qs *QuerySchema) AddTable(m *influxql.Measurement, refs []influxql.VarRef)
- func (qs *QuerySchema) Binarys() map[string]*influxql.BinaryExpr
- func (qs *QuerySchema) BuildDownSampleSchema(addPrefix bool) record.Schemas
- func (qs *QuerySchema) Calls() map[string]*influxql.Call
- func (qs *QuerySchema) CanAggPushDown() bool
- func (qs *QuerySchema) CanAggTagSet() bool
- func (qs *QuerySchema) CanCallsPushdown() bool
- func (qs *QuerySchema) CanLimitCut() bool
- func (qs *QuerySchema) CanSeqAggPushDown() bool
- func (qs *QuerySchema) CloneField(f *influxql.Field) *influxql.Field
- func (qs *QuerySchema) CompositeCall() map[string]*hybridqp.OGSketchCompositeOperator
- func (qs *QuerySchema) ContainSeriesIgnoreCall() bool
- func (qs *QuerySchema) CountDistinct() *influxql.Call
- func (qs *QuerySchema) CountField() map[int]bool
- func (qs *QuerySchema) DerivedOrigCall(call *influxql.Call) influxql.VarRef
- func (qs *QuerySchema) DerivedRef(ref *influxql.VarRef) influxql.VarRef
- func (qs *QuerySchema) Fields() influxql.Fields
- func (qs *QuerySchema) FieldsRef() influxql.VarRefs
- func (qs *QuerySchema) GetColumnNames() []string
- func (qs *QuerySchema) GetFieldType(i int) (int64, error)
- func (qs *QuerySchema) GetJoinCaseCount() int
- func (qs *QuerySchema) GetJoinCases() []*influxql.Join
- func (qs *QuerySchema) GetOptions() hybridqp.Options
- func (qs *QuerySchema) GetPlanType() PlanType
- func (qs *QuerySchema) GetPromCalls() []*influxql.PromSubCall
- func (qs *QuerySchema) GetQueryFields() influxql.Fields
- func (qs *QuerySchema) GetSortFields() influxql.SortFields
- func (qs *QuerySchema) GetSourcesNames() []string
- func (qs *QuerySchema) GetTimeRangeByTC() util.TimeRange
- func (qs *QuerySchema) GetUnnests() influxql.Unnests
- func (qs *QuerySchema) HasAuxTag() bool
- func (qs *QuerySchema) HasBlankRowCall() bool
- func (qs *QuerySchema) HasCall() bool
- func (qs *QuerySchema) HasCastorCall() bool
- func (qs *QuerySchema) HasExcatLimit() bool
- func (qs *QuerySchema) HasFieldCondition() bool
- func (qs *QuerySchema) HasGroupBy() bool
- func (qs *QuerySchema) HasHoltWintersCall() bool
- func (qs *QuerySchema) HasInSeriesAgg() bool
- func (qs *QuerySchema) HasInterval() bool
- func (qs *QuerySchema) HasLabelCalls() bool
- func (qs *QuerySchema) HasLimit() bool
- func (qs *QuerySchema) HasMath() bool
- func (qs *QuerySchema) HasMeanCall() bool
- func (qs *QuerySchema) HasNonPreCall() bool
- func (qs *QuerySchema) HasNotInSeriesAgg() bool
- func (qs *QuerySchema) HasOptimizeAgg() bool
- func (qs *QuerySchema) HasOptimizeCall() bool
- func (qs *QuerySchema) HasPercentileOGSketch() bool
- func (qs *QuerySchema) HasPromAbsentCall() bool
- func (qs *QuerySchema) HasPromNestedCall() bool
- func (qs *QuerySchema) HasPromTimeCalls() bool
- func (qs *QuerySchema) HasRowCount() bool
- func (qs *QuerySchema) HasSlidingWindowCall() bool
- func (qs *QuerySchema) HasSort() bool
- func (qs *QuerySchema) HasStreamCall() bool
- func (qs *QuerySchema) HasString() bool
- func (qs *QuerySchema) HasSubQuery() bool
- func (qs *QuerySchema) HasTopNDDCM() bool
- func (qs *QuerySchema) HasUnnests() bool
- func (qs *QuerySchema) HoltWinters() []*influxql.Field
- func (qs *QuerySchema) InitFieldCondition()
- func (qs *QuerySchema) IsHoltWinters(val string) bool
- func (qs *QuerySchema) IsMultiMeasurements() bool
- func (qs *QuerySchema) IsPromAbsentCall() bool
- func (qs *QuerySchema) IsPromNestedCall(call *influxql.Call) bool
- func (qs *QuerySchema) IsPromNestedCountCall() bool
- func (qs *QuerySchema) IsRefInQueryFields(ref *influxql.VarRef) bool
- func (qs *QuerySchema) IsRefInSymbolFields(ref *influxql.VarRef) bool
- func (qs *QuerySchema) IsTimeZero() bool
- func (qs *QuerySchema) LimitAndOffset() (int, int)
- func (qs *QuerySchema) LimitType() hybridqp.LimitType
- func (qs *QuerySchema) MakeRefs() []influxql.VarRef
- func (qs *QuerySchema) Mapping() map[influxql.Expr]influxql.VarRef
- func (qs *QuerySchema) MatchPreAgg() bool
- func (qs *QuerySchema) OnlyOneCallRef() *influxql.VarRef
- func (qs *QuerySchema) Options() hybridqp.Options
- func (qs *QuerySchema) OrigCalls() map[string]*influxql.Call
- func (qs *QuerySchema) PromNestedCall() map[string]*hybridqp.PromNestedCall
- func (qs *QuerySchema) PromResetTime() bool
- func (qs *QuerySchema) Refs() map[string]*influxql.VarRef
- func (qs *QuerySchema) SetFill(fill influxql.FillOption)
- func (qs *QuerySchema) SetHoltWinters(calls []*influxql.Call)
- func (qs *QuerySchema) SetOpt(opt hybridqp.Options)
- func (qs *QuerySchema) SetPlanType(planType PlanType)
- func (qs *QuerySchema) SetPromCalls(calls []*influxql.PromSubCall)
- func (qs *QuerySchema) SetSimpleTagset()
- func (qs *QuerySchema) SetUnnests(unnests []*influxql.Unnest)
- func (qs *QuerySchema) SlidingWindow() map[string]*influxql.Call
- func (qs *QuerySchema) Sources() influxql.Sources
- func (qs *QuerySchema) Symbols() map[string]influxql.VarRef
- func (qs *QuerySchema) Table(name string) *QueryTable
- func (qs *QuerySchema) Visit(n influxql.Node) influxql.Visitor
- type QuerySchemaCreator
- type QueryTable
- type RPCClient
- func (c *RPCClient) Abort(noMarkCrash bool)
- func (c *RPCClient) AddHandler(msgType byte, handle Handler)
- func (c *RPCClient) FinishAnalyze()
- func (c *RPCClient) GetCodec() transport.Codec
- func (c *RPCClient) Handle(data interface{}) error
- func (c *RPCClient) Init(ctx context.Context, queryNode []byte)
- func (c *RPCClient) Interrupt(noMarkCrash bool)
- func (c *RPCClient) Run() error
- func (c *RPCClient) StartAnalyze(span *tracing.Span)
- type RPCReaderTransform
- func (t *RPCReaderTransform) Abort()
- func (t *RPCReaderTransform) Close()
- func (t *RPCReaderTransform) Distribute(node hybridqp.QueryNode)
- func (t *RPCReaderTransform) Explain() []ValuePair
- func (t *RPCReaderTransform) GetInputNumber(_ Port) int
- func (t *RPCReaderTransform) GetInputs() Ports
- func (t *RPCReaderTransform) GetOutputNumber(_ Port) int
- func (t *RPCReaderTransform) GetOutputs() Ports
- func (t *RPCReaderTransform) Interrupt()
- func (t *RPCReaderTransform) InterruptWithoutMark()
- func (t *RPCReaderTransform) IsSink() bool
- func (t *RPCReaderTransform) Name() string
- func (t *RPCReaderTransform) Release() error
- func (t *RPCReaderTransform) Work(ctx context.Context) error
- type RPCSenderTransform
- func (t *RPCSenderTransform) Close()
- func (t *RPCSenderTransform) Explain() []ValuePair
- func (t *RPCSenderTransform) GetInputNumber(_ Port) int
- func (t *RPCSenderTransform) GetInputs() Ports
- func (t *RPCSenderTransform) GetOutputNumber(_ Port) int
- func (t *RPCSenderTransform) GetOutputs() Ports
- func (t *RPCSenderTransform) Name() string
- func (t *RPCSenderTransform) Work(ctx context.Context) error
- type RateFinalReduceFunc
- type RateMergeFunc
- type RateMiddleReduceFunc
- type RateUpdateFunc
- type ReaderCreator
- type ReaderCreatorFactory
- type ReaderUpdateInSubQueryRule
- type ReflectionTable
- type ReflectionTables
- type RemoteQuery
- type ResultEval
- type ResultEvalPool
- type RetryErrTransform
- func (source *RetryErrTransform) Close()
- func (source *RetryErrTransform) Explain() []ValuePair
- func (source *RetryErrTransform) GetInputNumber(_ Port) int
- func (source *RetryErrTransform) GetInputs() Ports
- func (source *RetryErrTransform) GetOutputNumber(_ Port) int
- func (source *RetryErrTransform) GetOutputs() Ports
- func (source *RetryErrTransform) Name() string
- func (source *RetryErrTransform) Work(ctx context.Context) error
- type Routine
- func NewAbsentRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewBottomRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewCountRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewCumulativeSumRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewDerivativeRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewDifferenceRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewDistinctRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (Routine, error)
- func NewElapsedRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewFirstRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewIntegralRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewLastRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewMedianRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewModeRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewMovingAverageRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewPercentileApproxRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, ...) (Routine, error)
- func NewPercentileRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewRateRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewSampleRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewSlidingWindowCountRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) Routine
- func NewSlidingWindowMaxRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) Routine
- func NewSlidingWindowMinRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) Routine
- func NewSlidingWindowSumRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) Routine
- func NewStddevRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewSumRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- func NewTopRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, ...) (Routine, error)
- type RoutineImpl
- type Row
- type RowChunk
- type Rows
- type RowsGenerator
- type RuleInstruction
- type RuleSet
- type SampleItem
- type ScalarBuf
- type ScalarIterator
- type Semaphore
- type Series
- type SeriesRecord
- func (r *SeriesRecord) GetErr() error
- func (r *SeriesRecord) GetRec() *record.Record
- func (r *SeriesRecord) GetSeq() uint64
- func (r *SeriesRecord) GetSid() uint64
- func (r *SeriesRecord) GetTr() *util.TimeRange
- func (r *SeriesRecord) GetTsspFile() immutable.TSSPFile
- func (r *SeriesRecord) SetRec(re *record.Record)
- type SeriesRecordPort
- func (p *SeriesRecordPort) Close()
- func (p *SeriesRecordPort) Connect(to Port)
- func (p *SeriesRecordPort) ConnectWithoutCache(to Port)
- func (p *SeriesRecordPort) ConnectionId() uintptr
- func (p *SeriesRecordPort) Equal(to Port) bool
- func (p *SeriesRecordPort) Redirect(to Port)
- func (p *SeriesRecordPort) Release()
- type SetSchemaVisitor
- type ShardFileFragment
- type ShardInfo
- type ShardsFragments
- type ShardsFragmentsGroup
- func (sfg *ShardsFragmentsGroup) GetFragmentCount() int64
- func (sfg *ShardsFragmentsGroup) GetFrags() ShardsFragments
- func (sfg *ShardsFragmentsGroup) MoveTo(des *ShardsFragmentsGroup, id uint64, filePath string)
- func (sfg *ShardsFragmentsGroup) MoveToFileNotExist(des *ShardsFragmentsGroup)
- func (sfg *ShardsFragmentsGroup) SearchAndMoveExistFile(des *ShardsFragmentsGroup)
- type ShardsFragmentsGroups
- func (fgs *ShardsFragmentsGroups) Balance()
- func (fgs *ShardsFragmentsGroups) HasGroup() bool
- func (fgs *ShardsFragmentsGroups) Len() int
- func (fgs *ShardsFragmentsGroups) Less(i, j int) bool
- func (fgs *ShardsFragmentsGroups) MoveFrags(from, to int)
- func (fgs *ShardsFragmentsGroups) NextGroup() *ShardsFragmentsGroup
- func (fgs *ShardsFragmentsGroups) PeekGroup() *ShardsFragmentsGroup
- func (fgs *ShardsFragmentsGroups) Pop() interface{}
- func (fgs *ShardsFragmentsGroups) Push(x interface{})
- func (fgs *ShardsFragmentsGroups) String() string
- func (fgs *ShardsFragmentsGroups) Swap(i, j int)
- type SinkFromFunction
- func (sink *SinkFromFunction) Close()
- func (sink *SinkFromFunction) Explain() []ValuePair
- func (sink *SinkFromFunction) GetInputNumber(_ Port) int
- func (sink *SinkFromFunction) GetInputs() Ports
- func (sink *SinkFromFunction) GetOutputNumber(_ Port) int
- func (sink *SinkFromFunction) GetOutputs() Ports
- func (sink *SinkFromFunction) Name() string
- func (sink *SinkFromFunction) Work(ctx context.Context) error
- type SliceItem
- type SliceReduce
- type SlideWindowSpreadRule
- type SlidingWindow
- type SlidingWindowBooleanIterator
- type SlidingWindowFloatIterator
- type SlidingWindowIntegerIterator
- type SlidingWindowTransform
- func (trans *SlidingWindowTransform) Close()
- func (trans *SlidingWindowTransform) Explain() []ValuePair
- func (trans *SlidingWindowTransform) GetInputNumber(port Port) int
- func (trans *SlidingWindowTransform) GetInputs() Ports
- func (trans *SlidingWindowTransform) GetOutputNumber(port Port) int
- func (trans *SlidingWindowTransform) GetOutputs() Ports
- func (trans *SlidingWindowTransform) Name() string
- func (trans *SlidingWindowTransform) Work(ctx context.Context) error
- type SlidingWindowTransformCreator
- type SortAppendTransf
- func (t *SortAppendTransf) CostName() string
- func (t *SortAppendTransf) GetType() MergeTransformType
- func (t *SortAppendTransf) InitColumnsIteratorHelper(rt hybridqp.RowDataType) CoProcessor
- func (t *SortAppendTransf) InitHeapItems(inRowDataLen int, _ hybridqp.RowDataType, schema *QuerySchema) BaseHeapItems
- func (t *SortAppendTransf) Name() string
- type SortAppendTransformCreator
- type SortMergeTransf
- func (t *SortMergeTransf) CostName() string
- func (t *SortMergeTransf) GetType() MergeTransformType
- func (t *SortMergeTransf) InitColumnsIteratorHelper(rt hybridqp.RowDataType) CoProcessor
- func (t *SortMergeTransf) InitHeapItems(inRowDataLen int, rt hybridqp.RowDataType, schema *QuerySchema) BaseHeapItems
- func (t *SortMergeTransf) Name() string
- type SortMergeTransformCreator
- type SortTransform
- func (trans *SortTransform) Close()
- func (trans *SortTransform) Explain() []ValuePair
- func (trans *SortTransform) GetInputNumber(_ Port) int
- func (trans *SortTransform) GetInputs() Ports
- func (trans *SortTransform) GetOutputNumber(_ Port) int
- func (trans *SortTransform) GetOutputs() Ports
- func (trans *SortTransform) Name() string
- func (trans *SortTransform) Release() error
- func (trans *SortTransform) Work(ctx context.Context) error
- type SortTransformCreator
- type SortedBreakPoint
- type SortedHeapItems
- func (h *SortedHeapItems) GetBreakPoint() BaseBreakPoint
- func (h *SortedHeapItems) GetOption() *query.ProcessorOptions
- func (h *SortedHeapItems) Len() int
- func (h *SortedHeapItems) Less(i, j int) bool
- func (h *SortedHeapItems) Pop() interface{}
- func (h *SortedHeapItems) Push(x interface{})
- func (h *SortedHeapItems) Swap(i, j int)
- type SortedMergeAuxHelper
- type SortedMergeAuxHelpers
- type SourceFromSingleChunk
- func (source *SourceFromSingleChunk) Close()
- func (source *SourceFromSingleChunk) Explain() []ValuePair
- func (source *SourceFromSingleChunk) GetInputNumber(_ Port) int
- func (source *SourceFromSingleChunk) GetInputs() Ports
- func (source *SourceFromSingleChunk) GetOutputNumber(_ Port) int
- func (source *SourceFromSingleChunk) GetOutputs() Ports
- func (source *SourceFromSingleChunk) Name() string
- func (source *SourceFromSingleChunk) Work(ctx context.Context) error
- type Spacer
- type SparseIndexScanTransform
- func (trans *SparseIndexScanTransform) Abort()
- func (trans *SparseIndexScanTransform) Close()
- func (trans *SparseIndexScanTransform) Counting(ctx context.Context)
- func (trans *SparseIndexScanTransform) Explain() []ValuePair
- func (trans *SparseIndexScanTransform) GetInputNumber(_ Port) int
- func (trans *SparseIndexScanTransform) GetInputs() Ports
- func (trans *SparseIndexScanTransform) GetOutputNumber(_ Port) int
- func (trans *SparseIndexScanTransform) GetOutputs() Ports
- func (trans *SparseIndexScanTransform) IsSink() bool
- func (trans *SparseIndexScanTransform) Name() string
- func (trans *SparseIndexScanTransform) Release() error
- func (trans *SparseIndexScanTransform) Running(ctx context.Context)
- func (trans *SparseIndexScanTransform) Work(ctx context.Context) error
- func (trans *SparseIndexScanTransform) WorkHelper(ctx context.Context) error
- type SparseIndexScanTransformCreator
- type SplitTransformTransform
- func (trans *SplitTransformTransform) Close()
- func (trans *SplitTransformTransform) Explain() []ValuePair
- func (trans *SplitTransformTransform) GetInputNumber(_ Port) int
- func (trans *SplitTransformTransform) GetInputs() Ports
- func (trans *SplitTransformTransform) GetOutputNumber(_ Port) int
- func (trans *SplitTransformTransform) GetOutputs() Ports
- func (trans *SplitTransformTransform) Name() string
- func (trans *SplitTransformTransform) Release() error
- func (trans *SplitTransformTransform) SendChunk()
- func (trans *SplitTransformTransform) Work(ctx context.Context) error
- type SplitTransformTransformCreator
- type StdoutChunkWriter
- type StoreExchangeTraits
- func (t *StoreExchangeTraits) HasReader() bool
- func (t *StoreExchangeTraits) HasShard() bool
- func (t *StoreExchangeTraits) NextReader() []interface{}
- func (t *StoreExchangeTraits) NextShard() uint64
- func (t *StoreExchangeTraits) PeekReader() []interface{}
- func (t *StoreExchangeTraits) PeekShard() uint64
- func (t *StoreExchangeTraits) Readers(shard uint64) [][]interface{}
- func (t *StoreExchangeTraits) Reset()
- type StreamAggregateTransform
- func (trans *StreamAggregateTransform) Close()
- func (trans *StreamAggregateTransform) Explain() []ValuePair
- func (trans *StreamAggregateTransform) GetInputNumber(port Port) int
- func (trans *StreamAggregateTransform) GetInputs() Ports
- func (trans *StreamAggregateTransform) GetOutputNumber(port Port) int
- func (trans *StreamAggregateTransform) GetOutputs() Ports
- func (trans *StreamAggregateTransform) Name() string
- func (trans *StreamAggregateTransform) NextChunk()
- func (trans *StreamAggregateTransform) Work(ctx context.Context) error
- type StreamAggregateTransformCreator
- type StringAlignIterator
- type StringAppendIterator
- type StringColReduceSliceReduce
- type StringColStringDistinctIterator
- type StringColStringSampleIterator
- type StringColStringSliceIterator
- type StringFieldValuer
- type StringIntervalIterator
- type StringIterator
- type StringLimitIterator
- type StringLinearFillProcessor
- type StringMerge
- type StringMergeIterator
- type StringNullFillProcessor
- type StringNumberFillProcessor
- type StringPoint
- type StringPreviousFillProcessor
- type StringTimeColStringIterator
- type StringTimeColStringMerge
- type StringValuer
- type SubQueryBuilder
- type SubQueryTransform
- func (trans *SubQueryTransform) Close()
- func (trans *SubQueryTransform) Explain() []ValuePair
- func (trans *SubQueryTransform) GetInputNumber(_ Port) int
- func (trans *SubQueryTransform) GetInputs() Ports
- func (trans *SubQueryTransform) GetOutputNumber(_ Port) int
- func (trans *SubQueryTransform) GetOutputs() Ports
- func (trans *SubQueryTransform) Name() string
- func (trans *SubQueryTransform) Release() error
- func (trans *SubQueryTransform) Work(ctx context.Context) error
- type SubQueryTransformCreator
- type TCountMinSketch
- type TCounter
- type TDdcm
- func (ddcm *TDdcm) AddKeyCount(key TKey, value TCounter)
- func (ddcm *TDdcm) CalcHashesAndGetIndices(key TKey, level int, indices *[]int)
- func (ddcm *TDdcm) CalcLargeSketchIndices(key TKey, indices *[]int)
- func (ddcm *TDdcm) ExtendLevels(size int)
- func (ddcm *TDdcm) GetFrequentKeys(countLowerBound TCounter) ([]TKey, []TCounter)
- func (ddcm *TDdcm) GetFrequentKeysOfSize(countLowerBound TCounter, size int, keys *[]TKey, values *[]TCounter)
- func (ddcm *TDdcm) GetKeyCount(key TKey) TCounter
- func (ddcm *TDdcm) GetTotalCount() TCounter
- type TDdcmCycleManagerBase
- type TDdcmCycleManagerWdm
- type TDdcmParameters
- type TExtendedHashValue
- type THashValue
- type THashVector
- type THasher
- func (h *THasher) GetInitialHashVector(hashVector *THashVector)
- func (h *THasher) TurnHashesIntoIndices(hashes THashVector, indices *[]int)
- func (h *THasher) UpdateHashes(key TKey, numBitsBefore int, numBitsAfter int, hashes *THashVector)
- func (h *THasher) UpdateHashesBytewise(key TKey, numBytesBefore int, numBytesAfter int, hashes *THashVector)
- type TKey
- type TableScanFromSingleChunk
- func (scan *TableScanFromSingleChunk) Close()
- func (scan *TableScanFromSingleChunk) Explain() []ValuePair
- func (scan *TableScanFromSingleChunk) GetInputNumber(_ Port) int
- func (scan *TableScanFromSingleChunk) GetInputs() Ports
- func (scan *TableScanFromSingleChunk) GetOutputNumber(_ Port) int
- func (scan *TableScanFromSingleChunk) GetOutputs() Ports
- func (scan *TableScanFromSingleChunk) Name() string
- func (scan *TableScanFromSingleChunk) Work(ctx context.Context) error
- type TagValues
- type TargetTable
- type TargetTablePool
- type TargetTransform
- func (trans *TargetTransform) Close()
- func (trans *TargetTransform) CloseWriteChan()
- func (trans *TargetTransform) Explain() []ValuePair
- func (trans *TargetTransform) GetInputNumber(_ Port) int
- func (trans *TargetTransform) GetInputs() Ports
- func (trans *TargetTransform) GetOutputNumber(_ Port) int
- func (trans *TargetTransform) GetOutputs() Ports
- func (trans *TargetTransform) Name() string
- func (trans *TargetTransform) Work(ctx context.Context) error
- type TargetTransformCreator
- type TargetTuple
- type TimeColReduceFunc
- type TimeFuncState
- type TopNTransform
- func (trans *TopNTransform) Close()
- func (trans *TopNTransform) Explain() []ValuePair
- func (trans *TopNTransform) GetInputNumber(_ Port) int
- func (trans *TopNTransform) GetInputs() Ports
- func (trans *TopNTransform) GetOutputNumber(_ Port) int
- func (trans *TopNTransform) GetOutputs() Ports
- func (trans *TopNTransform) InitFuncs(inRowDataType hybridqp.RowDataType, fn string, opt hybridqp.ExprOptions) error
- func (trans *TopNTransform) Name() string
- func (trans *TopNTransform) Work(ctx context.Context) error
- type TopNTransformCreator
- type TransItem
- type TransformCreator
- type TransformCreatorFactory
- type TransformDag
- func (dag *TransformDag) AddEdge(from *TransformVertex, to *TransformVertex) bool
- func (dag *TransformDag) AddVertex(vertex *TransformVertex) bool
- func (dag *TransformDag) Contains(vertex *TransformVertex) bool
- func (dag *TransformDag) DepthFirstWalkVertex(visitor TransformVertexVisitor, vertex *TransformVertex)
- func (dag *TransformDag) SetVertexToInfo(vertex *TransformVertex, info *TransformVertexInfo)
- func (dag *TransformDag) WalkVertex(vertex *TransformVertex, fn func(to, from *TransformVertex))
- type TransformEdge
- type TransformVertex
- type TransformVertexInfo
- type TransformVertexVisitor
- type UnRefDbPt
- type ValueCount
- type ValuePair
- type Vertex
- type VertexId
- type VertexWriter
- type VertexWriterImpl
- type Vertexs
- type WalkFn
- type WideCoProcessorImpl
- type WideIterator
- type WideReduce
- type WideRoutineImpl
- type WindowMerge
Constants ¶
const ( DefaultClusterNum = 100 MaxClusterNum = 100000 )
const ( OGSketchInsert = "ogsketch_insert" OGSketchMerge = "ogsketch_merge" OGSketchPercentile = "ogsketch_percentile" PercentileApprox = "percentile_approx" PercentileOGSketch = "percentile_ogsketch" )
const ( LenOfValuers = 2 // MathValuer + MapValuer ZeroTimeStamp = 0 )
const ( SlowFuncIdx int = 0 FastFuncIdx int = 1 FuncPathCount int = 2 )
const ( IncAggChunkCacheSize int64 = 100 * 1024 * 1024 IncAggChunkCacheTTL = 10 * time.Minute )
const ( IncHashAggChunkCacheSize int64 = 100 * 1024 * 1024 IncHashAggChunkCacheTTL = 10 * time.Minute MaxRowsInChunk int = 32768 )
const ( UnknownMessage byte = iota ErrorMessage FinishMessage ChunkResponseMessage AnalyzeResponseMessage QueryMessage IncQueryFinishMessage MessageEof )
const ( BALANCED_DIFF = 5 Aborted = "aborted" )
const AggBufChunkNum = 2
const AlignPingPongChunkNum = 4
const (
BinOpTransformName = "BinOpTransform"
)
const CircularChunkNum = 4
CircularChunkNum Do not Modify. CircularChunks consists of one input chunk, two cached chunks(agg/fill and cached channel) and one chunk(cycle)
const DefaultTime = 0
const EulerNumber float64 = 2.7182818284
const FillBufChunkNum = 2
const HashAggTransformBufCap = 8192
const HashMergeTransformBufCap = 1024
const (
INVALID_NUMBER int = -1
)
const IncQueryFinishLength = util.BooleanSizeBytes*2 + util.Int32SizeBytes + util.Int64SizeBytes
const MersennePower int = 31
const OrderbyChunkNum = 6
OrderbyChunkNum consists of 3 orderbyTransform chunks and 3 hash_agg_transform chunks orderby_transform: 1 currChunk,1 bufChunk and 1 outCh hash_agg_transform: 1 inCh, 1 inputChunk and 1 bufChunk
const (
PORT_CHAN_SIZE int = 1
)
const (
PromInstantVectorTransformName = "PromInstantVectorTransform"
)
const (
PromRangeVectorTransformName = "PromRangeVectorTransform"
)
const (
RESULT_NAME string = "result"
)
const SlidingWindowBufChunkNum = 2
const UDAFMaxRow = 10000
Variables ¶
var (
BitMask2 = [8]byte{1, 2, 4, 8, 16, 32, 64, 128}
)
var DefaultDelta float64 = 1e-8
var DefaultEps float64 = DefaultPhi / 10
var DefaultPhi float64 = 3e-5
var DefaultSigma float64 = 1e-3 var DefaultDelta float64 = 1e-3
var DefaultSigma float64 = 1e-8
var DefaultTypeMapper = influxql.MultiTypeMapper( op.TypeMapper{}, query.MathTypeMapper{}, query.FunctionTypeMapper{}, query.StringFunctionTypeMapper{}, query.LabelFunctionTypeMapper{}, query.PromTimeFunctionTypeMapper{}, )
var GetColValsFn map[influxql.DataType]func(col Column, bmStart, bmEnd int, ckLen int, dst []interface{}) []interface{}
var GetPlanType func(hybridqp.Catalog, *influxql.SelectStatement) PlanType
var IgnoreEmptyTag = false
var IncAggChunkCache = cache.NewCache(IncAggChunkCacheSize, IncAggChunkCacheTTL)
var IncHashAggChunkCache = cache.NewCache(IncHashAggChunkCacheSize, IncHashAggChunkCacheTTL)
var MatchPlanFunc []func(hybridqp.Catalog) PlanType
var NotAggOnSeries = make(map[string]bool)
var OneShardStorePlanTemplate []*PlanTemplate
var PlanTypes []PlanType
var RowSize = 1024
var SkipDefault = interface{}(0)
var SqlPlanTemplate []*PlanTemplate
var StorePlanTemplate []*PlanTemplate
var TemplateSql []string = []string{
"SELECT max(f1) from mst WHERE (tag1 = 'tag1val') and time > 1 and time < 2 group by time(1ns)",
"SELECT max(f1) from mst WHERE time < 2 group by time(1ns) limit 1",
"SELECT * from mst where f1 > 1 and (tag1 = 'tag1val') and time > 1 and time < 2",
"SELECT last(*) from mst group by tag1",
"SELECT f1 from mst where tag1 = 'tag1val' order by time limit 1",
"SELECT max(f1) from mst WHERE (tag1 = 'tag1val') and time > 1 and time < 2 group by time(1ns) fill(none)",
}
only for OptimizeAgg or call PreAggregateCallMapping, some calls like top/bottom/percentile_ogsketch which cancallspushdown but not use template plan
Functions ¶
func AbsentMerge ¶ added in v1.3.0
func AbsentMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
func AbsentReduce ¶ added in v1.3.0
func AbsentWithOutDataAlive ¶ added in v1.4.0
func AbsentWithOutDataAlive(opt *query.ProcessorOptions, outChunk Chunk)
func AbsoluteDiffFunc ¶ added in v1.3.0
func AbsoluteDiffFunc[T util.NumberOnly](prev, curr T) T
func AppendRowValue ¶ added in v1.0.0
func AppendRowValue(column Column, value interface{})
func BehindDiffFunc ¶ added in v1.3.0
func BehindDiffFunc[T util.NumberOnly](prev, curr T) T
func BinOpATAN2 ¶ added in v1.4.0
func BooleanAuxHelpFunc ¶
func BooleanFirstMerge ¶
func BooleanFirstReduce ¶
func BooleanLastMerge ¶
func BooleanLastReduce ¶
func BooleanMaxMerge ¶
func BooleanMaxReduce ¶
func BooleanMinMerge ¶
func BooleanMinReduce ¶
func BottomCmpByTimeReduce ¶ added in v1.3.0
func BottomCmpByTimeReduce[T util.NumberOnly](a, b *PointItem[T]) bool
func BottomCmpByValueReduce ¶ added in v1.3.0
func BottomCmpByValueReduce[T util.NumberOnly](a, b *PointItem[T]) bool
func BottomCmpByValueReduceProm ¶ added in v1.4.0
func BottomCmpByValueReduceProm[T util.NumberOnly](a, b *PointItem[T]) bool
func BuildBinOpQueryPlan ¶ added in v1.3.0
func BuildBinOpQueryPlan(ctx context.Context, qc query.LogicalPlanCreator, stmt *influxql.SelectStatement, schema *QuerySchema) (hybridqp.QueryNode, error)
func BuildFullJoinQueryPlan ¶ added in v1.3.0
func BuildFullJoinQueryPlan(ctx context.Context, qc query.LogicalPlanCreator, stmt *influxql.SelectStatement, schema *QuerySchema) (hybridqp.QueryNode, error)
func BuildHeuristicPlanner ¶ added in v1.0.0
func BuildHeuristicPlannerForStore ¶ added in v1.0.0
func BuildInConditionPlan ¶ added in v1.1.0
func BuildInConditionPlan(ctx context.Context, qc query.LogicalPlanCreator, stmt *influxql.SelectStatement, schema *QuerySchema) (hybridqp.QueryNode, hybridqp.Catalog, error)
func BuildSources ¶ added in v1.3.0
func CalcChange ¶ added in v1.4.0
func CalcHoltWinters ¶ added in v1.4.0
func CalcLastTwoPoints ¶ added in v1.4.0
func CalcMad ¶ added in v1.4.0
CalcMad calculates the Mean Absolute Deviation (MAD) of a given dataset. Parameters:
values: a slice of float64 numbers representing the dataset to calculate the MAD.
Return value:
The calculated MAD.
Note: This function modifies the input slice by changing its values in place.
func CalcQuantile ¶ added in v1.4.0
CalcQuantile calculates the q-quantile of a given dataset. Parameters:
q: the quantile to calculate (should be between 0 and 1). values: a slice of float64 numbers representing the dataset.
Return value:
The calculated q-quantile.
Note: This function modifies the input slice by sorting its elements.
If q is less than 0 or greater than 1, it returns positive or negative infinity. If the input slice is empty or q is NaN, it returns NaN.
func CalcQuantile2 ¶ added in v1.4.0
func CalcReduceResult ¶ added in v1.3.0
func CalcResets ¶ added in v1.4.0
func CastorReduce ¶ added in v0.2.0
func ChangeCallExprForTimestamp ¶ added in v1.3.0
func ChangeOpsForTimestamp ¶ added in v1.3.0
func ChangeOpsForTimestamp(ops []hybridqp.ExprOptions) []hybridqp.ExprOptions
func ChunkToArrowRecords ¶ added in v1.0.0
func ChunkToArrowRecords(chunks []Chunk, taskId string, args []influxql.Expr) ([]arrow.Record, *errno.Error)
ChunkToArrowRecords must release record after use
func ColumnStringValue ¶ added in v1.2.0
func CompareBreakPoint ¶
func CompareBreakPoint(name string, time int64, tag ChunkTags, b *BreakPoint, opt query.ProcessorOptions) bool
func CompareSortedAppendBreakPoint ¶
func CompareSortedAppendBreakPoint(item Item, in int, tag ChunkTags, b *SortedBreakPoint, opt query.ProcessorOptions) bool
func CompareSortedMergeBreakPoint ¶
func CompareSortedMergeBreakPoint(item Item, in int, tag ChunkTags, b *SortedBreakPoint, opt *query.ProcessorOptions) bool
func ContainDim ¶
func ContainsSameTagset ¶ added in v1.4.0
func CopyArrowRecordToChunk ¶ added in v1.0.0
func CountMerge ¶ added in v1.3.0
func CountMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
func CountReduce ¶ added in v1.3.0
func DecodeBytes ¶
func DoCalcChange ¶ added in v1.4.0
func DoCalcResets ¶ added in v1.4.0
func EnableFileCursor ¶
func EnableFileCursor(en bool)
func ExpandColumnOffsets ¶ added in v1.2.0
func FirstMerge ¶ added in v1.3.0
func FirstMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
func FirstReduce ¶ added in v1.3.0
func FirstTimeColFastReduce ¶ added in v1.3.0
func FirstTimeColMerge ¶ added in v1.3.0
func FirstTimeColMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
func FirstTimeColReduce ¶ added in v1.3.0
func FirstTimeColSlowReduce ¶ added in v1.3.0
func Float64Equal ¶ added in v1.4.0
func FloatAuxHelpFunc ¶
func FloatCountPromMerge ¶ added in v1.3.0
func FloatCountPromReduce ¶ added in v1.3.0
func FrontDiffFunc ¶ added in v1.3.0
func FrontDiffFunc[T util.NumberOnly](prev, curr T) T
func GetEnableFileCursor ¶
func GetEnableFileCursor() bool
func GetFieldInfo ¶ added in v1.0.0
GetFieldInfo return every series' field info in form of 2 level map. Level 1 key is series key, level 2 key is field name.
func GetInnerDimensions ¶ added in v1.0.0
func GetMaxNumsOfGroups ¶ added in v1.2.0
func GetMaxNumsOfGroups() int
func GetOrdinal ¶ added in v1.3.0
func GetOrdinal(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (int, int)
func GetPlanSliceByTree ¶ added in v1.1.0
func GetPlanSliceByTreeDFS ¶ added in v1.1.0
func GetPromTimeFuncInstance ¶ added in v1.3.0
func GetPromTimeFuncInstance() map[string]PromTimeFunction
func GetStorePlanTemplate ¶ added in v1.1.0
func GetTypeName ¶
func GetTypeName(i interface{}) string
func GroupMerge ¶ added in v1.3.0
func GroupReduce ¶ added in v1.3.0
func IndexUnion ¶
func InitLocalStoreTemplatePlan ¶ added in v1.2.0
func InitLocalStoreTemplatePlan()
func InitMstName ¶ added in v1.0.0
func InitMstName(item *AppendHeapItems) string
func IntegerAuxHelpFunc ¶
func IntervalIndexGen ¶
func IntervalIndexGen(ck Chunk, opt *query.ProcessorOptions)
func IrateFastReduce ¶ added in v1.3.0
func IrateFinalReduce ¶ added in v1.3.0
func IrateMerge ¶ added in v1.3.0
func IrateMiddleReduce ¶ added in v1.3.0
func IrateSlowReduce ¶ added in v1.3.0
func IrateUpdate ¶ added in v1.3.0
func IrateUpdate[T util.NumberOnly](prevPoints, currPoints [2]*Point[T])
func IsEnableFileCursor ¶ added in v1.3.0
func IsSubTreeEqual ¶
func KahanSumInc ¶ added in v1.4.0
func LastMerge ¶ added in v1.3.0
func LastMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
func LastReduce ¶ added in v1.3.0
func LastTimeColFastReduce ¶ added in v1.3.0
func LastTimeColMerge ¶ added in v1.3.0
func LastTimeColMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
func LastTimeColReduce ¶ added in v1.3.0
func LastTimeColSlowReduce ¶ added in v1.3.0
func MarshalPtQuerys ¶ added in v1.2.0
func MarshalQueryNode ¶
MarshalQueryNode The schema of all nodes are the same, only one codec is required. |8 byte schema size|schema buffer|node buffer|
func MarshalShardInfos ¶ added in v1.2.0
func MaxMerge ¶ added in v1.3.0
func MaxMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
func MaxPromMerge ¶ added in v1.3.0
func MaxPromReduce ¶ added in v1.3.0
func MinMerge ¶ added in v1.3.0
func MinMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
func MinPromMerge ¶ added in v1.3.0
func MinPromReduce ¶ added in v1.3.0
func NewAggFunc ¶ added in v1.1.0
func NewAggFunc(aggType AggFuncType, fn NewAggOperator, inIdx int, outIdx int, p any) *aggFunc
func NewBoolSortEle ¶ added in v1.1.0
func NewBoolSortEle() sortEleMsg
func NewBooleanModeReduce ¶
func NewBooleanModeReduce(BooleanSliceItem *BooleanSliceItem) (int, int64, float64, bool)
func NewChunkResponse ¶
func NewCountFunc ¶ added in v1.1.0
func NewCountFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewCountOperator ¶ added in v1.1.1
func NewCountOperator() aggOperator
func NewCountPromFunc ¶ added in v1.3.0
func NewCountPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewCountPromOperator ¶ added in v1.3.0
func NewCountPromOperator() aggOperator
func NewFinishMessage ¶
func NewFirstBooleanOperator ¶ added in v1.1.1
func NewFirstBooleanOperator() aggOperator
func NewFirstFloatOperator ¶ added in v1.1.1
func NewFirstFloatOperator() aggOperator
func NewFirstFunc ¶ added in v1.1.0
func NewFirstFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewFirstIntegerOperator ¶ added in v1.1.1
func NewFirstIntegerOperator() aggOperator
func NewFirstStringOperator ¶ added in v1.1.1
func NewFirstStringOperator() aggOperator
func NewFloatSortEle ¶ added in v1.1.0
func NewFloatSortEle() sortEleMsg
func NewGroupPromFunc ¶ added in v1.4.0
func NewGroupPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewGroupPromOperator ¶ added in v1.4.0
func NewGroupPromOperator() aggOperator
func NewHeapFloatOperator ¶ added in v1.2.0
func NewHeapFloatOperator() aggOperator
func NewHeapFunc ¶ added in v1.2.0
func NewHeapFunc(inRowDataType, outRowDataType hybridqp.RowDataType, exprOpt []hybridqp.ExprOptions, sortIdx int, sortAsc bool) (*aggFunc, error)
func NewHeapIntegerOperator ¶ added in v1.2.0
func NewHeapIntegerOperator() aggOperator
func NewHeapParam ¶ added in v1.2.0
func NewHeapStringOperator ¶ added in v1.2.0
func NewHeapStringOperator() aggOperator
func NewHoltWintersReducer ¶ added in v1.0.0
func NewIncQueryFinishMessage ¶ added in v1.2.0
func NewIntegerSortEle ¶ added in v1.1.0
func NewIntegerSortEle() sortEleMsg
func NewInvalidTypeError ¶
func NewLastBooleanOperator ¶ added in v1.1.1
func NewLastBooleanOperator() aggOperator
func NewLastFloatOperator ¶ added in v1.1.1
func NewLastFloatOperator() aggOperator
func NewLastFunc ¶ added in v1.1.0
func NewLastFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewLastIntegerOperator ¶ added in v1.1.1
func NewLastIntegerOperator() aggOperator
func NewLastStringOperator ¶ added in v1.1.1
func NewLastStringOperator() aggOperator
func NewLocalStoreSqlPlanTypePool ¶ added in v1.2.0
func NewMaxBooleanOperator ¶ added in v1.2.0
func NewMaxBooleanOperator() aggOperator
func NewMaxFloatOperator ¶ added in v1.1.1
func NewMaxFloatOperator() aggOperator
func NewMaxFunc ¶ added in v1.1.0
func NewMaxFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewMaxIntegerOperator ¶ added in v1.1.1
func NewMaxIntegerOperator() aggOperator
func NewMaxPromFunc ¶ added in v1.3.0
func NewMaxPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewMaxPromOperator ¶ added in v1.3.0
func NewMaxPromOperator() aggOperator
func NewMedianReduce ¶ added in v1.3.0
func NewMinBooleanOperator ¶ added in v1.2.0
func NewMinBooleanOperator() aggOperator
func NewMinFloatOperator ¶ added in v1.1.1
func NewMinFloatOperator() aggOperator
func NewMinFunc ¶ added in v1.1.0
func NewMinFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewMinIntegerOperator ¶ added in v1.1.1
func NewMinIntegerOperator() aggOperator
func NewMinPromFunc ¶ added in v1.3.0
func NewMinPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewMinPromOperator ¶ added in v1.3.0
func NewMinPromOperator() aggOperator
func NewModeReduce ¶ added in v1.3.0
func NewOneShardStorePlanTypePool ¶ added in v1.1.0
func NewPercentileFloatOperator ¶ added in v1.1.1
func NewPercentileFloatOperator() aggOperator
func NewPercentileFunc ¶ added in v1.1.0
func NewPercentileFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewPercentileIntegerOperator ¶ added in v1.1.1
func NewPercentileIntegerOperator() aggOperator
func NewPlanBySchemaAndSrcPlan ¶ added in v1.1.0
func NewPreparedStatement ¶
func NewPrevValuesFunc ¶
func NewPrevValuesFunc(rowDataType hybridqp.RowDataType) []func(prev Chunk, prevValues []interface{}, ordinal int)
func NewPrevWindowFunc ¶
func NewProcessors ¶
func NewProcessors(inRowDataType, outRowDataType hybridqp.RowDataType, exprOpt []hybridqp.ExprOptions, opt *query.ProcessorOptions, isSubQuery bool) (*processorResults, error)
func NewPromFunc ¶ added in v1.3.0
func NewPromFunc(inRowDataType hybridqp.RowDataType, typ AggFuncType, op func() aggOperator, inOrdinal, outOrdinal int) (*aggFunc, error)
func NewRPCMessage ¶
func NewSortPartition ¶ added in v1.1.0
func NewSortRowMsg ¶ added in v1.1.0
func NewSortRowMsg(eles []sortEleMsg) *sortRowMsg
func NewSqlPlanTypePool ¶ added in v1.1.0
func NewStdPromOperator ¶ added in v1.4.0
func NewStdPromOperator(flag bool) aggOperator
func NewStddevPromFunc ¶ added in v1.4.0
func NewStddevPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewStdvarPromFunc ¶ added in v1.4.0
func NewStdvarPromFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewStorePlanTypePool ¶ added in v1.1.0
func NewStringSortEle ¶ added in v1.1.0
func NewStringSortEle() sortEleMsg
func NewSumFloatOperator ¶ added in v1.1.1
func NewSumFloatOperator() aggOperator
func NewSumFunc ¶ added in v1.1.0
func NewSumFunc(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (*aggFunc, error)
func NewSumIntegerOperator ¶ added in v1.1.1
func NewSumIntegerOperator() aggOperator
func NewfloatTuple ¶ added in v1.0.0
func NewfloatTuple(tuple []float64) *floatTuple
func PutIncAggChunk ¶ added in v1.2.0
func PutIncHashAggItem ¶ added in v1.2.0
func PutIncHashAggItem(queryID string, item *IncHashAggItem)
func RateFastReduce ¶ added in v1.3.0
func RateFinalReduce ¶ added in v1.3.0
func RateLowReduce ¶ added in v1.3.0
func RateMiddleReduce ¶ added in v1.3.0
func RateUpdate ¶ added in v1.3.0
func RateUpdate[T util.NumberOnly](prevPoints, currPoints [2]*Point[T])
func ReWriteArgs ¶ added in v1.1.0
func RebuildAggNodes ¶ added in v1.1.0
func RebuildColumnStorePlan ¶ added in v1.1.0
func RegistryAggOp ¶ added in v1.3.0
func RegistryAggOp(name string, aggOp AggOperator)
func RegistryLabelFunction ¶ added in v1.3.0
func RegistryLabelFunction(name string, labelFunc LabelFunction)
func RegistryPromTimeFunction ¶ added in v1.3.0
func RegistryPromTimeFunction(name string, timeFunc PromTimeFunction)
func RegistryReaderCreator ¶ added in v1.1.0
func RegistryReaderCreator(plan LogicalPlan, creator ReaderCreator) bool
func RegistryTransformCreator ¶
func RegistryTransformCreator(plan LogicalPlan, creator TransformCreator) bool
func RemoveCommonValues ¶ added in v1.3.0
func RemoveCommonValues(prev, curr [][]interface{}) [][]interface{}
func ReplaceSortAggMergeWithHashAgg ¶ added in v1.2.0
func ReplaceSortAggWithHashAgg ¶ added in v1.2.0
func ReplaceSortMergeWithHashMerge ¶ added in v1.2.0
func ResetTimeForProm ¶ added in v1.3.0
func Select ¶
func Select(ctx context.Context, stmt *influxql.SelectStatement, shardMapper query.ShardMapper, opt query.SelectOptions) (hybridqp.Executor, error)
Select compiles, prepares, and then initiates execution of the query using the default compile options.
func SetLocalStorageForQuery ¶ added in v1.2.0
func SetLocalStorageForQuery(storage hybridqp.StoreEngine)
func SetMaxGroupsNums ¶ added in v1.2.0
func SetMaxGroupsNums(numsOfGroups int)
func SetTimeZero ¶
func SetTimeZero(schema *QuerySchema) bool
func SlidingWindowMergeFunc ¶ added in v1.3.0
func SlidingWindowMergeFunc[T util.ExceptString](prevWindow, currWindow *SlidingWindow[T], fpm PointMerge[T])
func SortByTimeAsc ¶ added in v1.4.0
func SortByTimeAsc[T util.NumberOnly](f *HeapItem[T])
func SortByValueDsc ¶ added in v1.4.0
func SortByValueDsc[T util.NumberOnly](f *HeapItem[T])
func StrLenFunc ¶
func StringAuxHelpFunc ¶
func StringFirstMerge ¶
func StringFirstMerge(prevPoint, currPoint *StringPoint)
func StringLastMerge ¶
func StringLastMerge(prevPoint, currPoint *StringPoint)
func SubStrThreeParaFunc ¶
func SubStrTwoParaFunc ¶
func SumMerge ¶ added in v1.3.0
func SumMerge[T util.NumberOnly](prevPoint, currPoint *Point[T])
func TopCmpByTimeReduce ¶ added in v1.3.0
func TopCmpByTimeReduce[T util.NumberOnly](a, b *PointItem[T]) bool
func TopCmpByValueReduce ¶ added in v1.3.0
func TopCmpByValueReduce[T util.NumberOnly](a, b *PointItem[T]) bool
func TopCmpByValueReduceProm ¶ added in v1.4.0
func TopCmpByValueReduceProm[T util.NumberOnly](a, b *PointItem[T]) bool
func TransparentForwardBoolean ¶ added in v1.0.0
func TransparentForwardFloat ¶ added in v1.0.0
func TransparentForwardInteger ¶ added in v1.0.0
func TransparentForwardString ¶ added in v1.0.0
func TranverseBinTreeForTimestamp ¶ added in v1.3.0
func UnionBitMapArray ¶
func UnionColumns ¶
func UnmarshalBinary ¶ added in v1.0.0
func UnmarshalBinaryNode ¶ added in v1.0.0
func UnmarshalQueryNode ¶
func UpdateHashBooleanMaxFast ¶ added in v1.3.0
func UpdateHashBooleanMaxSlow ¶ added in v1.3.0
func UpdateHashBooleanMinFast ¶ added in v1.3.0
func UpdateHashBooleanMinSlow ¶ added in v1.3.0
func UpdateHashFloatMaxFast ¶ added in v1.3.0
func UpdateHashFloatMaxSlow ¶ added in v1.3.0
func UpdateHashFloatMinFast ¶ added in v1.3.0
func UpdateHashFloatMinSlow ¶ added in v1.3.0
func UpdateHashFloatSumFast ¶ added in v1.3.0
func UpdateHashFloatSumSlow ¶ added in v1.3.0
func UpdateHashInterMaxFast ¶ added in v1.3.0
func UpdateHashInterMaxSlow ¶ added in v1.3.0
func UpdateHashInterMinFast ¶ added in v1.3.0
func UpdateHashInterMinSlow ¶ added in v1.3.0
func UpdateHashInterSumFast ¶ added in v1.3.0
func UpdateHashInterSumSlow ¶ added in v1.3.0
func UpdateIncAggFunc ¶ added in v1.2.0
func UpdateIncHashAggFunc ¶ added in v1.2.0
func ValidRpcMessageType ¶ added in v1.1.0
func ValidateFieldsFromPlans ¶
func Walk ¶
func Walk(v LogicalPlanVisitor, plan hybridqp.QueryNode)
Types ¶
type AbortProcessor ¶ added in v1.3.0
type AbortProcessor interface {
AbortSinkTransform()
}
type AbsentIterator ¶ added in v1.4.0
type AbsentIterator struct {
// contains filtered or unexported fields
}
func NewAbsentIterator ¶ added in v1.4.0
func NewAbsentIterator(inOrdinal, outOrdinal int, opt *query.ProcessorOptions) *AbsentIterator
func (*AbsentIterator) Next ¶ added in v1.4.0
func (r *AbsentIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type AggCallFuncParams ¶ added in v1.3.0
type AggCallFuncParams struct {
InRowDataType, OutRowDataType hybridqp.RowDataType // dataType
ExprOpt hybridqp.ExprOptions // aggregate column information
IsSingleCall bool // is a single call flag, used for optimize performance
AuxProcessor []*AuxProcessor // eg: select first(v1),v2 from xxx,then v2 is aux
Opt *query.ProcessorOptions // ProcessorOptions is an object passed to CreateIterator to specify creation options.
ProRes *processorResults //processor response
IsSubQuery bool
Name string
}
type AggFactory ¶ added in v1.3.0
type AggFactory map[string]AggOperator
type AggFuncType ¶ added in v1.1.0
type AggFuncType uint32
type AggOperator ¶ added in v1.3.0
type AggOperator interface {
CreateRoutine(params *AggCallFuncParams) (Routine, error)
}
func GetAggOperator ¶ added in v1.3.0
func GetAggOperator(name string) AggOperator
type AggOperatorMsgs ¶ added in v1.1.0
type AggOperatorMsgs struct {
// contains filtered or unexported fields
}
func NewAggOperatorMsgs ¶ added in v1.1.0
func NewAggOperatorMsgs(size int) *AggOperatorMsgs
func (*AggOperatorMsgs) Alloc ¶ added in v1.1.0
func (a *AggOperatorMsgs) Alloc(size int) []*aggOperatorMsg
func (*AggOperatorMsgs) Free ¶ added in v1.1.0
func (a *AggOperatorMsgs) Free()
type AggPushDownToColumnStoreReaderRule ¶ added in v1.1.0
type AggPushDownToColumnStoreReaderRule struct {
OptRuleBase
}
func NewAggPushDownToColumnStoreReaderRule ¶ added in v1.1.0
func NewAggPushDownToColumnStoreReaderRule(description string) *AggPushDownToColumnStoreReaderRule
func (*AggPushDownToColumnStoreReaderRule) Catagory ¶ added in v1.1.0
func (r *AggPushDownToColumnStoreReaderRule) Catagory() OptRuleCatagory
func (*AggPushDownToColumnStoreReaderRule) Equals ¶ added in v1.1.0
func (r *AggPushDownToColumnStoreReaderRule) Equals(rhs OptRule) bool
func (*AggPushDownToColumnStoreReaderRule) OnMatch ¶ added in v1.1.0
func (r *AggPushDownToColumnStoreReaderRule) OnMatch(call *OptRuleCall)
func (*AggPushDownToColumnStoreReaderRule) ToString ¶ added in v1.1.0
func (r *AggPushDownToColumnStoreReaderRule) ToString() string
type AggPushDownToSubQueryRule ¶
type AggPushDownToSubQueryRule struct {
OptRuleBase
}
func NewAggPushDownToSubQueryRule ¶
func NewAggPushDownToSubQueryRule(description string) *AggPushDownToSubQueryRule
func (*AggPushDownToSubQueryRule) Catagory ¶
func (r *AggPushDownToSubQueryRule) Catagory() OptRuleCatagory
func (*AggPushDownToSubQueryRule) Equals ¶
func (r *AggPushDownToSubQueryRule) Equals(rhs OptRule) bool
func (*AggPushDownToSubQueryRule) OnMatch ¶
func (r *AggPushDownToSubQueryRule) OnMatch(call *OptRuleCall)
func (*AggPushDownToSubQueryRule) ToString ¶
func (r *AggPushDownToSubQueryRule) ToString() string
type AggPushdownToExchangeRule ¶
type AggPushdownToExchangeRule struct {
OptRuleBase
}
func NewAggPushdownToExchangeRule ¶
func NewAggPushdownToExchangeRule(description string) *AggPushdownToExchangeRule
func (*AggPushdownToExchangeRule) Catagory ¶
func (r *AggPushdownToExchangeRule) Catagory() OptRuleCatagory
func (*AggPushdownToExchangeRule) Equals ¶
func (r *AggPushdownToExchangeRule) Equals(rhs OptRule) bool
func (*AggPushdownToExchangeRule) OnMatch ¶
func (r *AggPushdownToExchangeRule) OnMatch(call *OptRuleCall)
func (*AggPushdownToExchangeRule) ToString ¶
func (r *AggPushdownToExchangeRule) ToString() string
type AggPushdownToReaderRule ¶
type AggPushdownToReaderRule struct {
OptRuleBase
}
func NewAggPushdownToReaderRule ¶
func NewAggPushdownToReaderRule(description string) *AggPushdownToReaderRule
func (*AggPushdownToReaderRule) Catagory ¶
func (r *AggPushdownToReaderRule) Catagory() OptRuleCatagory
func (*AggPushdownToReaderRule) Equals ¶
func (r *AggPushdownToReaderRule) Equals(rhs OptRule) bool
func (*AggPushdownToReaderRule) OnMatch ¶
func (r *AggPushdownToReaderRule) OnMatch(call *OptRuleCall)
func (*AggPushdownToReaderRule) ToString ¶
func (r *AggPushdownToReaderRule) ToString() string
type AggPushdownToSeriesRule ¶
type AggPushdownToSeriesRule struct {
OptRuleBase
}
func NewAggPushdownToSeriesRule ¶
func NewAggPushdownToSeriesRule(description string) *AggPushdownToSeriesRule
func (*AggPushdownToSeriesRule) Catagory ¶
func (r *AggPushdownToSeriesRule) Catagory() OptRuleCatagory
func (*AggPushdownToSeriesRule) Equals ¶
func (r *AggPushdownToSeriesRule) Equals(rhs OptRule) bool
func (*AggPushdownToSeriesRule) OnMatch ¶
func (r *AggPushdownToSeriesRule) OnMatch(call *OptRuleCall)
func (*AggPushdownToSeriesRule) ToString ¶
func (r *AggPushdownToSeriesRule) ToString() string
type AggSpreadToExchangeRule ¶
type AggSpreadToExchangeRule struct {
OptRuleBase
}
func NewAggSpreadToExchangeRule ¶
func NewAggSpreadToExchangeRule(description string) *AggSpreadToExchangeRule
func (*AggSpreadToExchangeRule) Catagory ¶
func (r *AggSpreadToExchangeRule) Catagory() OptRuleCatagory
func (*AggSpreadToExchangeRule) Equals ¶
func (r *AggSpreadToExchangeRule) Equals(rhs OptRule) bool
func (*AggSpreadToExchangeRule) OnMatch ¶
func (r *AggSpreadToExchangeRule) OnMatch(call *OptRuleCall)
func (*AggSpreadToExchangeRule) ToString ¶
func (r *AggSpreadToExchangeRule) ToString() string
type AggSpreadToReaderRule ¶
type AggSpreadToReaderRule struct {
OptRuleBase
}
func NewAggSpreadToReaderRule ¶
func NewAggSpreadToReaderRule(description string) *AggSpreadToReaderRule
func (*AggSpreadToReaderRule) Catagory ¶
func (r *AggSpreadToReaderRule) Catagory() OptRuleCatagory
func (*AggSpreadToReaderRule) Equals ¶
func (r *AggSpreadToReaderRule) Equals(rhs OptRule) bool
func (*AggSpreadToReaderRule) OnMatch ¶
func (r *AggSpreadToReaderRule) OnMatch(call *OptRuleCall)
func (*AggSpreadToReaderRule) ToString ¶
func (r *AggSpreadToReaderRule) ToString() string
type AggSpreadToSortAppendRule ¶
type AggSpreadToSortAppendRule struct {
OptRuleBase
}
func NewAggSpreadToSortAppendRule ¶
func NewAggSpreadToSortAppendRule(description string) *AggSpreadToSortAppendRule
func (*AggSpreadToSortAppendRule) Catagory ¶
func (r *AggSpreadToSortAppendRule) Catagory() OptRuleCatagory
func (*AggSpreadToSortAppendRule) Equals ¶
func (r *AggSpreadToSortAppendRule) Equals(rhs OptRule) bool
func (*AggSpreadToSortAppendRule) OnMatch ¶
func (r *AggSpreadToSortAppendRule) OnMatch(call *OptRuleCall)
func (*AggSpreadToSortAppendRule) ToString ¶
func (r *AggSpreadToSortAppendRule) ToString() string
type AggToProjectInSubQueryRule ¶
type AggToProjectInSubQueryRule struct {
OptRuleBase
}
func NewAggToProjectInSubQueryRule ¶
func NewAggToProjectInSubQueryRule(description string) *AggToProjectInSubQueryRule
func (*AggToProjectInSubQueryRule) Catagory ¶
func (r *AggToProjectInSubQueryRule) Catagory() OptRuleCatagory
func (*AggToProjectInSubQueryRule) Equals ¶
func (r *AggToProjectInSubQueryRule) Equals(rhs OptRule) bool
func (*AggToProjectInSubQueryRule) OnMatch ¶
func (r *AggToProjectInSubQueryRule) OnMatch(call *OptRuleCall)
func (*AggToProjectInSubQueryRule) ToString ¶
func (r *AggToProjectInSubQueryRule) ToString() string
type AlignTransform ¶
type AlignTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
// contains filtered or unexported fields
}
func NewAlignTransform ¶
func NewAlignTransform(inRowDataType []hybridqp.RowDataType, outRowDataType []hybridqp.RowDataType, opt *query.ProcessorOptions) *AlignTransform
func (*AlignTransform) Close ¶
func (trans *AlignTransform) Close()
func (*AlignTransform) Explain ¶
func (trans *AlignTransform) Explain() []ValuePair
func (*AlignTransform) GetInputNumber ¶
func (trans *AlignTransform) GetInputNumber(port Port) int
func (*AlignTransform) GetInputs ¶
func (trans *AlignTransform) GetInputs() Ports
func (*AlignTransform) GetOutputNumber ¶
func (trans *AlignTransform) GetOutputNumber(port Port) int
func (*AlignTransform) GetOutputs ¶
func (trans *AlignTransform) GetOutputs() Ports
func (*AlignTransform) Name ¶
func (trans *AlignTransform) Name() string
func (*AlignTransform) SendChunk ¶
func (trans *AlignTransform) SendChunk()
type AlignTransformCreator ¶
type AlignTransformCreator struct{}
func (*AlignTransformCreator) Create ¶
func (c *AlignTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type AnalyzeResponse ¶
type AnalyzeResponse struct {
// contains filtered or unexported fields
}
func (AnalyzeResponse) Instance ¶
func (a AnalyzeResponse) Instance() transport.Codec
func (*AnalyzeResponse) Size ¶
func (a *AnalyzeResponse) Size() int
func (*AnalyzeResponse) Unmarshal ¶
func (a *AnalyzeResponse) Unmarshal(buf []byte) error
type AppendHeapItems ¶
type AppendHeapItems struct {
Items []*Item
// contains filtered or unexported fields
}
func (*AppendHeapItems) GetBreakPoint ¶ added in v1.0.0
func (h *AppendHeapItems) GetBreakPoint() BaseBreakPoint
func (*AppendHeapItems) GetOption ¶ added in v1.0.0
func (h *AppendHeapItems) GetOption() *query.ProcessorOptions
func (*AppendHeapItems) Len ¶
func (h *AppendHeapItems) Len() int
func (*AppendHeapItems) Less ¶
func (h *AppendHeapItems) Less(i, j int) bool
func (*AppendHeapItems) Pop ¶
func (h *AppendHeapItems) Pop() interface{}
func (*AppendHeapItems) Push ¶
func (h *AppendHeapItems) Push(x interface{})
func (*AppendHeapItems) Swap ¶
func (h *AppendHeapItems) Swap(i, j int)
type AttachedFrags ¶ added in v1.2.0
type AttachedFrags struct {
BaseFrags
// contains filtered or unexported fields
}
func NewAttachedFrags ¶ added in v1.2.0
func NewAttachedFrags(basePath string, cap int) *AttachedFrags
func (*AttachedFrags) AppendIndexes ¶ added in v1.2.0
func (s *AttachedFrags) AppendIndexes(tsspFiles ...interface{})
func (*AttachedFrags) IndexCount ¶ added in v1.2.0
func (s *AttachedFrags) IndexCount() int
func (*AttachedFrags) Indexes ¶ added in v1.2.0
func (s *AttachedFrags) Indexes() interface{}
type AttachedIndexInfo ¶ added in v1.2.0
type AttachedIndexInfo struct {
// contains filtered or unexported fields
}
func NewAttachedIndexInfo ¶ added in v1.2.0
func NewAttachedIndexInfo(files []immutable.TSSPFile, infos []*colstore.PKInfo) *AttachedIndexInfo
func (*AttachedIndexInfo) Files ¶ added in v1.2.0
func (a *AttachedIndexInfo) Files() []immutable.TSSPFile
func (*AttachedIndexInfo) Infos ¶ added in v1.2.0
func (a *AttachedIndexInfo) Infos() []*colstore.PKInfo
type AuxProcessor ¶
type AuxProcessor struct {
// contains filtered or unexported fields
}
func NewAuxCoProcessor ¶
func NewAuxCoProcessor(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) *AuxProcessor
type BaseBreakPoint ¶ added in v1.0.0
type BaseBreakPoint interface {
}
type BaseFrags ¶ added in v1.2.0
type BaseFrags struct {
// contains filtered or unexported fields
}
func NewBaseFrags ¶ added in v1.2.0
func (*BaseFrags) AddFragCount ¶ added in v1.2.0
func (*BaseFrags) AppendFragRanges ¶ added in v1.2.0
func (s *BaseFrags) AppendFragRanges(frs ...fragment.FragmentRanges)
func (*BaseFrags) FragRanges ¶ added in v1.2.0
func (s *BaseFrags) FragRanges() []fragment.FragmentRanges
type BaseHeapItems ¶ added in v1.0.0
type BaseHeapItems interface {
Len() int
Less(i, j int) bool
Swap(i, j int)
Push(x interface{})
Pop() interface{}
GetBreakPoint() BaseBreakPoint
GetOption() *query.ProcessorOptions
}
type BaseMergeIterator ¶ added in v1.1.0
type BaseMergeIterator struct {
// contains filtered or unexported fields
}
type BaseProcessor ¶
type BaseProcessor struct {
// contains filtered or unexported fields
}
func (*BaseProcessor) Abort ¶ added in v1.0.1
func (bp *BaseProcessor) Abort()
func (*BaseProcessor) Analyze ¶
func (bp *BaseProcessor) Analyze(span *tracing.Span)
func (*BaseProcessor) BaseSpan ¶
func (bp *BaseProcessor) BaseSpan() *tracing.Span
func (*BaseProcessor) FinishSpan ¶
func (bp *BaseProcessor) FinishSpan()
func (*BaseProcessor) Interrupt ¶ added in v1.3.0
func (bp *BaseProcessor) Interrupt()
func (*BaseProcessor) InterruptWithoutMark ¶ added in v1.4.0
func (bp *BaseProcessor) InterruptWithoutMark()
func (*BaseProcessor) IsSink ¶
func (bp *BaseProcessor) IsSink() bool
func (*BaseProcessor) Once ¶
func (bp *BaseProcessor) Once(fn func())
func (*BaseProcessor) Release ¶
func (bp *BaseProcessor) Release() error
type BasePromOp ¶ added in v1.3.0
type BasePromOp struct {
// contains filtered or unexported fields
}
func NewBasePromOp ¶ added in v1.3.0
func NewBasePromOp(op string, fn ColReduceFunc[float64], fv ColMergeFunc[float64]) BasePromOp
func (*BasePromOp) CreateRoutine ¶ added in v1.3.0
func (c *BasePromOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type BaseTransData ¶
type BaseTransData struct {
// contains filtered or unexported fields
}
type BatchMPool ¶ added in v1.1.0
type BatchMPool struct {
// contains filtered or unexported fields
}
func NewBatchMPool ¶ added in v1.1.0
func NewBatchMPool(size int) *BatchMPool
func (*BatchMPool) AllocBatchEndLocs ¶ added in v1.1.0
func (b *BatchMPool) AllocBatchEndLocs() []int
func (*BatchMPool) FreeBatchEndLocs ¶ added in v1.1.0
func (b *BatchMPool) FreeBatchEndLocs(batchEndLocs []int)
type BinOpTransform ¶ added in v1.3.0
type BinOpTransform struct {
BaseProcessor
OpType int
On bool // true: on; false: ignore
MatchKeysForMatchCompute []string // on(MatchKeys)/ ignore(MatchKeys)
MatchKeys []string
IncludeKeys []string // group_left/group_right(IncludeKeys)
ReturnBool bool
NilMst influxql.NilMstState
BinOpHelper func(ctx context.Context, errs *errno.Errs)
// contains filtered or unexported fields
}
func NewBinOpTransform ¶ added in v1.3.0
func NewBinOpTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, schema *QuerySchema, para *influxql.BinOp, lExpr, rExpr influxql.Expr) (*BinOpTransform, error)
func (*BinOpTransform) AddResult ¶ added in v1.3.0
func (trans *BinOpTransform) AddResult(secondaryChunk Chunk) error
func (*BinOpTransform) AddResultSimple ¶ added in v1.3.0
func (trans *BinOpTransform) AddResultSimple(secondaryChunk Chunk)
1.no compute resultTags; 2.no computeMatchResult by both side input; 3.no resultMap dup err check
func (*BinOpTransform) BinOpHelperConditionBoth ¶ added in v1.3.0
func (trans *BinOpTransform) BinOpHelperConditionBoth(ctx context.Context, errs *errno.Errs)
func (*BinOpTransform) BinOpHelperConditionSingle ¶ added in v1.3.0
func (trans *BinOpTransform) BinOpHelperConditionSingle(ctx context.Context, errs *errno.Errs)
func (*BinOpTransform) BinOpHelperConditionSingleExpr ¶ added in v1.4.0
func (trans *BinOpTransform) BinOpHelperConditionSingleExpr(ctx context.Context, errs *errno.Errs)
func (*BinOpTransform) BinOpHelperOperator ¶ added in v1.3.0
func (trans *BinOpTransform) BinOpHelperOperator(ctx context.Context, errs *errno.Errs)
func (*BinOpTransform) Close ¶ added in v1.3.0
func (trans *BinOpTransform) Close()
func (*BinOpTransform) ComputeResultTags ¶ added in v1.3.0
func (trans *BinOpTransform) ComputeResultTags(pTagKeys, pTagValues, sTagKeys, sTagValues []string) ([]string, []string, string)
func (*BinOpTransform) Explain ¶ added in v1.3.0
func (trans *BinOpTransform) Explain() []ValuePair
func (*BinOpTransform) GetInputNumber ¶ added in v1.3.0
func (trans *BinOpTransform) GetInputNumber(_ Port) int
func (*BinOpTransform) GetInputs ¶ added in v1.3.0
func (trans *BinOpTransform) GetInputs() Ports
func (*BinOpTransform) GetOutputNumber ¶ added in v1.3.0
func (trans *BinOpTransform) GetOutputNumber(_ Port) int
func (*BinOpTransform) GetOutputs ¶ added in v1.3.0
func (trans *BinOpTransform) GetOutputs() Ports
func (*BinOpTransform) Name ¶ added in v1.3.0
func (trans *BinOpTransform) Name() string
func (*BinOpTransform) SendChunk ¶ added in v1.3.0
func (trans *BinOpTransform) SendChunk()
type BinOpTransformCreator ¶ added in v1.3.0
type BinOpTransformCreator struct {
}
func (*BinOpTransformCreator) Create ¶ added in v1.3.0
func (c *BinOpTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type Bitmap ¶
type Bitmap struct {
// contains filtered or unexported fields
}
Bitmap for column
func (*Bitmap) SetNilCount ¶
func (*Bitmap) UpdateBitWithArray ¶
type BlockChunkPool ¶ added in v1.0.0
type BlockChunkPool struct {
// contains filtered or unexported fields
}
BlockChunkPool fixed-capacity memory pool that blocks when the pool is empty or full.
func NewBlockChunkPool ¶ added in v1.0.0
func NewBlockChunkPool(chunkNum int, chunkBuilder *ChunkBuilder) *BlockChunkPool
func (*BlockChunkPool) Get ¶ added in v1.0.0
func (cp *BlockChunkPool) Get() Chunk
func (*BlockChunkPool) Put ¶ added in v1.0.0
func (cp *BlockChunkPool) Put(c Chunk)
func (*BlockChunkPool) Release ¶ added in v1.0.0
func (cp *BlockChunkPool) Release()
type BooleanAlignIterator ¶
type BooleanAlignIterator struct{}
func NewBooleanAlignIterator ¶
func NewBooleanAlignIterator() *BooleanAlignIterator
func (*BooleanAlignIterator) Next ¶
func (f *BooleanAlignIterator) Next(endpoint *IteratorEndpoint, _ *IteratorParams)
type BooleanAppendIterator ¶
type BooleanAppendIterator struct {
// contains filtered or unexported fields
}
func NewBooleanAppendIterator ¶
func NewBooleanAppendIterator() *BooleanAppendIterator
func (*BooleanAppendIterator) Next ¶
func (f *BooleanAppendIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type BooleanColBooleanDistinctIterator ¶
type BooleanColBooleanDistinctIterator struct {
// contains filtered or unexported fields
}
func NewBooleanColBooleanDistinctIterator ¶
func NewBooleanColBooleanDistinctIterator( inOrdinal, outOrdinal int, ) *BooleanColBooleanDistinctIterator
func (*BooleanColBooleanDistinctIterator) Next ¶
func (r *BooleanColBooleanDistinctIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type BooleanColBooleanSampleIterator ¶
type BooleanColBooleanSampleIterator struct {
// contains filtered or unexported fields
}
func NewBooleanColBooleanSampleIterator ¶
func NewBooleanColBooleanSampleIterator(sampleNum int, isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *BooleanColBooleanSampleIterator
func (*BooleanColBooleanSampleIterator) Next ¶
func (r *BooleanColBooleanSampleIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type BooleanColBooleanSliceIterator ¶
type BooleanColBooleanSliceIterator struct {
// contains filtered or unexported fields
}
func NewBooleanColBooleanSliceIterator ¶
func NewBooleanColBooleanSliceIterator(fn BooleanColReduceSliceReduce, isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *BooleanColBooleanSliceIterator
func (*BooleanColBooleanSliceIterator) Next ¶
func (r *BooleanColBooleanSliceIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type BooleanColReduceSliceReduce ¶
type BooleanColReduceSliceReduce func(booleanItem *BooleanSliceItem) (index int, time int64, value float64, isNil bool)
type BooleanDistinctItem ¶
type BooleanDistinctItem struct {
// contains filtered or unexported fields
}
func NewBooleanDistinctItem ¶
func NewBooleanDistinctItem() *BooleanDistinctItem
func (*BooleanDistinctItem) Len ¶
func (f *BooleanDistinctItem) Len() int
func (*BooleanDistinctItem) Less ¶
func (f *BooleanDistinctItem) Less(i, j int) bool
func (*BooleanDistinctItem) Nil ¶
func (f *BooleanDistinctItem) Nil() bool
func (*BooleanDistinctItem) Reset ¶
func (f *BooleanDistinctItem) Reset()
func (*BooleanDistinctItem) Swap ¶
func (f *BooleanDistinctItem) Swap(i, j int)
type BooleanFieldValuer ¶ added in v1.0.0
type BooleanFieldValuer struct {
// contains filtered or unexported fields
}
type BooleanIntervalIterator ¶
type BooleanIntervalIterator struct{}
func NewBooleanIntervalIterator ¶
func NewBooleanIntervalIterator() *BooleanIntervalIterator
func (*BooleanIntervalIterator) Next ¶
func (f *BooleanIntervalIterator) Next(endpoint *IteratorEndpoint, _ *IteratorParams)
type BooleanIterator ¶ added in v1.3.0
type BooleanIterator struct {
// contains filtered or unexported fields
}
func NewBooleanIterator ¶ added in v1.3.0
func NewBooleanIterator(fn BooleanReduce, fv PointMerge[bool], isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *BooleanIterator
func (*BooleanIterator) Next ¶ added in v1.3.0
func (r *BooleanIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type BooleanLimitIterator ¶
type BooleanLimitIterator struct {
// contains filtered or unexported fields
}
func NewBooleanLimitIterator ¶
func NewBooleanLimitIterator() *BooleanLimitIterator
func (*BooleanLimitIterator) Next ¶
func (f *BooleanLimitIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type BooleanLinearFillProcessor ¶
type BooleanLinearFillProcessor struct {
// contains filtered or unexported fields
}
func NewBooleanLinearFillProcessor ¶
func NewBooleanLinearFillProcessor(inOrdinal, outOrdinal int) *BooleanLinearFillProcessor
type BooleanMergeIterator ¶
type BooleanMergeIterator struct {
BaseMergeIterator
// contains filtered or unexported fields
}
func NewBooleanMergeIterator ¶
func NewBooleanMergeIterator() *BooleanMergeIterator
func (*BooleanMergeIterator) Next ¶
func (f *BooleanMergeIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type BooleanNullFillProcessor ¶
type BooleanNullFillProcessor struct {
// contains filtered or unexported fields
}
func NewBooleanNullFillProcessor ¶
func NewBooleanNullFillProcessor(inOrdinal, outOrdinal int) *BooleanNullFillProcessor
type BooleanNumberFillProcessor ¶
type BooleanNumberFillProcessor struct {
// contains filtered or unexported fields
}
func NewBooleanNumberFillProcessor ¶
func NewBooleanNumberFillProcessor(inOrdinal, outOrdinal int) *BooleanNumberFillProcessor
type BooleanPreviousFillProcessor ¶
type BooleanPreviousFillProcessor struct {
// contains filtered or unexported fields
}
func NewBooleanPreviousFillProcessor ¶
func NewBooleanPreviousFillProcessor(inOrdinal, outOrdinal int) *BooleanPreviousFillProcessor
type BooleanReduce ¶ added in v1.3.0
type BooleanSliceItem ¶
type BooleanSliceItem struct {
// contains filtered or unexported fields
}
func NewBooleanSliceItem ¶
func NewBooleanSliceItem() *BooleanSliceItem
func (*BooleanSliceItem) AppendItem ¶
func (f *BooleanSliceItem) AppendItem(c Chunk, ordinal, start, end int)
func (*BooleanSliceItem) Len ¶
func (f *BooleanSliceItem) Len() int
func (*BooleanSliceItem) Reset ¶
func (f *BooleanSliceItem) Reset()
type BooleanTimeColBooleanIterator ¶
type BooleanTimeColBooleanIterator struct {
// contains filtered or unexported fields
}
func NewBooleanTimeColBooleanIterator ¶
func NewBooleanTimeColBooleanIterator( fn BooleanTimeColBooleanReduce, fv BooleanTimeColBooleanMerge, inOrdinal, outOrdinal int, ) *BooleanTimeColBooleanIterator
func (*BooleanTimeColBooleanIterator) Next ¶
func (r *BooleanTimeColBooleanIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type BreakPoint ¶
BreakPoint is the point we peek from the 2nd. less chunk, if the value is bigger than the BreakPoint, which means we Need to change the chunk.
type CONTEXT_IDENTIFIER ¶ added in v1.0.0
type CONTEXT_IDENTIFIER int
const (
WRITER_CONTEXT CONTEXT_IDENTIFIER = 0x01
)
type CSIndexInfo ¶ added in v1.2.0
type CSIndexInfo struct {
AttachedIndexInfo
// contains filtered or unexported fields
}
func NewCSIndexInfo ¶ added in v1.2.0
func NewCSIndexInfo(shardPath string, info *AttachedIndexInfo, version uint32) *CSIndexInfo
func (*CSIndexInfo) ShardPath ¶ added in v1.2.0
func (cs *CSIndexInfo) ShardPath() string
func (*CSIndexInfo) Version ¶ added in v1.2.0
func (cs *CSIndexInfo) Version() uint32
type CancelOnlySource ¶
type CancelOnlySource struct {
BaseProcessor
Output *ChunkPort
}
func NewCancelOnlySource ¶
func NewCancelOnlySource(rowDataType hybridqp.RowDataType) *CancelOnlySource
func (*CancelOnlySource) Close ¶
func (source *CancelOnlySource) Close()
func (*CancelOnlySource) Explain ¶
func (source *CancelOnlySource) Explain() []ValuePair
func (*CancelOnlySource) GetInputNumber ¶
func (source *CancelOnlySource) GetInputNumber(_ Port) int
func (*CancelOnlySource) GetInputs ¶
func (source *CancelOnlySource) GetInputs() Ports
func (*CancelOnlySource) GetOutputNumber ¶
func (source *CancelOnlySource) GetOutputNumber(_ Port) int
func (*CancelOnlySource) GetOutputs ¶
func (source *CancelOnlySource) GetOutputs() Ports
func (*CancelOnlySource) Name ¶
func (source *CancelOnlySource) Name() string
type CastorAggCutRule ¶ added in v0.2.0
type CastorAggCutRule struct {
OptRuleBase
}
func NewCastorAggCutRule ¶ added in v0.2.0
func NewCastorAggCutRule(description string) *CastorAggCutRule
func (*CastorAggCutRule) Catagory ¶ added in v0.2.0
func (r *CastorAggCutRule) Catagory() OptRuleCatagory
func (*CastorAggCutRule) Equals ¶ added in v0.2.0
func (r *CastorAggCutRule) Equals(rhs OptRule) bool
func (*CastorAggCutRule) OnMatch ¶ added in v0.2.0
func (r *CastorAggCutRule) OnMatch(call *OptRuleCall)
func (*CastorAggCutRule) ToString ¶ added in v0.2.0
func (r *CastorAggCutRule) ToString() string
type Chunk ¶
type Chunk interface {
RowDataType() hybridqp.RowDataType
SetRowDataType(hybridqp.RowDataType)
Name() string
SetName(string)
Tags() []ChunkTags
TagIndex() []int
TagLen() int
AppendTagsAndIndex(ChunkTags, int)
AppendTagsAndIndexes([]ChunkTags, []int)
InitTimeWindow(minTime, maxTime, intervalTime int64, hasInterval, ascending bool, tag ChunkTags)
Time() []int64
TruncateTime(int)
SetTime(time []int64)
ResetTime(int, int64)
AppendTime(int64)
AppendTimes([]int64)
TimeByIndex(int) int64
IntervalIndex() []int
AppendIntervalIndexes([]int)
AppendIntervalIndex(int)
ResetIntervalIndex(...int)
Columns() []Column
Column(int) Column
Dims() []Column
AddDims([]string)
NewDims(size int)
SetColumn(Column, int)
AddColumn(...Column)
Dim(int) Column
SetDim(Column, int)
AddDim(...Column)
IsNil() bool
NumberOfRows() int
NumberOfCols() int
Release()
Len() int
Reset()
SlimChunk(ridIdx []int) Chunk
IntervalLen() int
AddTagAndIndex(tag ChunkTags, i int)
ResetTagsAndIndexes(tags []ChunkTags, tagIndex []int)
AddIntervalIndex(i int)
Clone() Chunk
CopyTo(Chunk)
// CheckChunk TODO: CheckChunk used to check the chunk's structure
CheckChunk()
GetRecord() *record.Record
String() string
Marshal([]byte) ([]byte, error)
Unmarshal([]byte) error
Instance() transport.Codec
Size() int
CreatePointRowIterator(string, *FieldsValuer) PointRowIterator
CopyByRowDataType(c Chunk, fromRt hybridqp.RowDataType, dstRt hybridqp.RowDataType) error
PromStepInvariant(typ PromStepInvariantType, preGroup []byte, nextGroup []byte, step, startT, endT int64, dst Chunk) Chunk
}
type ChunkBuilder ¶
type ChunkBuilder struct {
// contains filtered or unexported fields
}
func NewChunkBuilder ¶
func NewChunkBuilder(rowDataType hybridqp.RowDataType) *ChunkBuilder
func (*ChunkBuilder) NewChunk ¶
func (b *ChunkBuilder) NewChunk(name string) Chunk
func (*ChunkBuilder) SetDim ¶ added in v1.1.0
func (b *ChunkBuilder) SetDim(dimDataType hybridqp.RowDataType)
type ChunkImpl ¶
ChunkImpl DO NOT ADD ADDITIONAL FIELDS TO THIS STRUCT.
func NewChunkImpl ¶
func NewChunkImpl(rowDataType hybridqp.RowDataType, name string) *ChunkImpl
NewChunkImpl FIXME: memory pool
func (*ChunkImpl) AddIntervalIndex ¶
func (*ChunkImpl) AddTagAndIndex ¶
func (*ChunkImpl) AppendIntervalFullRows ¶ added in v1.2.0
func (*ChunkImpl) AppendIntervalIndex ¶
func (*ChunkImpl) AppendIntervalIndexes ¶ added in v1.1.0
func (*ChunkImpl) AppendTagsAndIndex ¶
func (*ChunkImpl) AppendTagsAndIndexes ¶
func (*ChunkImpl) AppendTime ¶
func (*ChunkImpl) AppendTimes ¶ added in v1.1.0
func (*ChunkImpl) CheckChunk ¶
func (c *ChunkImpl) CheckChunk()
func (*ChunkImpl) CopyByRowDataType ¶ added in v1.1.0
func (c *ChunkImpl) CopyByRowDataType(dst Chunk, fromRt hybridqp.RowDataType, dstRt hybridqp.RowDataType) error
func (*ChunkImpl) CreatePointRowIterator ¶ added in v1.0.0
func (c *ChunkImpl) CreatePointRowIterator(name string, valuer *FieldsValuer) PointRowIterator
func (*ChunkImpl) InitTimeWindow ¶ added in v1.2.0
func (*ChunkImpl) IntervalIndex ¶
func (*ChunkImpl) IntervalLen ¶
func (*ChunkImpl) NumberOfCols ¶
func (*ChunkImpl) NumberOfRows ¶
func (*ChunkImpl) PromStepInvariant ¶ added in v1.4.0
func (*ChunkImpl) PromStepInvariantOnlyLastGroup ¶ added in v1.4.0
func (*ChunkImpl) PromStepInvariantSkipLastGroup ¶ added in v1.4.0
func (*ChunkImpl) ResetIntervalIndex ¶
func (*ChunkImpl) ResetTagsAndIndexes ¶
func (*ChunkImpl) RowDataType ¶
func (c *ChunkImpl) RowDataType() hybridqp.RowDataType
func (*ChunkImpl) SetRowDataType ¶
func (c *ChunkImpl) SetRowDataType(r hybridqp.RowDataType)
func (*ChunkImpl) TimeByIndex ¶
func (*ChunkImpl) TruncateTime ¶
type ChunkIterator ¶ added in v1.0.0
type ChunkIterator struct {
// contains filtered or unexported fields
}
func NewChunkIteratorFromValuer ¶ added in v1.0.0
func NewChunkIteratorFromValuer(chunk *ChunkImpl, name string, valuer *FieldsValuer) *ChunkIterator
func (*ChunkIterator) GetNext ¶ added in v1.0.0
func (iter *ChunkIterator) GetNext(row *influx.Row, tuple *TargetTuple)
func (*ChunkIterator) HasMore ¶ added in v1.0.0
func (iter *ChunkIterator) HasMore() bool
type ChunkPort ¶
type ChunkPort struct {
RowDataType hybridqp.RowDataType
State chan Chunk
OrigiState chan Chunk
Redirected bool
// contains filtered or unexported fields
}
func NewChunkPort ¶
func NewChunkPort(rowDataType hybridqp.RowDataType) *ChunkPort
func (*ChunkPort) ConnectNoneCache ¶ added in v1.0.0
func (*ChunkPort) ConnectionId ¶
type ChunkPorts ¶
type ChunkPorts []*ChunkPort
func (ChunkPorts) Close ¶
func (ps ChunkPorts) Close()
type ChunkTags ¶
type ChunkTags struct {
// contains filtered or unexported fields
}
func NewChunkTagsByBytes ¶ added in v1.3.0
func NewChunkTagsByTagKVs ¶ added in v1.0.0
func NewChunkTagsDeepCopy ¶ added in v1.3.0
func NewChunkTagsV2 ¶
func NewChunkTagsWithoutDims ¶ added in v1.3.0
func (*ChunkTags) DecodeTagsWithoutTag ¶ added in v1.3.0
func (*ChunkTags) GetChunkTagAndValues ¶
func (*ChunkTags) GetChunkTagValue ¶
func (*ChunkTags) GetOffsets ¶ added in v1.0.0
func (*ChunkTags) RemoveKeys ¶ added in v1.3.0
type ChunkValuer ¶
type ChunkValuer struct {
// contains filtered or unexported fields
}
ChunkValuer is a valuer that substitutes values for the mapped interface.
func NewChunkValuer ¶
func NewChunkValuer(isPromQuery bool) *ChunkValuer
func (*ChunkValuer) AtChunkRow ¶
func (c *ChunkValuer) AtChunkRow(chunk Chunk, index int)
func (*ChunkValuer) SetValueFnOnlyPromTime ¶ added in v1.4.0
func (c *ChunkValuer) SetValueFnOnlyPromTime()
func (*ChunkValuer) Value ¶
func (c *ChunkValuer) Value(key string) (interface{}, bool)
Value returns the value for a key in the MapValuer.
func (*ChunkValuer) ValueNormal ¶ added in v1.3.0
func (c *ChunkValuer) ValueNormal(key string) (interface{}, bool)
func (*ChunkValuer) ValueProm ¶ added in v1.3.0
func (c *ChunkValuer) ValueProm(key string) (interface{}, bool)
func (*ChunkValuer) ValuePromTime ¶ added in v1.4.0
func (c *ChunkValuer) ValuePromTime(key string) (interface{}, bool)
type ChunkWriter ¶
type ChunkWriter interface {
Write(Chunk)
Close()
}
type CircularChunkPool ¶
type CircularChunkPool struct {
// contains filtered or unexported fields
}
func NewCircularChunkPool ¶
func NewCircularChunkPool(chunkNum int, chunkBuilder *ChunkBuilder) *CircularChunkPool
func (*CircularChunkPool) GetChunk ¶
func (cp *CircularChunkPool) GetChunk() Chunk
func (*CircularChunkPool) Release ¶
func (cp *CircularChunkPool) Release()
type Cluster ¶ added in v1.0.0
func NewCluster ¶ added in v1.0.0
func NewCluster() *Cluster
type ClusterPool ¶ added in v1.0.0
type ClusterPool struct {
// contains filtered or unexported fields
}
func NewClusterPool ¶ added in v1.0.0
func NewClusterPool() *ClusterPool
func (*ClusterPool) Get ¶ added in v1.0.0
func (p *ClusterPool) Get() *Cluster
func (*ClusterPool) Put ¶ added in v1.0.0
func (p *ClusterPool) Put(cluster *Cluster)
type ClusterSet ¶ added in v1.0.0
type ClusterSet []Cluster
func (ClusterSet) Len ¶ added in v1.0.0
func (l ClusterSet) Len() int
func (ClusterSet) Less ¶ added in v1.0.0
func (l ClusterSet) Less(i, j int) bool
func (ClusterSet) Swap ¶ added in v1.0.0
func (l ClusterSet) Swap(i, j int)
type CoProcessor ¶
type CoProcessor interface {
WorkOnChunk(Chunk, Chunk, *IteratorParams)
}
func AppendColumnsIteratorHelper ¶
func AppendColumnsIteratorHelper(rowDataType hybridqp.RowDataType) CoProcessor
func FixedColumnsIteratorHelper ¶
func FixedColumnsIteratorHelper(rowDataType hybridqp.RowDataType) CoProcessor
func FixedMergeColumnsIteratorHelper ¶
func FixedMergeColumnsIteratorHelper(rowDataType hybridqp.RowDataType) CoProcessor
func NewAlignCoProcessor ¶
func NewAlignCoProcessor(rowDataType hybridqp.RowDataType) CoProcessor
func NewIntervalCoProcessor ¶
func NewIntervalCoProcessor(rowDataType hybridqp.RowDataType) CoProcessor
func NewSlidingWindowProcessors ¶
func NewSlidingWindowProcessors( inRowDataType, outRowDataType hybridqp.RowDataType, exprOpt []hybridqp.ExprOptions, opt *query.ProcessorOptions, schema hybridqp.Catalog, ) (CoProcessor, int, int)
func NewWideProcessorImpl ¶ added in v0.2.0
func NewWideProcessorImpl(inRowDataType, outRowDataType hybridqp.RowDataType, exprOpts []hybridqp.ExprOptions) (CoProcessor, error)
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) WorkOnChunk ¶
func (p *CoProcessorImpl) WorkOnChunk(in Chunk, out Chunk, params *IteratorParams)
type ColMergeFunc ¶ added in v1.3.0
type ColMergeFunc[T util.ExceptString] func(prevPoint, currPoint *Point[T])
type ColReduceFunc ¶ added in v1.3.0
type Column ¶
type Column interface {
DataType() influxql.DataType
Length() int
NilCount() int
IsEmpty() bool
ColumnTime(int) int64
ColumnTimes() []int64
AppendColumnTime(int64)
AppendColumnTimes([]int64)
SetColumnTimes([]int64)
IsNilV2(int) bool
NilsV2() *Bitmap
SetNilsBitmap(new *Bitmap)
AppendNil()
AppendNotNil()
AppendNilsV2(dat ...bool)
AppendManyNotNil(num int)
AppendManyNil(num int)
GetValueIndexV2(start int) int
GetRangeValueIndexV2(bmStart, bmEnd int) (s int, e int)
StringValuesRangeV2(dst []string, start, end int) []string
GetTimeIndex(valIdx int) int
Reset()
FloatTuple(int) floatTuple
FloatTuples() []floatTuple
AppendFloatTuple(floatTuple)
AppendFloatTuples([]floatTuple)
SetFloatTuples([]floatTuple)
FloatValue(int) float64
FloatValues() []float64
AppendFloatValue(float64)
AppendFloatValues([]float64)
SetFloatValues([]float64)
UpdateFloatValueFast(v float64, row int)
IntegerValue(int) int64
IntegerValues() []int64
AppendIntegerValue(int64)
AppendIntegerValues([]int64)
SetIntegerValues([]int64)
UpdateIntegerValueFast(v int64, row int)
StringValue(int) string
StringValuesV2(dst []string) []string
StringValuesRange(dst []string, start, end int) []string
StringValuesWithOffset(start, end int, offsets []uint32) ([]byte, []uint32)
AppendStringValue(string)
AppendStringValues([]string)
AppendStringBytes([]byte, []uint32)
SetStringValues([]byte, []uint32)
GetStringBytes() ([]byte, []uint32)
CloneStringValues([]byte, []uint32)
GetStringValueBytes(valueBits []byte, value []string, start, end int) ([]byte, []string)
BooleanValue(int) bool
BooleanValues() []bool
AppendBooleanValue(bool)
AppendBooleanValues([]bool)
SetBooleanValues([]bool)
UpdateBooleanValueFast(v bool, row int)
//TODO:CheckColumn used to check the chunk's structure
// Remember to remove it!
CheckColumn(int)
Marshal([]byte) ([]byte, error)
Unmarshal([]byte) error
Size() int
BitMap() *Bitmap
}
type ColumnImpl ¶
type ColumnImpl struct {
// contains filtered or unexported fields
}
func NewColumnImpl ¶
func NewColumnImpl(dataType influxql.DataType) *ColumnImpl
func (*ColumnImpl) AppendBooleanValue ¶ added in v1.1.0
func (c *ColumnImpl) AppendBooleanValue(value bool)
func (*ColumnImpl) AppendBooleanValues ¶
func (c *ColumnImpl) AppendBooleanValues(values []bool)
func (*ColumnImpl) AppendColumnTime ¶ added in v1.1.0
func (c *ColumnImpl) AppendColumnTime(value int64)
func (*ColumnImpl) AppendColumnTimes ¶
func (c *ColumnImpl) AppendColumnTimes(values []int64)
func (*ColumnImpl) AppendFloatTuple ¶ added in v1.1.0
func (c *ColumnImpl) AppendFloatTuple(tuple floatTuple)
func (*ColumnImpl) AppendFloatTuples ¶ added in v1.0.0
func (c *ColumnImpl) AppendFloatTuples(tuples []floatTuple)
func (*ColumnImpl) AppendFloatValue ¶ added in v1.1.0
func (c *ColumnImpl) AppendFloatValue(value float64)
func (*ColumnImpl) AppendFloatValues ¶
func (c *ColumnImpl) AppendFloatValues(values []float64)
func (*ColumnImpl) AppendIntegerValue ¶ added in v1.1.0
func (c *ColumnImpl) AppendIntegerValue(value int64)
func (*ColumnImpl) AppendIntegerValues ¶
func (c *ColumnImpl) AppendIntegerValues(values []int64)
func (*ColumnImpl) AppendManyNil ¶
func (c *ColumnImpl) AppendManyNil(num int)
func (*ColumnImpl) AppendManyNotNil ¶
func (c *ColumnImpl) AppendManyNotNil(num int)
func (*ColumnImpl) AppendNil ¶
func (c *ColumnImpl) AppendNil()
func (*ColumnImpl) AppendNilsV2 ¶
func (c *ColumnImpl) AppendNilsV2(dat ...bool)
func (*ColumnImpl) AppendNotNil ¶ added in v1.1.0
func (c *ColumnImpl) AppendNotNil()
func (*ColumnImpl) AppendStringBytes ¶
func (c *ColumnImpl) AppendStringBytes(val []byte, offset []uint32)
func (*ColumnImpl) AppendStringValue
deprecated
added in
v1.1.0
func (c *ColumnImpl) AppendStringValue(value string)
Deprecated: please do not use. recommend to use AppendStringBytes
func (*ColumnImpl) AppendStringValues
deprecated
func (c *ColumnImpl) AppendStringValues(values []string)
Deprecated: please do not use. recommend to use AppendStringBytes
func (*ColumnImpl) BitMap ¶
func (c *ColumnImpl) BitMap() *Bitmap
func (*ColumnImpl) BooleanValue ¶
func (c *ColumnImpl) BooleanValue(idx int) bool
func (*ColumnImpl) BooleanValues ¶
func (c *ColumnImpl) BooleanValues() []bool
func (*ColumnImpl) CheckColumn ¶
func (c *ColumnImpl) CheckColumn(length int)
func (*ColumnImpl) CloneStringValues ¶
func (c *ColumnImpl) CloneStringValues(val []byte, offset []uint32)
func (*ColumnImpl) ColumnTime ¶
func (c *ColumnImpl) ColumnTime(idx int) int64
func (*ColumnImpl) ColumnTimes ¶
func (c *ColumnImpl) ColumnTimes() []int64
func (*ColumnImpl) DataType ¶
func (c *ColumnImpl) DataType() influxql.DataType
func (*ColumnImpl) FloatTuple ¶ added in v1.0.0
func (c *ColumnImpl) FloatTuple(idx int) floatTuple
func (*ColumnImpl) FloatTuples ¶ added in v1.0.0
func (c *ColumnImpl) FloatTuples() []floatTuple
func (*ColumnImpl) FloatValue ¶
func (c *ColumnImpl) FloatValue(idx int) float64
func (*ColumnImpl) FloatValues ¶
func (c *ColumnImpl) FloatValues() []float64
func (*ColumnImpl) GetRangeValueIndexV2 ¶
func (c *ColumnImpl) GetRangeValueIndexV2(bmStart, bmEnd int) (int, int)
func (*ColumnImpl) GetStringBytes ¶
func (c *ColumnImpl) GetStringBytes() ([]byte, []uint32)
func (*ColumnImpl) GetStringValueBytes ¶
func (*ColumnImpl) GetTimeIndex ¶
func (c *ColumnImpl) GetTimeIndex(valIdx int) int
func (*ColumnImpl) GetValueIndexV2 ¶
func (c *ColumnImpl) GetValueIndexV2(start int) int
func (*ColumnImpl) Instance ¶
func (c *ColumnImpl) Instance() transport.Codec
func (*ColumnImpl) IntegerValue ¶
func (c *ColumnImpl) IntegerValue(idx int) int64
func (*ColumnImpl) IntegerValues ¶
func (c *ColumnImpl) IntegerValues() []int64
func (*ColumnImpl) IsEmpty ¶
func (c *ColumnImpl) IsEmpty() bool
func (*ColumnImpl) IsNilV2 ¶
func (c *ColumnImpl) IsNilV2(idx int) bool
func (*ColumnImpl) Length ¶
func (c *ColumnImpl) Length() int
func (*ColumnImpl) NilCount ¶
func (c *ColumnImpl) NilCount() int
func (*ColumnImpl) NilsV2 ¶
func (c *ColumnImpl) NilsV2() *Bitmap
func (*ColumnImpl) Reset ¶
func (c *ColumnImpl) Reset()
func (*ColumnImpl) SetBooleanValues ¶
func (c *ColumnImpl) SetBooleanValues(values []bool)
func (*ColumnImpl) SetColumnTimes ¶
func (c *ColumnImpl) SetColumnTimes(values []int64)
func (*ColumnImpl) SetFloatTuples ¶ added in v1.0.0
func (c *ColumnImpl) SetFloatTuples(tuples []floatTuple)
func (*ColumnImpl) SetFloatValues ¶
func (c *ColumnImpl) SetFloatValues(values []float64)
func (*ColumnImpl) SetIntegerValues ¶
func (c *ColumnImpl) SetIntegerValues(values []int64)
func (*ColumnImpl) SetNilsBitmap ¶
func (c *ColumnImpl) SetNilsBitmap(new *Bitmap)
SetNilsBitmap just for test use now.
func (*ColumnImpl) SetStringValues ¶
func (c *ColumnImpl) SetStringValues(val []byte, offset []uint32)
func (*ColumnImpl) Size ¶
func (c *ColumnImpl) Size() int
func (*ColumnImpl) StringValue ¶
func (c *ColumnImpl) StringValue(idx int) string
func (*ColumnImpl) StringValuesRange ¶
func (c *ColumnImpl) StringValuesRange(dst []string, start, end int) []string
func (*ColumnImpl) StringValuesRangeV2 ¶ added in v1.1.0
func (c *ColumnImpl) StringValuesRangeV2(dst []string, start, end int) []string
func (*ColumnImpl) StringValuesV2 ¶
func (c *ColumnImpl) StringValuesV2(dst []string) []string
StringValuesV2 just use for test.
func (*ColumnImpl) StringValuesWithOffset ¶ added in v1.1.0
func (c *ColumnImpl) StringValuesWithOffset(start, end int, offsets []uint32) ([]byte, []uint32)
func (*ColumnImpl) Unmarshal ¶
func (c *ColumnImpl) Unmarshal(buf []byte) error
func (*ColumnImpl) UpdateBooleanValueFast ¶ added in v1.3.0
func (c *ColumnImpl) UpdateBooleanValueFast(v bool, row int)
func (*ColumnImpl) UpdateFloatValueFast ¶ added in v1.2.0
func (c *ColumnImpl) UpdateFloatValueFast(v float64, row int)
func (*ColumnImpl) UpdateIntegerValueFast ¶ added in v1.2.0
func (c *ColumnImpl) UpdateIntegerValueFast(v int64, row int)
type ConditionExprVisitor ¶
type ConditionExprVisitor struct {
// contains filtered or unexported fields
}
func NewConditionExprVisitor ¶
func NewConditionExprVisitor() *ConditionExprVisitor
type CountValuesIterator ¶ added in v1.3.0
type CountValuesIterator struct {
// contains filtered or unexported fields
}
func NewCountValuesIterator ¶ added in v1.3.0
func NewCountValuesIterator(inOrdinal, outOrdinal int, tagName string) *CountValuesIterator
func (*CountValuesIterator) Next ¶ added in v1.3.0
func (r *CountValuesIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type CountValuesOp ¶ added in v1.3.0
type CountValuesOp struct{}
func (*CountValuesOp) CreateRoutine ¶ added in v1.3.0
func (c *CountValuesOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type CsStoreExchangeTraits ¶ added in v1.2.0
type CsStoreExchangeTraits struct {
// contains filtered or unexported fields
}
func NewCsStoreExchangeTraits ¶ added in v1.2.0
func NewCsStoreExchangeTraits(w spdy.Responser, PtQuerys []PtQuery) *CsStoreExchangeTraits
type DAG ¶
func NewDAG ¶
func NewDAG(processors Processors) *DAG
func (*DAG) CyclicGraph ¶
func (*DAG) Explain ¶
func (dag *DAG) Explain(fn func(*DAG, *strings.Builder) VertexWriter) VertexWriter
func (*DAG) OrphanVertexs ¶
func (*DAG) Processors ¶
func (dag *DAG) Processors() Processors
func (*DAG) SinkVertexs ¶
func (*DAG) SourceVertexs ¶
type DAGBuilder ¶
type DAGBuilder struct {
// contains filtered or unexported fields
}
func NewDAGBuilder ¶
func NewDAGBuilder(opt query.ProcessorOptions) *DAGBuilder
func (*DAGBuilder) Visit ¶
func (b *DAGBuilder) Visit(plan hybridqp.QueryNode) LogicalPlanVisitor
type DeleteClusterSet ¶ added in v1.0.0
type DetachedFrags ¶ added in v1.2.0
type DetachedFrags struct {
BaseFrags
// contains filtered or unexported fields
}
func NewDetachedFrags ¶ added in v1.2.0
func NewDetachedFrags(basePath string, cap int) *DetachedFrags
func (*DetachedFrags) AppendIndexes ¶ added in v1.2.0
func (s *DetachedFrags) AppendIndexes(metaIndexes ...interface{})
func (*DetachedFrags) IndexCount ¶ added in v1.2.0
func (s *DetachedFrags) IndexCount() int
func (*DetachedFrags) Indexes ¶ added in v1.2.0
func (s *DetachedFrags) Indexes() interface{}
func (*DetachedFrags) Size ¶ added in v1.2.0
func (s *DetachedFrags) Size() int
type DetachedIndexInfo ¶ added in v1.2.0
type DetachedIndexInfo struct {
// contains filtered or unexported fields
}
func NewDetachedIndexInfo ¶ added in v1.2.0
func NewDetachedIndexInfo(files []*immutable.MetaIndex, infos []*colstore.DetachedPKInfo) *DetachedIndexInfo
func (*DetachedIndexInfo) Files ¶ added in v1.2.0
func (a *DetachedIndexInfo) Files() []*immutable.MetaIndex
func (*DetachedIndexInfo) Infos ¶ added in v1.2.0
func (a *DetachedIndexInfo) Infos() []*colstore.DetachedPKInfo
type DistinctItem ¶ added in v1.3.0
type DistinctItem[T util.ExceptBool] struct { // contains filtered or unexported fields }
func NewDistinctItem ¶ added in v1.3.0
func NewDistinctItem[T util.ExceptBool]() *DistinctItem[T]
func (*DistinctItem[T]) Len ¶ added in v1.3.0
func (f *DistinctItem[T]) Len() int
func (*DistinctItem[T]) Less ¶ added in v1.3.0
func (f *DistinctItem[T]) Less(i, j int) bool
func (*DistinctItem[T]) Nil ¶ added in v1.3.0
func (f *DistinctItem[T]) Nil() bool
func (*DistinctItem[T]) Reset ¶ added in v1.3.0
func (f *DistinctItem[T]) Reset()
func (*DistinctItem[T]) Swap ¶ added in v1.3.0
func (f *DistinctItem[T]) Swap(i, j int)
type DownSampleState ¶ added in v1.0.0
type DownSampleState struct {
// contains filtered or unexported fields
}
func NewDownSampleState ¶ added in v1.0.0
func NewDownSampleState(taskID int, err error, newFiles []immutable.TSSPFile) *DownSampleState
func (*DownSampleState) GetErr ¶ added in v1.0.0
func (p *DownSampleState) GetErr() error
func (*DownSampleState) GetNewFiles ¶ added in v1.0.0
func (p *DownSampleState) GetNewFiles() []immutable.TSSPFile
func (*DownSampleState) GetTaskID ¶ added in v1.0.0
func (p *DownSampleState) GetTaskID() int
type DownSampleStatePort ¶ added in v1.0.0
type DownSampleStatePort struct {
RowDataType hybridqp.RowDataType
State chan *DownSampleState
OrigiState chan *DownSampleState
Redirected bool
// contains filtered or unexported fields
}
func NewDownSampleStatePort ¶ added in v1.0.0
func NewDownSampleStatePort(rowDataType hybridqp.RowDataType) *DownSampleStatePort
func (*DownSampleStatePort) Close ¶ added in v1.0.0
func (p *DownSampleStatePort) Close()
func (*DownSampleStatePort) Connect ¶ added in v1.0.0
func (p *DownSampleStatePort) Connect(to Port)
func (*DownSampleStatePort) ConnectStateReserve ¶ added in v1.0.0
func (p *DownSampleStatePort) ConnectStateReserve(to Port)
func (*DownSampleStatePort) ConnectionId ¶ added in v1.0.0
func (p *DownSampleStatePort) ConnectionId() uintptr
func (*DownSampleStatePort) Equal ¶ added in v1.0.0
func (p *DownSampleStatePort) Equal(to Port) bool
func (*DownSampleStatePort) Redirect ¶ added in v1.0.0
func (p *DownSampleStatePort) Redirect(to Port)
func (*DownSampleStatePort) Release ¶ added in v1.0.0
func (p *DownSampleStatePort) Release()
type ElapsedItem ¶
type ElapsedItem struct {
// contains filtered or unexported fields
}
func NewElapsedItem ¶
func NewElapsedItem(interval hybridqp.Interval) *ElapsedItem
func (*ElapsedItem) AppendItem ¶
func (f *ElapsedItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*ElapsedItem) AppendItemFastFunc ¶
func (f *ElapsedItem) AppendItemFastFunc(c Chunk, _ int, start, end int, sameInterval bool)
func (*ElapsedItem) AppendItemSlowFunc ¶
func (f *ElapsedItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*ElapsedItem) GetBaseTransData ¶
func (f *ElapsedItem) GetBaseTransData() BaseTransData
func (*ElapsedItem) Len ¶
func (f *ElapsedItem) Len() int
func (*ElapsedItem) PrevNil ¶
func (f *ElapsedItem) PrevNil() bool
func (*ElapsedItem) Reset ¶
func (f *ElapsedItem) Reset()
func (*ElapsedItem) ResetPrev ¶
func (f *ElapsedItem) ResetPrev()
type EndPointPair ¶
type EquivalenceExprRewriter ¶
type EquivalenceExprRewriter struct {
}
type Exchange ¶ added in v1.2.0
type Exchange interface {
hybridqp.QueryNode
Schema() hybridqp.Catalog
EType() ExchangeType
ERole() ExchangeRole
ETraits() []hybridqp.Trait
AddTrait(trait interface{})
ToProducer()
}
type ExchangeRole ¶
type ExchangeRole uint8
const ( UNKNOWN_ROLE ExchangeRole = iota CONSUMER_ROLE PRODUCER_ROLE )
type ExchangeType ¶
type ExchangeType uint8
const ( UNKNOWN_EXCHANGE ExchangeType = iota NODE_EXCHANGE SHARD_EXCHANGE SINGLE_SHARD_EXCHANGE READER_EXCHANGE SERIES_EXCHANGE SEGMENT_EXCHANGE PARTITION_EXCHANGE SUBQUERY_EXCHANGE )
type ExecutorBuilder ¶
type ExecutorBuilder struct {
// contains filtered or unexported fields
}
func NewColStoreScanExecutorBuilder ¶ added in v1.2.0
func NewColStoreScanExecutorBuilder(traits *StoreExchangeTraits, indexInfo interface{}, info *IndexScanExtraInfo) *ExecutorBuilder
func NewCsStoreExecutorBuilder ¶ added in v1.2.0
func NewCsStoreExecutorBuilder(traits *CsStoreExchangeTraits, s hybridqp.StoreEngine, req *RemoteQuery, ctx context.Context, limitSize int) *ExecutorBuilder
func NewIndexScanExecutorBuilder ¶
func NewIndexScanExecutorBuilder(traits *StoreExchangeTraits, enableBinaryTreeMerge int64) *ExecutorBuilder
func NewMocStoreExecutorBuilder ¶
func NewMocStoreExecutorBuilder(traits *StoreExchangeTraits, csTraits *CsStoreExchangeTraits, info *IndexScanExtraInfo, enableBinaryTreeMerge int64) *ExecutorBuilder
func NewQueryExecutorBuilder ¶
func NewQueryExecutorBuilder(enableBinaryTreeMerge int64) *ExecutorBuilder
func NewScannerStoreExecutorBuilder ¶
func NewScannerStoreExecutorBuilder(traits *StoreExchangeTraits, s hybridqp.StoreEngine, req *RemoteQuery, ctx context.Context, limitSize int) *ExecutorBuilder
func NewSparseIndexScanExecutorBuilder ¶ added in v1.1.0
func NewSparseIndexScanExecutorBuilder(frags *ShardsFragmentsGroups, info *IndexScanExtraInfo) *ExecutorBuilder
func NewStoreExecutorBuilder ¶
func NewStoreExecutorBuilder(traits *StoreExchangeTraits, enableBinaryTreeMerge int64) *ExecutorBuilder
func (*ExecutorBuilder) Analyze ¶
func (builder *ExecutorBuilder) Analyze(span *tracing.Span)
func (*ExecutorBuilder) CanOptimizeExchange ¶ added in v1.4.0
func (builder *ExecutorBuilder) CanOptimizeExchange(node hybridqp.QueryNode, children []*TransformVertex) (*TransformVertex, bool)
CanOptimizeExchange used for optimizing one shard or multiple shards in the same prom PT. Eliminate redundant Merge and Agg on the IndexScan upper layer.
func (*ExecutorBuilder) IsMultiMstPlanNode ¶ added in v1.3.0
func (builder *ExecutorBuilder) IsMultiMstPlanNode(node hybridqp.QueryNode) bool
func (*ExecutorBuilder) NextInfo ¶ added in v1.2.0
func (builder *ExecutorBuilder) NextInfo()
ts-server + multiPt nextInfo is use for nextPt
func (*ExecutorBuilder) NextMst ¶ added in v1.2.0
func (builder *ExecutorBuilder) NextMst()
func (*ExecutorBuilder) SetInfo ¶ added in v1.0.0
func (builder *ExecutorBuilder) SetInfo(info *IndexScanExtraInfo)
func (*ExecutorBuilder) SetInfosAndTraits ¶ added in v1.2.0
func (builder *ExecutorBuilder) SetInfosAndTraits(mstsReqs []*MultiMstReqs, ctx context.Context)
func (*ExecutorBuilder) SetMultiMstInfosForLocalStore ¶ added in v1.2.0
func (builder *ExecutorBuilder) SetMultiMstInfosForLocalStore(t []*IndexScanExtraInfo)
func (*ExecutorBuilder) SetMultiMstTraitsForLocalStore ¶ added in v1.2.0
func (builder *ExecutorBuilder) SetMultiMstTraitsForLocalStore(t []*StoreExchangeTraits)
func (*ExecutorBuilder) SetTraits ¶ added in v1.2.0
func (builder *ExecutorBuilder) SetTraits(t *StoreExchangeTraits)
type ExprRewriteRule ¶
type ExprRewriteRules ¶
type ExprRewriteRules []ExprRewriteRule
func (ExprRewriteRules) Rewrite ¶
func (rs ExprRewriteRules) Rewrite(schema hybridqp.Catalog)
type FieldValuer ¶ added in v1.0.0
func NewFieldValuer ¶ added in v1.0.0
func NewFieldValuer(ref *influxql.VarRef) (FieldValuer, error)
type FieldsValuer ¶ added in v1.0.0
type FieldsValuer struct {
// contains filtered or unexported fields
}
func NewFieldsValuer ¶ added in v1.0.0
func NewFieldsValuer(rdt hybridqp.RowDataType) (*FieldsValuer, error)
func (*FieldsValuer) At ¶ added in v1.0.0
func (valuer *FieldsValuer) At(chunk Chunk, pos int, tuple *TargetTuple)
type FileFragment ¶ added in v1.1.0
type FileFragment interface {
GetFile() immutable.TSSPFile
GetFragmentRanges() fragment.FragmentRanges
GetFragmentRange(int) *fragment.FragmentRange
AppendFragmentRange(fragment.FragmentRanges)
FragmentCount() int64
CutTo(num int64) FileFragment
}
type FileFragmentImpl ¶ added in v1.1.0
type FileFragmentImpl struct {
// contains filtered or unexported fields
}
func NewFileFragment ¶ added in v1.1.0
func NewFileFragment(f immutable.TSSPFile, fr fragment.FragmentRanges, fc int64) *FileFragmentImpl
func (*FileFragmentImpl) AppendFragmentRange ¶ added in v1.1.0
func (f *FileFragmentImpl) AppendFragmentRange(frs fragment.FragmentRanges)
func (*FileFragmentImpl) CutTo ¶ added in v1.1.0
func (f *FileFragmentImpl) CutTo(num int64) FileFragment
func (*FileFragmentImpl) FragmentCount ¶ added in v1.1.0
func (f *FileFragmentImpl) FragmentCount() int64
func (*FileFragmentImpl) GetFile ¶ added in v1.1.0
func (f *FileFragmentImpl) GetFile() immutable.TSSPFile
func (*FileFragmentImpl) GetFragmentRange ¶ added in v1.1.0
func (f *FileFragmentImpl) GetFragmentRange(i int) *fragment.FragmentRange
func (*FileFragmentImpl) GetFragmentRanges ¶ added in v1.1.0
func (f *FileFragmentImpl) GetFragmentRanges() fragment.FragmentRanges
type FileFragments ¶ added in v1.1.0
type FileFragments struct {
FragmentCount int64
FileMarks map[string]FileFragment
}
func NewFileFragments ¶ added in v1.1.0
func NewFileFragments() *FileFragments
func (*FileFragments) AddFileFragment ¶ added in v1.1.0
func (fms *FileFragments) AddFileFragment(filePath string, fm FileFragment, fc int64)
type FillItem ¶
type FillItem struct {
// contains filtered or unexported fields
}
func NewFillItem ¶
func NewFillItem() *FillItem
type FillProcessor ¶
type FillProcessor interface {
// contains filtered or unexported methods
}
func NewFillProcessor ¶
func NewFillProcessor(rowDataType hybridqp.RowDataType, schema *QuerySchema) ([]FillProcessor, error)
func NewLinearFillProcessor ¶
func NewLinearFillProcessor(rowDataType hybridqp.RowDataType) []FillProcessor
func NewNullFillProcessor ¶
func NewNullFillProcessor(rowDataType hybridqp.RowDataType, schema *QuerySchema) []FillProcessor
func NewNumberFillProcessor ¶
func NewNumberFillProcessor(rowDataType hybridqp.RowDataType) []FillProcessor
func NewPreviousFillProcessor ¶
func NewPreviousFillProcessor(rowDataType hybridqp.RowDataType) []FillProcessor
type FillTransform ¶
type FillTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
// contains filtered or unexported fields
}
func NewFillTransform ¶
func NewFillTransform(inRowDataType []hybridqp.RowDataType, outRowDataType []hybridqp.RowDataType, _ []hybridqp.ExprOptions, schema *QuerySchema) (*FillTransform, error)
func (*FillTransform) Close ¶
func (trans *FillTransform) Close()
func (*FillTransform) Explain ¶
func (trans *FillTransform) Explain() []ValuePair
func (*FillTransform) GetInputNumber ¶
func (trans *FillTransform) GetInputNumber(port Port) int
func (*FillTransform) GetInputs ¶
func (trans *FillTransform) GetInputs() Ports
func (*FillTransform) GetOutputNumber ¶
func (trans *FillTransform) GetOutputNumber(port Port) int
func (*FillTransform) GetOutputs ¶
func (trans *FillTransform) GetOutputs() Ports
func (*FillTransform) Name ¶
func (trans *FillTransform) Name() string
func (*FillTransform) NextChunk ¶ added in v1.4.0
func (trans *FillTransform) NextChunk()
type FillTransformCreator ¶
type FillTransformCreator struct{}
func (*FillTransformCreator) Create ¶
func (c *FillTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type FilterBlankTransform ¶
type FilterBlankTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
// contains filtered or unexported fields
}
func NewFilterBlankTransform ¶
func NewFilterBlankTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, opt *query.ProcessorOptions) *FilterBlankTransform
func (*FilterBlankTransform) Close ¶
func (trans *FilterBlankTransform) Close()
func (*FilterBlankTransform) Explain ¶
func (trans *FilterBlankTransform) Explain() []ValuePair
func (*FilterBlankTransform) GetInputNumber ¶
func (trans *FilterBlankTransform) GetInputNumber(port Port) int
func (*FilterBlankTransform) GetInputs ¶
func (trans *FilterBlankTransform) GetInputs() Ports
func (*FilterBlankTransform) GetOutputNumber ¶
func (trans *FilterBlankTransform) GetOutputNumber(port Port) int
func (*FilterBlankTransform) GetOutputs ¶
func (trans *FilterBlankTransform) GetOutputs() Ports
func (*FilterBlankTransform) Name ¶
func (trans *FilterBlankTransform) Name() string
type FilterBlankTransformCreator ¶
type FilterBlankTransformCreator struct {
}
func (*FilterBlankTransformCreator) Create ¶
func (c *FilterBlankTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type FilterTransform ¶
type FilterTransform struct {
BaseProcessor
Input *ChunkPort
Output *ChunkPort
ResultChunkPool *CircularChunkPool
CoProcessor CoProcessor
// contains filtered or unexported fields
}
func NewFilterTransform ¶
func NewFilterTransform(inRowDataType hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, schema *QuerySchema, opt *query.ProcessorOptions) *FilterTransform
func (*FilterTransform) Close ¶
func (trans *FilterTransform) Close()
func (*FilterTransform) Explain ¶
func (trans *FilterTransform) Explain() []ValuePair
func (*FilterTransform) GetInputNumber ¶
func (trans *FilterTransform) GetInputNumber(port Port) int
func (*FilterTransform) GetInputs ¶
func (trans *FilterTransform) GetInputs() Ports
func (*FilterTransform) GetOutputNumber ¶
func (trans *FilterTransform) GetOutputNumber(port Port) int
func (*FilterTransform) GetOutputs ¶
func (trans *FilterTransform) GetOutputs() Ports
func (*FilterTransform) Name ¶
func (trans *FilterTransform) Name() string
func (*FilterTransform) Release ¶
func (trans *FilterTransform) Release() error
type FilterTransformCreator ¶
type FilterTransformCreator struct {
}
func (*FilterTransformCreator) Create ¶
func (c *FilterTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type Float64AppendIterator ¶
type Float64AppendIterator struct {
// contains filtered or unexported fields
}
func NewFloat64AppendIterator ¶
func NewFloat64AppendIterator() *Float64AppendIterator
func (*Float64AppendIterator) Next ¶
func (f *Float64AppendIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type Float64LimitIterator ¶
type Float64LimitIterator struct {
// contains filtered or unexported fields
}
func NewFloat64LimitIterator ¶
func NewFloat64LimitIterator() *Float64LimitIterator
func (*Float64LimitIterator) Next ¶
func (f *Float64LimitIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type Float64MergeIterator ¶
type Float64MergeIterator struct {
// contains filtered or unexported fields
}
func NewFloat64MergeIterator ¶
func NewFloat64MergeIterator() *Float64MergeIterator
func (*Float64MergeIterator) Next ¶
func (f *Float64MergeIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type FloatAlignIterator ¶
type FloatAlignIterator struct{}
func NewFloatAlignIterator ¶
func NewFloatAlignIterator() *FloatAlignIterator
func (*FloatAlignIterator) Next ¶
func (f *FloatAlignIterator) Next(endpoint *IteratorEndpoint, _ *IteratorParams)
type FloatColFloatDistinctIterator ¶
type FloatColFloatDistinctIterator struct {
// contains filtered or unexported fields
}
func NewFloatColFloatDistinctIterator ¶
func NewFloatColFloatDistinctIterator( inOrdinal, outOrdinal int, ) *FloatColFloatDistinctIterator
func (*FloatColFloatDistinctIterator) Next ¶
func (r *FloatColFloatDistinctIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type FloatColFloatHeapIterator ¶
type FloatColFloatHeapIterator struct {
// contains filtered or unexported fields
}
func NewFloatColFloatHeapIterator ¶
func NewFloatColFloatHeapIterator( inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, FloatHeapItem *HeapItem[float64], ) *FloatColFloatHeapIterator
func (*FloatColFloatHeapIterator) Next ¶
func (r *FloatColFloatHeapIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type FloatColFloatHistogramIterator ¶ added in v1.3.0
type FloatColFloatHistogramIterator struct {
// contains filtered or unexported fields
}
func NewFloatColFloatHistogramIterator ¶ added in v1.3.0
func NewFloatColFloatHistogramIterator(fn FloatColReduceHistogramReduce, inOrdinal, outOrdinal int, rowDataType hybridqp.RowDataType) *FloatColFloatHistogramIterator
func (*FloatColFloatHistogramIterator) Next ¶ added in v1.3.0
func (r *FloatColFloatHistogramIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type FloatColFloatRateIterator ¶
type FloatColFloatRateIterator struct {
// contains filtered or unexported fields
}
func NewFloatRateIterator ¶ added in v1.3.0
func NewFloatRateIterator(fn RateMiddleReduceFunc[float64], fv RateFinalReduceFunc[float64], fu RateUpdateFunc[float64], fm RateMergeFunc[float64], isSingleCall bool, inOrdinal, outOrdinal int, rowDataType hybridqp.RowDataType, interval *hybridqp.Interval, ) *FloatColFloatRateIterator
func (*FloatColFloatRateIterator) Next ¶
func (r *FloatColFloatRateIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type FloatColFloatSampleIterator ¶
type FloatColFloatSampleIterator struct {
// contains filtered or unexported fields
}
func NewFloatColFloatSampleIterator ¶
func NewFloatColFloatSampleIterator(sampleNum int, isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *FloatColFloatSampleIterator
func (*FloatColFloatSampleIterator) Next ¶
func (r *FloatColFloatSampleIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type FloatColFloatSliceIterator ¶
type FloatColFloatSliceIterator struct {
// contains filtered or unexported fields
}
func NewFloatColFloatSliceIterator ¶
func NewFloatColFloatSliceIterator(fn SliceReduce[float64], isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *FloatColFloatSliceIterator
func (*FloatColFloatSliceIterator) Next ¶
func (r *FloatColFloatSliceIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type FloatColReduceHistogramReduce ¶ added in v1.3.0
type FloatColReduceHistogramReduce func(floatItem []bucket) (value float64)
func FloatHistogramQuantilePromReduce ¶ added in v1.3.0
func FloatHistogramQuantilePromReduce(p float64) FloatColReduceHistogramReduce
type FloatCountPromOp ¶ added in v1.3.0
type FloatCountPromOp struct {
BasePromOp
}
func (*FloatCountPromOp) CreateRoutine ¶ added in v1.3.0
func (c *FloatCountPromOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type FloatCumulativeSumItem ¶
type FloatCumulativeSumItem struct {
// contains filtered or unexported fields
}
func NewFloatCumulativeSumItem ¶
func NewFloatCumulativeSumItem() *FloatCumulativeSumItem
func (*FloatCumulativeSumItem) AppendItem ¶
func (f *FloatCumulativeSumItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatCumulativeSumItem) AppendItemFastFunc ¶
func (f *FloatCumulativeSumItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatCumulativeSumItem) AppendItemSlowFunc ¶
func (f *FloatCumulativeSumItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatCumulativeSumItem) GetBaseTransData ¶
func (f *FloatCumulativeSumItem) GetBaseTransData() BaseTransData
func (*FloatCumulativeSumItem) Len ¶
func (f *FloatCumulativeSumItem) Len() int
func (*FloatCumulativeSumItem) PrevNil ¶
func (f *FloatCumulativeSumItem) PrevNil() bool
func (*FloatCumulativeSumItem) Reset ¶
func (f *FloatCumulativeSumItem) Reset()
func (*FloatCumulativeSumItem) ResetPrev ¶
func (f *FloatCumulativeSumItem) ResetPrev()
type FloatDerivativeItem ¶
type FloatDerivativeItem struct {
// contains filtered or unexported fields
}
func NewFloatDerivativeItem ¶
func NewFloatDerivativeItem(isNonNegative, ascending bool, interval hybridqp.Interval) *FloatDerivativeItem
func (*FloatDerivativeItem) AppendItem ¶
func (f *FloatDerivativeItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatDerivativeItem) AppendItemFastFunc ¶
func (f *FloatDerivativeItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatDerivativeItem) AppendItemSlowFunc ¶
func (f *FloatDerivativeItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatDerivativeItem) GetBaseTransData ¶
func (f *FloatDerivativeItem) GetBaseTransData() BaseTransData
func (*FloatDerivativeItem) Len ¶
func (f *FloatDerivativeItem) Len() int
func (*FloatDerivativeItem) PrevNil ¶
func (f *FloatDerivativeItem) PrevNil() bool
func (*FloatDerivativeItem) Reset ¶
func (f *FloatDerivativeItem) Reset()
func (*FloatDerivativeItem) ResetPrev ¶
func (f *FloatDerivativeItem) ResetPrev()
type FloatDifferenceItem ¶
type FloatDifferenceItem struct {
// contains filtered or unexported fields
}
func NewFloatDifferenceItem ¶
func NewFloatDifferenceItem(isNonNegative bool, diff floatDifference) *FloatDifferenceItem
func (*FloatDifferenceItem) AppendItem ¶
func (f *FloatDifferenceItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatDifferenceItem) AppendItemFastFunc ¶
func (f *FloatDifferenceItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatDifferenceItem) AppendItemSlowFunc ¶
func (f *FloatDifferenceItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatDifferenceItem) GetBaseTransData ¶
func (f *FloatDifferenceItem) GetBaseTransData() BaseTransData
func (*FloatDifferenceItem) Len ¶
func (f *FloatDifferenceItem) Len() int
func (*FloatDifferenceItem) PrevNil ¶
func (f *FloatDifferenceItem) PrevNil() bool
func (*FloatDifferenceItem) Reset ¶
func (f *FloatDifferenceItem) Reset()
func (*FloatDifferenceItem) ResetPrev ¶
func (f *FloatDifferenceItem) ResetPrev()
type FloatFieldValuer ¶ added in v1.0.0
type FloatFieldValuer struct {
// contains filtered or unexported fields
}
type FloatIntegralIterator ¶ added in v1.3.0
type FloatIntegralIterator struct {
// contains filtered or unexported fields
}
func NewFloatIntegralIterator ¶ added in v1.3.0
func NewFloatIntegralIterator( isSingleCall bool, inOrdinal, outOrdinal int, interval hybridqp.Interval, opt *query.ProcessorOptions, ) *FloatIntegralIterator
func (*FloatIntegralIterator) Next ¶ added in v1.3.0
func (r *FloatIntegralIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type FloatIntervalIterator ¶
type FloatIntervalIterator struct{}
func NewFloatIntervalIterator ¶
func NewFloatIntervalIterator() *FloatIntervalIterator
func (*FloatIntervalIterator) Next ¶
func (f *FloatIntervalIterator) Next(endpoint *IteratorEndpoint, _ *IteratorParams)
type FloatIterator ¶ added in v1.3.0
type FloatIterator struct {
// contains filtered or unexported fields
}
func NewFloatIterator ¶ added in v1.3.0
func NewFloatIterator(fn ColReduceFunc[float64], fv ColMergeFunc[float64], isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *FloatIterator
func (*FloatIterator) Next ¶ added in v1.3.0
func (r *FloatIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type FloatLinearFillProcessor ¶
type FloatLinearFillProcessor struct {
// contains filtered or unexported fields
}
func NewFloatLinearFillProcessor ¶
func NewFloatLinearFillProcessor(inOrdinal, outOrdinal int) *FloatLinearFillProcessor
type FloatMovingAverageItem ¶
type FloatMovingAverageItem struct {
// contains filtered or unexported fields
}
func NewFloatMovingAverageItem ¶
func NewFloatMovingAverageItem(n int) *FloatMovingAverageItem
func (*FloatMovingAverageItem) AppendItem ¶
func (f *FloatMovingAverageItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatMovingAverageItem) AppendItemFastFunc ¶
func (f *FloatMovingAverageItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatMovingAverageItem) AppendItemSlowFunc ¶
func (f *FloatMovingAverageItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*FloatMovingAverageItem) GetBaseTransData ¶
func (f *FloatMovingAverageItem) GetBaseTransData() BaseTransData
func (*FloatMovingAverageItem) Len ¶
func (f *FloatMovingAverageItem) Len() int
func (*FloatMovingAverageItem) PrevNil ¶
func (f *FloatMovingAverageItem) PrevNil() bool
func (*FloatMovingAverageItem) Reset ¶
func (f *FloatMovingAverageItem) Reset()
func (*FloatMovingAverageItem) ResetPrev ¶
func (f *FloatMovingAverageItem) ResetPrev()
type FloatNullFillProcessor ¶
type FloatNullFillProcessor struct {
// contains filtered or unexported fields
}
func NewFloatNullFillProcessor ¶
func NewFloatNullFillProcessor(inOrdinal, outOrdinal int) *FloatNullFillProcessor
type FloatNumberFillProcessor ¶
type FloatNumberFillProcessor struct {
// contains filtered or unexported fields
}
func NewFloatNumberFillProcessor ¶
func NewFloatNumberFillProcessor(inOrdinal, outOrdinal int) *FloatNumberFillProcessor
type FloatOGSketchInsertItem ¶ added in v1.0.0
type FloatOGSketchInsertItem struct {
// contains filtered or unexported fields
}
func NewFloatOGSketchInsertIem ¶ added in v1.0.0
func NewFloatOGSketchInsertIem(isSingleCall bool, inOrdinal, outOrdinal, clusterNum int, percentile float64) *FloatOGSketchInsertItem
func (*FloatOGSketchInsertItem) IsNil ¶ added in v1.0.0
func (o *FloatOGSketchInsertItem) IsNil() bool
func (*FloatOGSketchInsertItem) Reset ¶ added in v1.0.0
func (o *FloatOGSketchInsertItem) Reset()
func (*FloatOGSketchInsertItem) UpdateCluster ¶ added in v1.0.0
func (o *FloatOGSketchInsertItem) UpdateCluster(inChunk Chunk, start, end int)
func (*FloatOGSketchInsertItem) WriteResult ¶ added in v1.0.0
func (o *FloatOGSketchInsertItem) WriteResult(outChunk Chunk, time int64)
type FloatOGSketchPercentileItem ¶ added in v1.0.0
type FloatOGSketchPercentileItem struct {
// contains filtered or unexported fields
}
func NewFloatOGSketchPercentileItem ¶ added in v1.0.0
func NewFloatOGSketchPercentileItem(isSingleCall bool, inOrdinal, outOrdinal, clusterNum int, percentile float64) *FloatOGSketchPercentileItem
func (*FloatOGSketchPercentileItem) IsNil ¶ added in v1.0.0
func (o *FloatOGSketchPercentileItem) IsNil() bool
func (*FloatOGSketchPercentileItem) Reset ¶ added in v1.0.0
func (o *FloatOGSketchPercentileItem) Reset()
func (*FloatOGSketchPercentileItem) UpdateCluster ¶ added in v1.0.0
func (o *FloatOGSketchPercentileItem) UpdateCluster(inChunk Chunk, start, end int)
func (*FloatOGSketchPercentileItem) WriteResult ¶ added in v1.0.0
func (o *FloatOGSketchPercentileItem) WriteResult(outChunk Chunk, time int64)
type FloatPercentileApproxItem ¶ added in v1.0.0
type FloatPercentileApproxItem struct {
// contains filtered or unexported fields
}
func NewFloatPercentileApproxItem ¶ added in v1.0.0
func NewFloatPercentileApproxItem(isSingleCall bool, inOrdinal, outOrdinal, clusterNum int, percentile float64) *FloatPercentileApproxItem
func (*FloatPercentileApproxItem) IsNil ¶ added in v1.0.0
func (o *FloatPercentileApproxItem) IsNil() bool
func (*FloatPercentileApproxItem) Reset ¶ added in v1.0.0
func (o *FloatPercentileApproxItem) Reset()
func (*FloatPercentileApproxItem) UpdateCluster ¶ added in v1.0.0
func (o *FloatPercentileApproxItem) UpdateCluster(inChunk Chunk, start, end int)
func (*FloatPercentileApproxItem) WriteResult ¶ added in v1.0.0
func (o *FloatPercentileApproxItem) WriteResult(outChunk Chunk, time int64)
type FloatPreviousFillProcessor ¶
type FloatPreviousFillProcessor struct {
// contains filtered or unexported fields
}
func NewFloatPreviousFillProcessor ¶
func NewFloatPreviousFillProcessor(inOrdinal, outOrdinal int) *FloatPreviousFillProcessor
type FloatTimeColFloatIterator ¶
type FloatTimeColFloatIterator struct {
// contains filtered or unexported fields
}
func NewFloatTimeColFloatIterator ¶
func NewFloatTimeColFloatIterator( fn TimeColReduceFunc[float64], fv ColMergeFunc[float64], inOrdinal, outOrdinal int, ) *FloatTimeColFloatIterator
func (*FloatTimeColFloatIterator) Next ¶
func (r *FloatTimeColFloatIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type FloatTransIterator ¶ added in v1.3.0
type FloatTransIterator struct {
// contains filtered or unexported fields
}
func NewFloatTransIterator ¶ added in v1.3.0
func NewFloatTransIterator( isSingleCall bool, inOrdinal, outOrdinal int, transItem TransItem, ) *FloatTransIterator
func (*FloatTransIterator) Next ¶ added in v1.3.0
func (r *FloatTransIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type FloatTupleMergeIterator ¶ added in v1.0.0
type FloatTupleMergeIterator struct {
BaseMergeIterator
// contains filtered or unexported fields
}
func NewFloatTupleMergeIterator ¶ added in v1.0.0
func NewFloatTupleMergeIterator() *FloatTupleMergeIterator
func (*FloatTupleMergeIterator) Next ¶ added in v1.0.0
func (f *FloatTupleMergeIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type FrequentResult ¶ added in v1.4.0
type FrequentResult struct {
// contains filtered or unexported fields
}
func (*FrequentResult) Len ¶ added in v1.4.0
func (fr *FrequentResult) Len() int
func (*FrequentResult) Less ¶ added in v1.4.0
func (fr *FrequentResult) Less(i, j int) bool
func (*FrequentResult) Swap ¶ added in v1.4.0
func (fr *FrequentResult) Swap(i, j int)
type FullJoinTransform ¶ added in v1.0.0
type FullJoinTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewFullJoinTransform ¶ added in v1.0.0
func NewFullJoinTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, joinCase *influxql.Join, schema *QuerySchema) (*FullJoinTransform, error)
func (*FullJoinTransform) Close ¶ added in v1.0.0
func (trans *FullJoinTransform) Close()
func (*FullJoinTransform) Explain ¶ added in v1.0.0
func (trans *FullJoinTransform) Explain() []ValuePair
func (*FullJoinTransform) GetInputNumber ¶ added in v1.0.0
func (trans *FullJoinTransform) GetInputNumber(_ Port) int
func (*FullJoinTransform) GetInputs ¶ added in v1.0.0
func (trans *FullJoinTransform) GetInputs() Ports
func (*FullJoinTransform) GetOutputNumber ¶ added in v1.0.0
func (trans *FullJoinTransform) GetOutputNumber(_ Port) int
func (*FullJoinTransform) GetOutputs ¶ added in v1.0.0
func (trans *FullJoinTransform) GetOutputs() Ports
func (*FullJoinTransform) Name ¶ added in v1.0.0
func (trans *FullJoinTransform) Name() string
func (*FullJoinTransform) NewChunkElem ¶ added in v1.0.0
func (trans *FullJoinTransform) NewChunkElem(chunk Chunk, seriesKeyLoc int, seriesValLoc int) *chunkElem
func (*FullJoinTransform) SendChunk ¶ added in v1.0.0
func (trans *FullJoinTransform) SendChunk()
type FullJoinTransformCreator ¶ added in v1.0.0
type FullJoinTransformCreator struct {
}
func (*FullJoinTransformCreator) Create ¶ added in v1.0.0
func (c *FullJoinTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type GraphIterator ¶
type GraphIterator struct {
// contains filtered or unexported fields
}
func NewGraphIterator ¶
func NewGraphIterator(capacity int) *GraphIterator
func (*GraphIterator) HasNext ¶
func (iter *GraphIterator) HasNext() bool
func (*GraphIterator) Next ¶
func (iter *GraphIterator) Next() *HeuVertex
func (*GraphIterator) Reset ¶
func (iter *GraphIterator) Reset()
func (*GraphIterator) Size ¶
func (iter *GraphIterator) Size() int
func (*GraphIterator) Visit ¶
func (iter *GraphIterator) Visit(vertex *HeuVertex) HeuDagVisitor
type GroupByTransform ¶
type GroupByTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewGroupByTransform ¶
func NewGroupByTransform(inRowDataType hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, ops []hybridqp.ExprOptions, opt *query.ProcessorOptions) *GroupByTransform
func (*GroupByTransform) Close ¶
func (trans *GroupByTransform) Close()
func (*GroupByTransform) Explain ¶
func (trans *GroupByTransform) Explain() []ValuePair
func (*GroupByTransform) GetInputNumber ¶
func (trans *GroupByTransform) GetInputNumber(_ Port) int
func (*GroupByTransform) GetInputs ¶
func (trans *GroupByTransform) GetInputs() Ports
func (*GroupByTransform) GetOutputNumber ¶
func (trans *GroupByTransform) GetOutputNumber(_ Port) int
func (*GroupByTransform) GetOutputs ¶
func (trans *GroupByTransform) GetOutputs() Ports
func (*GroupByTransform) Name ¶
func (trans *GroupByTransform) Name() string
func (*GroupByTransform) Release ¶
func (trans *GroupByTransform) Release() error
type GroupByTransformCreator ¶
type GroupByTransformCreator struct {
}
func (*GroupByTransformCreator) Create ¶
func (c *GroupByTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type GroupKeysMPool ¶ added in v1.1.0
type GroupKeysMPool struct {
// contains filtered or unexported fields
}
func NewGroupKeysPool ¶ added in v1.1.0
func NewGroupKeysPool(size int) *GroupKeysMPool
func (*GroupKeysMPool) AllocGroupKeys ¶ added in v1.1.0
func (gkp *GroupKeysMPool) AllocGroupKeys(size int) [][]byte
func (*GroupKeysMPool) AllocGroupTags ¶ added in v1.1.0
func (gkp *GroupKeysMPool) AllocGroupTags(size int) []*ChunkTags
func (*GroupKeysMPool) AllocValues ¶ added in v1.1.0
func (gkp *GroupKeysMPool) AllocValues(size int) []uint64
func (*GroupKeysMPool) AllocZValues ¶ added in v1.1.0
func (gkp *GroupKeysMPool) AllocZValues(size int) []int64
func (*GroupKeysMPool) FreeGroupKeys ¶ added in v1.1.0
func (gkp *GroupKeysMPool) FreeGroupKeys(groupKeys [][]byte)
func (*GroupKeysMPool) FreeGroupTags ¶ added in v1.1.0
func (gkp *GroupKeysMPool) FreeGroupTags(groupTags []*ChunkTags)
func (*GroupKeysMPool) FreeValues ¶ added in v1.1.0
func (gkp *GroupKeysMPool) FreeValues(values []uint64)
func (*GroupKeysMPool) FreeZValue ¶ added in v1.1.0
func (gkp *GroupKeysMPool) FreeZValue(spillState []int64)
type HashAggTransform ¶ added in v1.1.0
type HashAggTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func (*HashAggTransform) Close ¶ added in v1.1.0
func (trans *HashAggTransform) Close()
func (*HashAggTransform) Explain ¶ added in v1.1.0
func (trans *HashAggTransform) Explain() []ValuePair
func (*HashAggTransform) GetFuncs ¶ added in v1.1.0
func (trans *HashAggTransform) GetFuncs() []aggFunc
func (*HashAggTransform) GetInputNumber ¶ added in v1.1.0
func (trans *HashAggTransform) GetInputNumber(_ Port) int
func (*HashAggTransform) GetInputs ¶ added in v1.1.0
func (trans *HashAggTransform) GetInputs() Ports
func (*HashAggTransform) GetOutputNumber ¶ added in v1.1.0
func (trans *HashAggTransform) GetOutputNumber(_ Port) int
func (*HashAggTransform) GetOutputs ¶ added in v1.1.0
func (trans *HashAggTransform) GetOutputs() Ports
func (*HashAggTransform) InitFuncs ¶ added in v1.1.0
func (trans *HashAggTransform) InitFuncs(inRowDataType, outRowDataType hybridqp.RowDataType, exprOpt []hybridqp.ExprOptions) error
func (*HashAggTransform) Name ¶ added in v1.1.0
func (trans *HashAggTransform) Name() string
type HashAggTransformCreator ¶ added in v1.1.0
type HashAggTransformCreator struct {
}
func (*HashAggTransformCreator) Create ¶ added in v1.1.0
func (c *HashAggTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type HashAggType ¶ added in v1.1.0
type HashAggType uint32
const ( Fill HashAggType = iota Normal SubQuery )
type HashMergeBooleanColumn ¶ added in v1.1.1
type HashMergeBooleanColumn struct {
// contains filtered or unexported fields
}
func (*HashMergeBooleanColumn) AppendValues ¶ added in v1.1.1
func (m *HashMergeBooleanColumn) AppendValues(col Column, start int, end int)
func (*HashMergeBooleanColumn) SetOutPut ¶ added in v1.1.1
func (m *HashMergeBooleanColumn) SetOutPut(col Column)
type HashMergeColumn ¶ added in v1.1.1
type HashMergeColumn interface {
AppendValues(col Column, start int, end int)
SetOutPut(col Column)
}
func NewHashMergeBooleanColumn ¶ added in v1.1.1
func NewHashMergeBooleanColumn() HashMergeColumn
func NewHashMergeFloatColumn ¶ added in v1.1.1
func NewHashMergeFloatColumn() HashMergeColumn
func NewHashMergeIntegerColumn ¶ added in v1.1.1
func NewHashMergeIntegerColumn() HashMergeColumn
func NewHashMergeStringColumn ¶ added in v1.1.1
func NewHashMergeStringColumn() HashMergeColumn
type HashMergeFloatColumn ¶ added in v1.1.1
type HashMergeFloatColumn struct {
// contains filtered or unexported fields
}
func (*HashMergeFloatColumn) AppendValues ¶ added in v1.1.1
func (m *HashMergeFloatColumn) AppendValues(col Column, start int, end int)
func (*HashMergeFloatColumn) SetOutPut ¶ added in v1.1.1
func (m *HashMergeFloatColumn) SetOutPut(col Column)
type HashMergeIntegerColumn ¶ added in v1.1.1
type HashMergeIntegerColumn struct {
// contains filtered or unexported fields
}
func (*HashMergeIntegerColumn) AppendValues ¶ added in v1.1.1
func (m *HashMergeIntegerColumn) AppendValues(col Column, start int, end int)
func (*HashMergeIntegerColumn) SetOutPut ¶ added in v1.1.1
func (m *HashMergeIntegerColumn) SetOutPut(col Column)
type HashMergeMsg ¶ added in v1.1.1
type HashMergeMsg struct {
// contains filtered or unexported fields
}
type HashMergeResult ¶ added in v1.1.1
type HashMergeResult struct {
// contains filtered or unexported fields
}
func (*HashMergeResult) AppendResult ¶ added in v1.1.1
func (mr *HashMergeResult) AppendResult(chunk Chunk, start int, end int)
type HashMergeStringColumn ¶ added in v1.1.1
type HashMergeStringColumn struct {
// contains filtered or unexported fields
}
func (*HashMergeStringColumn) AppendValues ¶ added in v1.1.1
func (m *HashMergeStringColumn) AppendValues(col Column, start int, end int)
func (*HashMergeStringColumn) SetOutPut ¶ added in v1.1.1
func (m *HashMergeStringColumn) SetOutPut(col Column)
type HashMergeTransform ¶ added in v1.1.0
type HashMergeTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewHashMergeHashTypeTransform ¶ added in v1.1.0
func NewHashMergeHashTypeTransform(inRowDataType, outRowDataType []hybridqp.RowDataType, s *QuerySchema) (*HashMergeTransform, error)
func NewHashMergeStreamTypeTransform ¶ added in v1.1.0
func NewHashMergeStreamTypeTransform(inRowDataType, outRowDataType []hybridqp.RowDataType, s *QuerySchema) (*HashMergeTransform, error)
func NewHashMergeTransform ¶ added in v1.1.0
func NewHashMergeTransform(inRowDataType, outRowDataType []hybridqp.RowDataType, s *QuerySchema) (*HashMergeTransform, error)
func (*HashMergeTransform) Close ¶ added in v1.1.0
func (trans *HashMergeTransform) Close()
func (*HashMergeTransform) Explain ¶ added in v1.1.0
func (trans *HashMergeTransform) Explain() []ValuePair
func (*HashMergeTransform) GetInputNumber ¶ added in v1.1.0
func (trans *HashMergeTransform) GetInputNumber(_ Port) int
func (*HashMergeTransform) GetInputs ¶ added in v1.1.0
func (trans *HashMergeTransform) GetInputs() Ports
func (*HashMergeTransform) GetOutputNumber ¶ added in v1.1.0
func (trans *HashMergeTransform) GetOutputNumber(_ Port) int
func (*HashMergeTransform) GetOutputs ¶ added in v1.1.0
func (trans *HashMergeTransform) GetOutputs() Ports
func (*HashMergeTransform) Name ¶ added in v1.1.0
func (trans *HashMergeTransform) Name() string
type HashMergeTransformCreator ¶ added in v1.1.0
type HashMergeTransformCreator struct {
}
func (*HashMergeTransformCreator) Create ¶ added in v1.1.0
func (c *HashMergeTransformCreator) Create(plan LogicalPlan, opt query.ProcessorOptions) (Processor, error)
type HashMergeType ¶ added in v1.1.0
type HashMergeType uint32
const ( Hash HashMergeType = iota Stream )
type HeapItem ¶ added in v1.3.0
type HeapItem[T util.NumberOnly] struct { // contains filtered or unexported fields }
func NewHeapItem ¶ added in v1.3.0
type HeapItems ¶
type HeapItems struct {
Items []*Item
// contains filtered or unexported fields
}
func (*HeapItems) GetBreakPoint ¶
func (h *HeapItems) GetBreakPoint() BaseBreakPoint
GetBreakPoint used to get the break point of the records
func (*HeapItems) GetOption ¶ added in v1.0.0
func (h *HeapItems) GetOption() *query.ProcessorOptions
type HeuDag ¶
type HeuDag struct {
// contains filtered or unexported fields
}
func (*HeuDag) AddVerteix ¶
func (*HeuDag) AllParents ¶
func (*HeuDag) DigestSize ¶
func (*HeuDag) GetGraphIterator ¶
func (dag *HeuDag) GetGraphIterator(vertex *HeuVertex, matchOrder HeuMatchOrder) *GraphIterator
func (*HeuDag) GetVertexByDigest ¶
func (*HeuDag) RemoveEdge ¶
func (*HeuDag) RemoveVertex ¶
func (*HeuDag) UpdateVerteix ¶
func (*HeuDag) VertexSize ¶
func (*HeuDag) WalkHeuDag ¶
func (dag *HeuDag) WalkHeuDag(visitor HeuDagVisitor, vertex *HeuVertex)
type HeuDagVisitor ¶
type HeuDagVisitor interface {
Visit(vertex *HeuVertex) HeuDagVisitor
}
type HeuInstruction ¶
type HeuInstruction interface {
Initialize(bool)
Execute(HeuPlanner)
}
type HeuPlanner ¶
type HeuPlannerImpl ¶
type HeuPlannerImpl struct {
// contains filtered or unexported fields
}
func NewHeuPlannerImpl ¶
func NewHeuPlannerImpl(program *HeuProgram) *HeuPlannerImpl
func (*HeuPlannerImpl) AddRule ¶
func (p *HeuPlannerImpl) AddRule(rule OptRule) bool
func (*HeuPlannerImpl) ExecuteInstruction ¶
func (p *HeuPlannerImpl) ExecuteInstruction(instruction HeuInstruction)
func (*HeuPlannerImpl) FindBestExp ¶
func (p *HeuPlannerImpl) FindBestExp() hybridqp.QueryNode
func (*HeuPlannerImpl) SetRoot ¶
func (p *HeuPlannerImpl) SetRoot(root hybridqp.QueryNode)
func (*HeuPlannerImpl) Transformations ¶
func (p *HeuPlannerImpl) Transformations() int
func (*HeuPlannerImpl) Vertex ¶
func (p *HeuPlannerImpl) Vertex(node hybridqp.QueryNode) (*HeuVertex, bool)
func (*HeuPlannerImpl) Visit ¶
func (p *HeuPlannerImpl) Visit(node hybridqp.QueryNode) hybridqp.QueryNodeVisitor
type HeuProgram ¶
type HeuProgram struct {
// contains filtered or unexported fields
}
func NewHeuProgram ¶
func NewHeuProgram(instructions []HeuInstruction) *HeuProgram
func (*HeuProgram) Initialize ¶
func (p *HeuProgram) Initialize(clearCache bool)
type HeuVertex ¶
type HeuVertex struct {
// contains filtered or unexported fields
}
func NewHeuVertex ¶
func (*HeuVertex) ApplyTrait ¶
func (*HeuVertex) DeriveOperations ¶
func (v *HeuVertex) DeriveOperations()
func (*HeuVertex) GetParentVertex ¶
func (*HeuVertex) ReplaceChild ¶
func (*HeuVertex) ReplaceChildren ¶
func (*HeuVertex) ReplaceNode ¶
func (*HeuVertex) RowDataType ¶
func (v *HeuVertex) RowDataType() hybridqp.RowDataType
func (*HeuVertex) RowExprOptions ¶
func (v *HeuVertex) RowExprOptions() []hybridqp.ExprOptions
func (*HeuVertex) SubTreeEqual ¶
type HeuVertexInfo ¶
type HeuVertexInfo struct {
// contains filtered or unexported fields
}
func NewHeuVertexInfo ¶
func NewHeuVertexInfo() *HeuVertexInfo
func (*HeuVertexInfo) AddBackwardEdge ¶
func (info *HeuVertexInfo) AddBackwardEdge(edge *HeuEdge)
func (*HeuVertexInfo) AddDirectEdge ¶
func (info *HeuVertexInfo) AddDirectEdge(edge *HeuEdge)
type HeuVertexWriter ¶
type HeuVertexs ¶
type HeuVertexs []*HeuVertex
func (HeuVertexs) IndexOf ¶
func (hvs HeuVertexs) IndexOf(vertex *HeuVertex) int
type HistogramQuantileOp ¶ added in v1.3.0
type HistogramQuantileOp struct{}
func (*HistogramQuantileOp) CreateRoutine ¶ added in v1.3.0
func (c *HistogramQuantileOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type HoltWintersTransform ¶ added in v1.0.0
type HoltWintersTransform struct {
BaseProcessor
Input ChunkPort
Output ChunkPort
// contains filtered or unexported fields
}
func NewHoltWintersTransform ¶ added in v1.0.0
func NewHoltWintersTransform( inRowDataType, outRowDataType hybridqp.RowDataType, opt *query.ProcessorOptions, schema hybridqp.Catalog, ) (*HoltWintersTransform, error)
func (*HoltWintersTransform) Close ¶ added in v1.0.0
func (trans *HoltWintersTransform) Close()
func (*HoltWintersTransform) Explain ¶ added in v1.0.0
func (trans *HoltWintersTransform) Explain() []ValuePair
func (*HoltWintersTransform) GetInputNumber ¶ added in v1.0.0
func (trans *HoltWintersTransform) GetInputNumber(port Port) int
func (*HoltWintersTransform) GetInputs ¶ added in v1.0.0
func (trans *HoltWintersTransform) GetInputs() Ports
func (*HoltWintersTransform) GetOutputNumber ¶ added in v1.0.0
func (trans *HoltWintersTransform) GetOutputNumber(port Port) int
func (*HoltWintersTransform) GetOutputs ¶ added in v1.0.0
func (trans *HoltWintersTransform) GetOutputs() Ports
func (*HoltWintersTransform) Name ¶ added in v1.0.0
func (trans *HoltWintersTransform) Name() string
type HoltWintersTransformCreator ¶ added in v1.0.0
type HoltWintersTransformCreator struct {
}
func (*HoltWintersTransformCreator) Create ¶ added in v1.0.0
func (c *HoltWintersTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type HttpChunkSender ¶
type HttpChunkSender struct {
RowChunk RowChunk
// contains filtered or unexported fields
}
func NewHttpChunkSender ¶
func NewHttpChunkSender(opt *query.ProcessorOptions) *HttpChunkSender
func (*HttpChunkSender) GenRows ¶ added in v1.3.0
func (w *HttpChunkSender) GenRows(chunk Chunk)
func (*HttpChunkSender) GetRows ¶
func (w *HttpChunkSender) GetRows(chunk Chunk) models.Rows
GetRows transfer Chunk to models.Rows
func (*HttpChunkSender) Release ¶ added in v1.1.0
func (w *HttpChunkSender) Release()
func (*HttpChunkSender) SetAbortProcessor ¶ added in v1.3.0
func (w *HttpChunkSender) SetAbortProcessor(trans AbortProcessor)
type HttpSenderHintTransform ¶
type HttpSenderHintTransform struct {
BaseProcessor
Writer *HttpChunkSender
// contains filtered or unexported fields
}
func NewHttpSenderHintTransform ¶
func NewHttpSenderHintTransform(inRowDataType hybridqp.RowDataType, schema *QuerySchema) *HttpSenderHintTransform
func (*HttpSenderHintTransform) AbortSinkTransform ¶ added in v1.3.0
func (trans *HttpSenderHintTransform) AbortSinkTransform()
func (*HttpSenderHintTransform) Close ¶
func (trans *HttpSenderHintTransform) Close()
func (*HttpSenderHintTransform) Explain ¶
func (trans *HttpSenderHintTransform) Explain() []ValuePair
func (*HttpSenderHintTransform) GetInputNumber ¶
func (trans *HttpSenderHintTransform) GetInputNumber(_ Port) int
func (*HttpSenderHintTransform) GetInputs ¶
func (trans *HttpSenderHintTransform) GetInputs() Ports
func (*HttpSenderHintTransform) GetOutputNumber ¶
func (trans *HttpSenderHintTransform) GetOutputNumber(_ Port) int
func (*HttpSenderHintTransform) GetOutputs ¶
func (trans *HttpSenderHintTransform) GetOutputs() Ports
func (*HttpSenderHintTransform) Name ¶
func (trans *HttpSenderHintTransform) Name() string
func (*HttpSenderHintTransform) SetDag ¶ added in v1.3.0
func (trans *HttpSenderHintTransform) SetDag(dag *TransformDag)
func (*HttpSenderHintTransform) SetVertex ¶ added in v1.3.0
func (trans *HttpSenderHintTransform) SetVertex(vertex *TransformVertex)
func (*HttpSenderHintTransform) Visit ¶ added in v1.3.0
func (trans *HttpSenderHintTransform) Visit(vertex *TransformVertex) TransformVertexVisitor
type HttpSenderHintTransformCreator ¶
type HttpSenderHintTransformCreator struct {
}
func (*HttpSenderHintTransformCreator) Create ¶
func (c *HttpSenderHintTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type HttpSenderTransform ¶
type HttpSenderTransform struct {
BaseProcessor
Sender *http.ResponseWriter
Writer *HttpChunkSender
// contains filtered or unexported fields
}
func NewHttpSenderTransform ¶
func NewHttpSenderTransform(inRowDataType hybridqp.RowDataType, schema *QuerySchema) *HttpSenderTransform
func (*HttpSenderTransform) AbortSinkTransform ¶ added in v1.3.0
func (trans *HttpSenderTransform) AbortSinkTransform()
func (*HttpSenderTransform) Close ¶
func (trans *HttpSenderTransform) Close()
func (*HttpSenderTransform) Explain ¶
func (trans *HttpSenderTransform) Explain() []ValuePair
func (*HttpSenderTransform) GetInputNumber ¶
func (trans *HttpSenderTransform) GetInputNumber(_ Port) int
func (*HttpSenderTransform) GetInputs ¶
func (trans *HttpSenderTransform) GetInputs() Ports
func (*HttpSenderTransform) GetOutputNumber ¶
func (trans *HttpSenderTransform) GetOutputNumber(_ Port) int
func (*HttpSenderTransform) GetOutputs ¶
func (trans *HttpSenderTransform) GetOutputs() Ports
func (*HttpSenderTransform) Name ¶
func (trans *HttpSenderTransform) Name() string
func (*HttpSenderTransform) Release ¶ added in v1.1.0
func (trans *HttpSenderTransform) Release() error
func (*HttpSenderTransform) SetDag ¶ added in v1.3.0
func (trans *HttpSenderTransform) SetDag(dag *TransformDag)
func (*HttpSenderTransform) SetVertex ¶ added in v1.3.0
func (trans *HttpSenderTransform) SetVertex(vertex *TransformVertex)
func (*HttpSenderTransform) Visit ¶ added in v1.3.0
func (trans *HttpSenderTransform) Visit(vertex *TransformVertex) TransformVertexVisitor
type HttpSenderTransformCreator ¶
type HttpSenderTransformCreator struct {
}
func (*HttpSenderTransformCreator) Create ¶
func (c *HttpSenderTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type IncAggEntry ¶ added in v1.2.0
type IncAggEntry struct {
// contains filtered or unexported fields
}
func NewIncAggEntry ¶ added in v1.2.0
func NewIncAggEntry(queryID string) *IncAggEntry
func (*IncAggEntry) GetKey ¶ added in v1.2.0
func (e *IncAggEntry) GetKey() string
func (*IncAggEntry) GetTime ¶ added in v1.2.0
func (e *IncAggEntry) GetTime() time.Time
func (*IncAggEntry) GetValue ¶ added in v1.2.0
func (e *IncAggEntry) GetValue() interface{}
func (*IncAggEntry) SetTime ¶ added in v1.2.0
func (e *IncAggEntry) SetTime(time time.Time)
func (*IncAggEntry) SetValue ¶ added in v1.2.0
func (e *IncAggEntry) SetValue(value interface{})
func (*IncAggEntry) Size ¶ added in v1.2.0
func (e *IncAggEntry) Size() int64
type IncAggItem ¶ added in v1.2.0
type IncAggItem struct {
// contains filtered or unexported fields
}
func NewIncAggIterm ¶ added in v1.2.0
func NewIncAggIterm(iterID int32, value Chunk) *IncAggItem
type IncAggRule ¶ added in v1.2.0
type IncAggRule struct {
OptRuleBase
}
func NewIncAggRule ¶ added in v1.2.0
func NewIncAggRule(description string) *IncAggRule
func (*IncAggRule) Catagory ¶ added in v1.2.0
func (r *IncAggRule) Catagory() OptRuleCatagory
func (*IncAggRule) Equals ¶ added in v1.2.0
func (r *IncAggRule) Equals(rhs OptRule) bool
func (*IncAggRule) OnMatch ¶ added in v1.2.0
func (r *IncAggRule) OnMatch(call *OptRuleCall)
func (*IncAggRule) ToString ¶ added in v1.2.0
func (r *IncAggRule) ToString() string
type IncAggTransform ¶ added in v1.2.0
type IncAggTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
// contains filtered or unexported fields
}
func NewIncAggTransform ¶ added in v1.2.0
func NewIncAggTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, ops []hybridqp.ExprOptions, opt *query.ProcessorOptions) (*IncAggTransform, error)
func (*IncAggTransform) Close ¶ added in v1.2.0
func (trans *IncAggTransform) Close()
func (*IncAggTransform) Explain ¶ added in v1.2.0
func (trans *IncAggTransform) Explain() []ValuePair
func (*IncAggTransform) GetIndex ¶ added in v1.2.0
func (trans *IncAggTransform) GetIndex(t int64) int64
func (*IncAggTransform) GetInputNumber ¶ added in v1.2.0
func (trans *IncAggTransform) GetInputNumber(port Port) int
func (*IncAggTransform) GetInputs ¶ added in v1.2.0
func (trans *IncAggTransform) GetInputs() Ports
func (*IncAggTransform) GetOutputNumber ¶ added in v1.2.0
func (trans *IncAggTransform) GetOutputNumber(port Port) int
func (*IncAggTransform) GetOutputs ¶ added in v1.2.0
func (trans *IncAggTransform) GetOutputs() Ports
func (*IncAggTransform) Name ¶ added in v1.2.0
func (trans *IncAggTransform) Name() string
type IncAggTransformCreator ¶ added in v1.2.0
type IncAggTransformCreator struct {
}
func (*IncAggTransformCreator) Create ¶ added in v1.2.0
func (c *IncAggTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type IncHashAggEntry ¶ added in v1.2.0
type IncHashAggEntry struct {
// contains filtered or unexported fields
}
func NewIncHashAggEntry ¶ added in v1.2.0
func NewIncHashAggEntry(queryID string) *IncHashAggEntry
func (*IncHashAggEntry) GetKey ¶ added in v1.2.0
func (e *IncHashAggEntry) GetKey() string
func (*IncHashAggEntry) GetTime ¶ added in v1.2.0
func (e *IncHashAggEntry) GetTime() time.Time
func (*IncHashAggEntry) GetValue ¶ added in v1.2.0
func (e *IncHashAggEntry) GetValue() interface{}
func (*IncHashAggEntry) SetTime ¶ added in v1.2.0
func (e *IncHashAggEntry) SetTime(time time.Time)
func (*IncHashAggEntry) SetValue ¶ added in v1.2.0
func (e *IncHashAggEntry) SetValue(value interface{})
func (*IncHashAggEntry) Size ¶ added in v1.2.0
func (e *IncHashAggEntry) Size() int64
type IncHashAggItem ¶ added in v1.2.0
type IncHashAggItem struct {
// contains filtered or unexported fields
}
func GetIncHashAggItem ¶ added in v1.2.0
func GetIncHashAggItem(queryID string, iterID int32) (*IncHashAggItem, bool)
func NewIncHashAggItem ¶ added in v1.2.0
func NewIncHashAggItem(iterID int32, chunks []Chunk) *IncHashAggItem
func (*IncHashAggItem) AppendGroupIdx ¶ added in v1.2.0
func (item *IncHashAggItem) AppendGroupIdx(groupIdx uint32)
func (*IncHashAggItem) GetGroupIds ¶ added in v1.2.0
func (item *IncHashAggItem) GetGroupIds(tag []byte) int
func (*IncHashAggItem) Size ¶ added in v1.2.0
func (item *IncHashAggItem) Size() int64
func (*IncHashAggItem) UpdateChunkAndIterID ¶ added in v1.2.0
func (item *IncHashAggItem) UpdateChunkAndIterID(iterID int32, chunks []Chunk)
type IncHashAggRule ¶ added in v1.2.0
type IncHashAggRule struct {
OptRuleBase
}
func NewIncHashAggRule ¶ added in v1.2.0
func NewIncHashAggRule(description string) *IncHashAggRule
func (*IncHashAggRule) Catagory ¶ added in v1.2.0
func (r *IncHashAggRule) Catagory() OptRuleCatagory
func (*IncHashAggRule) Equals ¶ added in v1.2.0
func (r *IncHashAggRule) Equals(rhs OptRule) bool
func (*IncHashAggRule) OnMatch ¶ added in v1.2.0
func (r *IncHashAggRule) OnMatch(call *OptRuleCall)
func (*IncHashAggRule) ToString ¶ added in v1.2.0
func (r *IncHashAggRule) ToString() string
type IncHashAggTransform ¶ added in v1.2.0
type IncHashAggTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
// contains filtered or unexported fields
}
func NewIncHashAggTransform ¶ added in v1.2.0
func NewIncHashAggTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, ops []hybridqp.ExprOptions, opt *query.ProcessorOptions) (*IncHashAggTransform, error)
func (*IncHashAggTransform) Close ¶ added in v1.2.0
func (trans *IncHashAggTransform) Close()
func (*IncHashAggTransform) Explain ¶ added in v1.2.0
func (trans *IncHashAggTransform) Explain() []ValuePair
func (*IncHashAggTransform) GetIndex ¶ added in v1.2.0
func (trans *IncHashAggTransform) GetIndex(t int64) int64
func (*IncHashAggTransform) GetInputNumber ¶ added in v1.2.0
func (trans *IncHashAggTransform) GetInputNumber(port Port) int
func (*IncHashAggTransform) GetInputs ¶ added in v1.2.0
func (trans *IncHashAggTransform) GetInputs() Ports
func (*IncHashAggTransform) GetOutputNumber ¶ added in v1.2.0
func (trans *IncHashAggTransform) GetOutputNumber(port Port) int
func (*IncHashAggTransform) GetOutputs ¶ added in v1.2.0
func (trans *IncHashAggTransform) GetOutputs() Ports
func (*IncHashAggTransform) Name ¶ added in v1.2.0
func (trans *IncHashAggTransform) Name() string
type IncHashAggTransformCreator ¶ added in v1.2.0
type IncHashAggTransformCreator struct {
}
func (*IncHashAggTransformCreator) Create ¶ added in v1.2.0
func (c *IncHashAggTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type IncQueryFinish ¶ added in v1.2.0
type IncQueryFinish struct {
// contains filtered or unexported fields
}
func (*IncQueryFinish) Instance ¶ added in v1.2.0
func (e *IncQueryFinish) Instance() transport.Codec
func (*IncQueryFinish) Marshal ¶ added in v1.2.0
func (e *IncQueryFinish) Marshal(buf []byte) ([]byte, error)
func (*IncQueryFinish) Size ¶ added in v1.2.0
func (e *IncQueryFinish) Size() int
func (*IncQueryFinish) Unmarshal ¶ added in v1.2.0
func (e *IncQueryFinish) Unmarshal(buf []byte) error
type IndexFrags ¶ added in v1.2.0
type IndexScanExtraInfo ¶
type IndexScanExtraInfo struct {
ShardID uint64
Req *RemoteQuery
Store hybridqp.StoreEngine
PtQuery *PtQuery
// contains filtered or unexported fields
}
func (*IndexScanExtraInfo) Clone ¶
func (e *IndexScanExtraInfo) Clone() *IndexScanExtraInfo
func (*IndexScanExtraInfo) IsPtQuery ¶ added in v1.2.0
func (e *IndexScanExtraInfo) IsPtQuery() bool
func (*IndexScanExtraInfo) Len ¶ added in v1.2.0
func (e *IndexScanExtraInfo) Len() int
func (*IndexScanExtraInfo) Next ¶ added in v1.2.0
func (e *IndexScanExtraInfo) Next() *ShardInfo
type IndexScanTransform ¶
type IndexScanTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewIndexScanTransform ¶
func NewIndexScanTransform(outRowDataType hybridqp.RowDataType, ops []hybridqp.ExprOptions, schema hybridqp.Catalog, input hybridqp.QueryNode, info *IndexScanExtraInfo, limiter chan struct{}, limit int, oneShardState bool) *IndexScanTransform
func (*IndexScanTransform) Abort ¶ added in v1.0.1
func (trans *IndexScanTransform) Abort()
func (*IndexScanTransform) BuildDownSamplePlan ¶ added in v1.0.0
func (*IndexScanTransform) BuildDownSampleSchema ¶ added in v1.0.0
func (trans *IndexScanTransform) BuildDownSampleSchema(schema hybridqp.Catalog) *QuerySchema
func (*IndexScanTransform) BuildPlan ¶ added in v1.0.0
func (trans *IndexScanTransform) BuildPlan(downSampleLevel int) (*QuerySchema, hybridqp.QueryNode, error)
func (*IndexScanTransform) CanDownSampleRewrite ¶ added in v1.0.0
func (trans *IndexScanTransform) CanDownSampleRewrite(downSampleLevel int) bool
func (*IndexScanTransform) Close ¶
func (trans *IndexScanTransform) Close()
func (*IndexScanTransform) CursorsClose ¶ added in v1.1.0
func (trans *IndexScanTransform) CursorsClose(plan hybridqp.QueryNode)
func (*IndexScanTransform) Explain ¶
func (trans *IndexScanTransform) Explain() []ValuePair
func (*IndexScanTransform) FreeResFromAllocator ¶ added in v1.0.1
func (trans *IndexScanTransform) FreeResFromAllocator()
func (*IndexScanTransform) GetInputNumber ¶
func (trans *IndexScanTransform) GetInputNumber(_ Port) int
func (*IndexScanTransform) GetInputs ¶
func (trans *IndexScanTransform) GetInputs() Ports
func (*IndexScanTransform) GetOutputNumber ¶
func (trans *IndexScanTransform) GetOutputNumber(_ Port) int
func (*IndexScanTransform) GetOutputs ¶
func (trans *IndexScanTransform) GetOutputs() Ports
func (*IndexScanTransform) GetResFromAllocator ¶ added in v1.0.1
func (trans *IndexScanTransform) GetResFromAllocator()
func (*IndexScanTransform) Interrupt ¶ added in v1.3.0
func (trans *IndexScanTransform) Interrupt()
func (*IndexScanTransform) IsSink ¶ added in v1.0.0
func (trans *IndexScanTransform) IsSink() bool
func (*IndexScanTransform) Name ¶
func (trans *IndexScanTransform) Name() string
func (*IndexScanTransform) Release ¶
func (trans *IndexScanTransform) Release() error
func (*IndexScanTransform) RewriteChunk ¶ added in v1.0.0
func (trans *IndexScanTransform) RewriteChunk(c Chunk) Chunk
func (*IndexScanTransform) Running ¶ added in v1.0.0
func (trans *IndexScanTransform) Running(ctx context.Context) bool
func (*IndexScanTransform) SetDownSampleLevel ¶ added in v1.0.0
func (trans *IndexScanTransform) SetDownSampleLevel(l int)
func (*IndexScanTransform) SetIndexScanErr ¶ added in v1.1.0
func (trans *IndexScanTransform) SetIndexScanErr(err bool)
func (*IndexScanTransform) SetPipelineExecutor ¶ added in v1.0.0
func (trans *IndexScanTransform) SetPipelineExecutor(exec *PipelineExecutor)
func (*IndexScanTransform) WorkHelper ¶ added in v1.0.0
func (trans *IndexScanTransform) WorkHelper(ctx context.Context) (error, bool)
type IndexScanTransformCreator ¶
type IndexScanTransformCreator struct {
}
func (*IndexScanTransformCreator) Create ¶
func (c *IndexScanTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type Int64AppendIterator ¶
type Int64AppendIterator struct {
// contains filtered or unexported fields
}
func NewInt64AppendIterator ¶
func NewInt64AppendIterator() *Int64AppendIterator
func (*Int64AppendIterator) Next ¶
func (f *Int64AppendIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type Int64LimitIterator ¶
type Int64LimitIterator struct {
// contains filtered or unexported fields
}
func NewInt64LimitIterator ¶
func NewInt64LimitIterator() *Int64LimitIterator
func (*Int64LimitIterator) Next ¶
func (f *Int64LimitIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type Int64MergeIterator ¶
type Int64MergeIterator struct {
BaseMergeIterator
// contains filtered or unexported fields
}
func NewInt64MergeIterator ¶
func NewInt64MergeIterator() *Int64MergeIterator
func (*Int64MergeIterator) Next ¶
func (f *Int64MergeIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type IntegerAlignIterator ¶
type IntegerAlignIterator struct{}
func NewIntegerAlignIterator ¶
func NewIntegerAlignIterator() *IntegerAlignIterator
func (*IntegerAlignIterator) Next ¶
func (f *IntegerAlignIterator) Next(endpoint *IteratorEndpoint, _ *IteratorParams)
type IntegerColFloatRateIterator ¶
type IntegerColFloatRateIterator struct {
// contains filtered or unexported fields
}
func NewIntegerRateIterator ¶ added in v1.3.0
func NewIntegerRateIterator(fn RateMiddleReduceFunc[int64], fv RateFinalReduceFunc[int64], fu RateUpdateFunc[int64], fm RateMergeFunc[int64], isSingleCall bool, inOrdinal, outOrdinal int, rowDataType hybridqp.RowDataType, interval *hybridqp.Interval, ) *IntegerColFloatRateIterator
func (*IntegerColFloatRateIterator) Next ¶
func (r *IntegerColFloatRateIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type IntegerColIntegerDistinctIterator ¶
type IntegerColIntegerDistinctIterator struct {
// contains filtered or unexported fields
}
func NewIntegerColIntegerDistinctIterator ¶
func NewIntegerColIntegerDistinctIterator( inOrdinal, outOrdinal int, ) *IntegerColIntegerDistinctIterator
func (*IntegerColIntegerDistinctIterator) Next ¶
func (r *IntegerColIntegerDistinctIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type IntegerColIntegerHeapIterator ¶
type IntegerColIntegerHeapIterator struct {
// contains filtered or unexported fields
}
func NewIntegerColIntegerHeapIterator ¶
func NewIntegerColIntegerHeapIterator( inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, IntegerHeapItem *HeapItem[int64], ) *IntegerColIntegerHeapIterator
func (*IntegerColIntegerHeapIterator) Next ¶
func (r *IntegerColIntegerHeapIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type IntegerColIntegerSampleIterator ¶
type IntegerColIntegerSampleIterator struct {
// contains filtered or unexported fields
}
func NewIntegerColIntegerSampleIterator ¶
func NewIntegerColIntegerSampleIterator(sampleNum int, isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *IntegerColIntegerSampleIterator
func (*IntegerColIntegerSampleIterator) Next ¶
func (r *IntegerColIntegerSampleIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type IntegerColIntegerSliceIterator ¶
type IntegerColIntegerSliceIterator struct {
// contains filtered or unexported fields
}
func NewIntegerColIntegerSliceIterator ¶
func NewIntegerColIntegerSliceIterator(fn SliceReduce[int64], isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *IntegerColIntegerSliceIterator
func (*IntegerColIntegerSliceIterator) Next ¶
func (r *IntegerColIntegerSliceIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type IntegerCumulativeSumItem ¶
type IntegerCumulativeSumItem struct {
// contains filtered or unexported fields
}
func NewIntegerCumulativeSumItem ¶
func NewIntegerCumulativeSumItem() *IntegerCumulativeSumItem
func (*IntegerCumulativeSumItem) AppendItem ¶
func (f *IntegerCumulativeSumItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerCumulativeSumItem) AppendItemFastFunc ¶
func (f *IntegerCumulativeSumItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerCumulativeSumItem) AppendItemSlowFunc ¶
func (f *IntegerCumulativeSumItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerCumulativeSumItem) GetBaseTransData ¶
func (f *IntegerCumulativeSumItem) GetBaseTransData() BaseTransData
func (*IntegerCumulativeSumItem) Len ¶
func (f *IntegerCumulativeSumItem) Len() int
func (*IntegerCumulativeSumItem) PrevNil ¶
func (f *IntegerCumulativeSumItem) PrevNil() bool
func (*IntegerCumulativeSumItem) Reset ¶
func (f *IntegerCumulativeSumItem) Reset()
func (*IntegerCumulativeSumItem) ResetPrev ¶
func (f *IntegerCumulativeSumItem) ResetPrev()
type IntegerDerivativeItem ¶
type IntegerDerivativeItem struct {
// contains filtered or unexported fields
}
func NewIntegerDerivativeItem ¶
func NewIntegerDerivativeItem(isNonNegative, ascending bool, interval hybridqp.Interval) *IntegerDerivativeItem
func (*IntegerDerivativeItem) AppendItem ¶
func (f *IntegerDerivativeItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerDerivativeItem) AppendItemFastFunc ¶
func (f *IntegerDerivativeItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerDerivativeItem) AppendItemSlowFunc ¶
func (f *IntegerDerivativeItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerDerivativeItem) GetBaseTransData ¶
func (f *IntegerDerivativeItem) GetBaseTransData() BaseTransData
func (*IntegerDerivativeItem) Len ¶
func (f *IntegerDerivativeItem) Len() int
func (*IntegerDerivativeItem) PrevNil ¶
func (f *IntegerDerivativeItem) PrevNil() bool
func (*IntegerDerivativeItem) Reset ¶
func (f *IntegerDerivativeItem) Reset()
func (*IntegerDerivativeItem) ResetPrev ¶
func (f *IntegerDerivativeItem) ResetPrev()
type IntegerDifferenceItem ¶
type IntegerDifferenceItem struct {
// contains filtered or unexported fields
}
func NewIntegerDifferenceItem ¶
func NewIntegerDifferenceItem(isNonNegative bool, diff integerDifference) *IntegerDifferenceItem
func (*IntegerDifferenceItem) AppendItem ¶
func (f *IntegerDifferenceItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerDifferenceItem) AppendItemFastFunc ¶
func (f *IntegerDifferenceItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerDifferenceItem) AppendItemSlowFunc ¶
func (f *IntegerDifferenceItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerDifferenceItem) GetBaseTransData ¶
func (f *IntegerDifferenceItem) GetBaseTransData() BaseTransData
func (*IntegerDifferenceItem) Len ¶
func (f *IntegerDifferenceItem) Len() int
func (*IntegerDifferenceItem) PrevNil ¶
func (f *IntegerDifferenceItem) PrevNil() bool
func (*IntegerDifferenceItem) Reset ¶
func (f *IntegerDifferenceItem) Reset()
func (*IntegerDifferenceItem) ResetPrev ¶
func (f *IntegerDifferenceItem) ResetPrev()
type IntegerFieldValuer ¶ added in v1.0.0
type IntegerFieldValuer struct {
// contains filtered or unexported fields
}
type IntegerIntegralIterator ¶ added in v1.3.0
type IntegerIntegralIterator struct {
// contains filtered or unexported fields
}
func NewIntegerIntegralIterator ¶ added in v1.3.0
func NewIntegerIntegralIterator( isSingleCall bool, inOrdinal, outOrdinal int, interval hybridqp.Interval, opt *query.ProcessorOptions, ) *IntegerIntegralIterator
func (*IntegerIntegralIterator) Next ¶ added in v1.3.0
func (r *IntegerIntegralIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type IntegerIntervalIterator ¶
type IntegerIntervalIterator struct{}
func NewIntegerIntervalIterator ¶
func NewIntegerIntervalIterator() *IntegerIntervalIterator
func (*IntegerIntervalIterator) Next ¶
func (f *IntegerIntervalIterator) Next(endpoint *IteratorEndpoint, _ *IteratorParams)
type IntegerIterator ¶ added in v1.3.0
type IntegerIterator struct {
// contains filtered or unexported fields
}
func NewIntegerIterator ¶ added in v1.3.0
func NewIntegerIterator(fn ColReduceFunc[int64], fv ColMergeFunc[int64], isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *IntegerIterator
func (*IntegerIterator) Next ¶ added in v1.3.0
func (r *IntegerIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type IntegerLinearFillProcessor ¶
type IntegerLinearFillProcessor struct {
// contains filtered or unexported fields
}
func NewIntegerLinearFillProcessor ¶
func NewIntegerLinearFillProcessor(inOrdinal, outOrdinal int) *IntegerLinearFillProcessor
type IntegerMovingAverageItem ¶
type IntegerMovingAverageItem struct {
// contains filtered or unexported fields
}
func NewIntegerMovingAverageItem ¶
func NewIntegerMovingAverageItem(n int) *IntegerMovingAverageItem
func (*IntegerMovingAverageItem) AppendItem ¶
func (f *IntegerMovingAverageItem) AppendItem(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerMovingAverageItem) AppendItemFastFunc ¶
func (f *IntegerMovingAverageItem) AppendItemFastFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerMovingAverageItem) AppendItemSlowFunc ¶
func (f *IntegerMovingAverageItem) AppendItemSlowFunc(c Chunk, ordinal int, start, end int, sameInterval bool)
func (*IntegerMovingAverageItem) GetBaseTransData ¶
func (f *IntegerMovingAverageItem) GetBaseTransData() BaseTransData
func (*IntegerMovingAverageItem) Len ¶
func (f *IntegerMovingAverageItem) Len() int
func (*IntegerMovingAverageItem) PrevNil ¶
func (f *IntegerMovingAverageItem) PrevNil() bool
func (*IntegerMovingAverageItem) Reset ¶
func (f *IntegerMovingAverageItem) Reset()
func (*IntegerMovingAverageItem) ResetPrev ¶
func (f *IntegerMovingAverageItem) ResetPrev()
type IntegerNullFillProcessor ¶
type IntegerNullFillProcessor struct {
// contains filtered or unexported fields
}
func NewIntegerNullFillProcessor ¶
func NewIntegerNullFillProcessor(inOrdinal, outOrdinal int) *IntegerNullFillProcessor
type IntegerNumberFillProcessor ¶
type IntegerNumberFillProcessor struct {
// contains filtered or unexported fields
}
func NewIntegerNumberFillProcessor ¶
func NewIntegerNumberFillProcessor(inOrdinal, outOrdinal int) *IntegerNumberFillProcessor
type IntegerOGSketchInsertItem ¶ added in v1.0.0
type IntegerOGSketchInsertItem struct {
// contains filtered or unexported fields
}
func NewIntegerOGSketchInsertIem ¶ added in v1.0.0
func NewIntegerOGSketchInsertIem(isSingleCall bool, inOrdinal, outOrdinal, clusterNum int, percentile float64) *IntegerOGSketchInsertItem
func (*IntegerOGSketchInsertItem) IsNil ¶ added in v1.0.0
func (o *IntegerOGSketchInsertItem) IsNil() bool
func (*IntegerOGSketchInsertItem) Reset ¶ added in v1.0.0
func (o *IntegerOGSketchInsertItem) Reset()
func (*IntegerOGSketchInsertItem) UpdateCluster ¶ added in v1.0.0
func (o *IntegerOGSketchInsertItem) UpdateCluster(inChunk Chunk, start, end int)
func (*IntegerOGSketchInsertItem) WriteResult ¶ added in v1.0.0
func (o *IntegerOGSketchInsertItem) WriteResult(outChunk Chunk, time int64)
type IntegerOGSketchPercentileItem ¶ added in v1.0.0
type IntegerOGSketchPercentileItem struct {
// contains filtered or unexported fields
}
func NewIntegerOGSketchPercentileItem ¶ added in v1.0.0
func NewIntegerOGSketchPercentileItem(isSingleCall bool, inOrdinal, outOrdinal, clusterNum int, percentile float64) *IntegerOGSketchPercentileItem
func (*IntegerOGSketchPercentileItem) IsNil ¶ added in v1.0.0
func (o *IntegerOGSketchPercentileItem) IsNil() bool
func (*IntegerOGSketchPercentileItem) Reset ¶ added in v1.0.0
func (o *IntegerOGSketchPercentileItem) Reset()
func (*IntegerOGSketchPercentileItem) UpdateCluster ¶ added in v1.0.0
func (o *IntegerOGSketchPercentileItem) UpdateCluster(inChunk Chunk, start, end int)
func (*IntegerOGSketchPercentileItem) WriteResult ¶ added in v1.0.0
func (o *IntegerOGSketchPercentileItem) WriteResult(outChunk Chunk, time int64)
type IntegerPercentileApproxItem ¶ added in v1.0.0
type IntegerPercentileApproxItem struct {
// contains filtered or unexported fields
}
func NewIntegerPercentileApproxItem ¶ added in v1.0.0
func NewIntegerPercentileApproxItem(isSingleCall bool, inOrdinal, outOrdinal, clusterNum int, percentile float64) *IntegerPercentileApproxItem
func (*IntegerPercentileApproxItem) IsNil ¶ added in v1.0.0
func (o *IntegerPercentileApproxItem) IsNil() bool
func (*IntegerPercentileApproxItem) Reset ¶ added in v1.0.0
func (o *IntegerPercentileApproxItem) Reset()
func (*IntegerPercentileApproxItem) UpdateCluster ¶ added in v1.0.0
func (o *IntegerPercentileApproxItem) UpdateCluster(inChunk Chunk, start, end int)
func (*IntegerPercentileApproxItem) WriteResult ¶ added in v1.0.0
func (o *IntegerPercentileApproxItem) WriteResult(outChunk Chunk, time int64)
type IntegerPreviousFillProcessor ¶
type IntegerPreviousFillProcessor struct {
// contains filtered or unexported fields
}
func NewIntegerPreviousFillProcessor ¶
func NewIntegerPreviousFillProcessor(inOrdinal, outOrdinal int) *IntegerPreviousFillProcessor
type IntegerTimeColIntegerIterator ¶
type IntegerTimeColIntegerIterator struct {
// contains filtered or unexported fields
}
func NewIntegerTimeColIntegerIterator ¶
func NewIntegerTimeColIntegerIterator( fn TimeColReduceFunc[int64], fv ColMergeFunc[int64], inOrdinal, outOrdinal int, ) *IntegerTimeColIntegerIterator
func (*IntegerTimeColIntegerIterator) Next ¶
func (r *IntegerTimeColIntegerIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type IntegerTransIterator ¶ added in v1.3.0
type IntegerTransIterator struct {
// contains filtered or unexported fields
}
func NewIntegerTransIterator ¶ added in v1.3.0
func NewIntegerTransIterator( isSingleCall bool, inOrdinal, outOrdinal int, transItem TransItem, ) *IntegerTransIterator
func (*IntegerTransIterator) Next ¶ added in v1.3.0
func (r *IntegerTransIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type IntegralItem ¶ added in v1.3.0
type IntegralItem[T util.NumberOnly] struct { // contains filtered or unexported fields }
func NewIntegralItem ¶ added in v1.3.0
func NewIntegralItem[T util.NumberOnly](interval hybridqp.Interval, opt *query.ProcessorOptions) *IntegralItem[T]
func (*IntegralItem[T]) AppendItem ¶ added in v1.3.0
func (f *IntegralItem[T]) AppendItem(c Chunk, values []T, ordinal int, start, end int, sameInterval, sameTag bool)
func (*IntegralItem[T]) AppendItemFastFunc ¶ added in v1.3.0
func (f *IntegralItem[T]) AppendItemFastFunc(c Chunk, values []T, start, end int, sameInterval bool, sameTag bool)
func (*IntegralItem[T]) AppendItemSlowFunc ¶ added in v1.3.0
func (f *IntegralItem[T]) AppendItemSlowFunc(c Chunk, values []T, ordinal int, vs, ve int, sameInterval, sameTag bool)
func (*IntegralItem[T]) CalculateUnit ¶ added in v1.3.0
func (f *IntegralItem[T]) CalculateUnit(index int, time int64, value float64)
func (*IntegralItem[T]) Len ¶ added in v1.3.0
func (f *IntegralItem[T]) Len() int
func (*IntegralItem[T]) Nil ¶ added in v1.3.0
func (f *IntegralItem[T]) Nil() bool
func (*IntegralItem[T]) Reset ¶ added in v1.3.0
func (f *IntegralItem[T]) Reset()
func (*IntegralItem[T]) StartNewInterval ¶ added in v1.3.0
func (f *IntegralItem[T]) StartNewInterval(time int64)
type IntervalKeysMPool ¶ added in v1.1.0
type IntervalKeysMPool struct {
// contains filtered or unexported fields
}
func NewIntervalKeysMpool ¶ added in v1.1.0
func NewIntervalKeysMpool(size int) *IntervalKeysMPool
func (*IntervalKeysMPool) AllocIntervalKeys ¶ added in v1.1.0
func (gkp *IntervalKeysMPool) AllocIntervalKeys(size int) []int64
func (*IntervalKeysMPool) AllocValues ¶ added in v1.1.0
func (gkp *IntervalKeysMPool) AllocValues(size int) []uint64
func (*IntervalKeysMPool) FreeIntervalKeys ¶ added in v1.1.0
func (gkp *IntervalKeysMPool) FreeIntervalKeys(intervalKeys []int64)
func (*IntervalKeysMPool) FreeValues ¶ added in v1.1.0
func (gkp *IntervalKeysMPool) FreeValues(values []uint64)
type IntervalToProjectInSubQueryRule ¶
type IntervalToProjectInSubQueryRule struct {
OptRuleBase
}
func NewIntervalToProjectInSubQueryRule ¶
func NewIntervalToProjectInSubQueryRule(description string) *IntervalToProjectInSubQueryRule
func (*IntervalToProjectInSubQueryRule) Catagory ¶
func (r *IntervalToProjectInSubQueryRule) Catagory() OptRuleCatagory
func (*IntervalToProjectInSubQueryRule) Equals ¶
func (r *IntervalToProjectInSubQueryRule) Equals(rhs OptRule) bool
func (*IntervalToProjectInSubQueryRule) OnMatch ¶
func (r *IntervalToProjectInSubQueryRule) OnMatch(call *OptRuleCall)
func (*IntervalToProjectInSubQueryRule) ToString ¶
func (r *IntervalToProjectInSubQueryRule) ToString() string
type IntervalTransform ¶
type IntervalTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
// contains filtered or unexported fields
}
func NewIntervalTransform ¶
func NewIntervalTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, opt *query.ProcessorOptions) *IntervalTransform
func (*IntervalTransform) Close ¶
func (trans *IntervalTransform) Close()
func (*IntervalTransform) Explain ¶
func (trans *IntervalTransform) Explain() []ValuePair
func (*IntervalTransform) GetInputNumber ¶
func (trans *IntervalTransform) GetInputNumber(port Port) int
func (*IntervalTransform) GetInputs ¶
func (trans *IntervalTransform) GetInputs() Ports
func (*IntervalTransform) GetOutputNumber ¶
func (trans *IntervalTransform) GetOutputNumber(port Port) int
func (*IntervalTransform) GetOutputs ¶
func (trans *IntervalTransform) GetOutputs() Ports
func (*IntervalTransform) Name ¶
func (trans *IntervalTransform) Name() string
type IntervalTransformCreator ¶
type IntervalTransformCreator struct {
}
func (*IntervalTransformCreator) Create ¶
func (c *IntervalTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type Iterator ¶
type Iterator interface {
Next(*IteratorEndpoint, *IteratorParams)
}
type IteratorEndpoint ¶
type IteratorEndpoint struct {
InputPoint EndPointPair
OutputPoint EndPointPair
}
type IteratorParams ¶
type IteratorParams struct {
Table ReflectionTable
// contains filtered or unexported fields
}
func (*IteratorParams) GetErr ¶ added in v1.0.0
func (i *IteratorParams) GetErr() error
type LabelFunction ¶ added in v1.3.0
type LabelValuer ¶ added in v1.3.0
type LabelValuer struct{}
valuer
func (LabelValuer) Call ¶ added in v1.3.0
func (v LabelValuer) Call(name string, args []interface{}) (interface{}, bool)
func (LabelValuer) SetValuer ¶ added in v1.3.0
func (LabelValuer) SetValuer(_ influxql.Valuer, _ int)
func (LabelValuer) Value ¶ added in v1.3.0
func (LabelValuer) Value(_ string) (interface{}, bool)
type LimitPushdownToExchangeRule ¶
type LimitPushdownToExchangeRule struct {
OptRuleBase
}
func NewLimitPushdownToExchangeRule ¶
func NewLimitPushdownToExchangeRule(description string) *LimitPushdownToExchangeRule
func (*LimitPushdownToExchangeRule) Catagory ¶
func (r *LimitPushdownToExchangeRule) Catagory() OptRuleCatagory
func (*LimitPushdownToExchangeRule) Equals ¶
func (r *LimitPushdownToExchangeRule) Equals(rhs OptRule) bool
func (*LimitPushdownToExchangeRule) OnMatch ¶
func (r *LimitPushdownToExchangeRule) OnMatch(call *OptRuleCall)
func (*LimitPushdownToExchangeRule) ToString ¶
func (r *LimitPushdownToExchangeRule) ToString() string
type LimitPushdownToReaderRule ¶
type LimitPushdownToReaderRule struct {
OptRuleBase
}
func NewLimitPushdownToReaderRule ¶
func NewLimitPushdownToReaderRule(description string) *LimitPushdownToReaderRule
func (*LimitPushdownToReaderRule) Catagory ¶
func (r *LimitPushdownToReaderRule) Catagory() OptRuleCatagory
func (*LimitPushdownToReaderRule) Equals ¶
func (r *LimitPushdownToReaderRule) Equals(rhs OptRule) bool
func (*LimitPushdownToReaderRule) OnMatch ¶
func (r *LimitPushdownToReaderRule) OnMatch(call *OptRuleCall)
func (*LimitPushdownToReaderRule) ToString ¶
func (r *LimitPushdownToReaderRule) ToString() string
type LimitPushdownToSeriesRule ¶
type LimitPushdownToSeriesRule struct {
OptRuleBase
}
func NewLimitPushdownToSeriesRule ¶
func NewLimitPushdownToSeriesRule(description string) *LimitPushdownToSeriesRule
func (*LimitPushdownToSeriesRule) Catagory ¶
func (r *LimitPushdownToSeriesRule) Catagory() OptRuleCatagory
func (*LimitPushdownToSeriesRule) Equals ¶
func (r *LimitPushdownToSeriesRule) Equals(rhs OptRule) bool
func (*LimitPushdownToSeriesRule) OnMatch ¶
func (r *LimitPushdownToSeriesRule) OnMatch(call *OptRuleCall)
func (*LimitPushdownToSeriesRule) ToString ¶
func (r *LimitPushdownToSeriesRule) ToString() string
type LimitTransform ¶
type LimitTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
Opt *query.ProcessorOptions
Count int
PreTag ChunkTags
CurrItem Chunk
NewChunk Chunk
CoProcessor CoProcessor
ChunkInit bool
LimitHelper func()
TagIndex int
IntervalIndex int
// contains filtered or unexported fields
}
func NewLimitTransform ¶
func NewLimitTransform(inRowDataType []hybridqp.RowDataType, outRowDataType []hybridqp.RowDataType, opt *query.ProcessorOptions, para LimitTransformParameters) *LimitTransform
func (*LimitTransform) AppendPoint ¶
func (trans *LimitTransform) AppendPoint(chunk Chunk, in int)
func (*LimitTransform) AppendPoints ¶
func (trans *LimitTransform) AppendPoints(chunk Chunk, in int)
func (*LimitTransform) Close ¶
func (trans *LimitTransform) Close()
func (*LimitTransform) Explain ¶
func (trans *LimitTransform) Explain() []ValuePair
func (*LimitTransform) GetInputNumber ¶
func (trans *LimitTransform) GetInputNumber(port Port) int
func (*LimitTransform) GetInputs ¶
func (trans *LimitTransform) GetInputs() Ports
func (*LimitTransform) GetMultiRowsIndexPara ¶
func (trans *LimitTransform) GetMultiRowsIndexPara() int
func (*LimitTransform) GetOutputNumber ¶
func (trans *LimitTransform) GetOutputNumber(port Port) int
func (*LimitTransform) GetOutputs ¶
func (trans *LimitTransform) GetOutputs() Ports
func (*LimitTransform) GetSingleRowPara ¶
func (trans *LimitTransform) GetSingleRowPara() int
func (*LimitTransform) IntervalIndexGen ¶
func (trans *LimitTransform) IntervalIndexGen()
func (*LimitTransform) MultipleRowsIgnoreTagLimitHelper ¶
func (trans *LimitTransform) MultipleRowsIgnoreTagLimitHelper()
func (*LimitTransform) MultipleRowsLimitHelper ¶
func (trans *LimitTransform) MultipleRowsLimitHelper()
func (*LimitTransform) Name ¶
func (trans *LimitTransform) Name() string
func (*LimitTransform) SameGroup ¶
func (trans *LimitTransform) SameGroup(i int) bool
func (*LimitTransform) SendChunk ¶
func (trans *LimitTransform) SendChunk()
func (*LimitTransform) SetDag ¶
func (trans *LimitTransform) SetDag(dag *TransformDag)
func (*LimitTransform) SetVertex ¶
func (trans *LimitTransform) SetVertex(vertex *TransformVertex)
func (*LimitTransform) SingleRowIgnoreTagLimitHelper ¶
func (trans *LimitTransform) SingleRowIgnoreTagLimitHelper()
func (*LimitTransform) SingleRowLimitHelper ¶
func (trans *LimitTransform) SingleRowLimitHelper()
func (*LimitTransform) Visit ¶
func (trans *LimitTransform) Visit(vertex *TransformVertex) TransformVertexVisitor
type LimitTransformCreator ¶
type LimitTransformCreator struct {
}
func (*LimitTransformCreator) Create ¶
func (c *LimitTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type LogicalAggregate ¶
type LogicalAggregate struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewCountDistinctAggregate ¶
func NewCountDistinctAggregate(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalAggregate
func NewLogicalAggregate ¶
func NewLogicalAggregate(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalAggregate
func NewLogicalTagSetAggregate ¶
func NewLogicalTagSetAggregate(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalAggregate
func (*LogicalAggregate) Clone ¶
func (p *LogicalAggregate) Clone() hybridqp.QueryNode
func (*LogicalAggregate) CountToSum ¶
func (p *LogicalAggregate) CountToSum()
func (*LogicalAggregate) DeriveOperations ¶
func (p *LogicalAggregate) DeriveOperations()
func (*LogicalAggregate) Digest ¶
func (p *LogicalAggregate) Digest() string
func (*LogicalAggregate) Explain ¶
func (p *LogicalAggregate) Explain(writer LogicalPlanWriter)
func (*LogicalAggregate) ForwardCallArgs ¶
func (p *LogicalAggregate) ForwardCallArgs()
func (*LogicalAggregate) LogicPlanType ¶ added in v1.0.0
func (p *LogicalAggregate) LogicPlanType() internal.LogicPlanType
func (*LogicalAggregate) String ¶
func (p *LogicalAggregate) String() string
func (*LogicalAggregate) Type ¶
func (p *LogicalAggregate) Type() string
type LogicalAlign ¶
type LogicalAlign struct {
LogicalPlanSingle
}
func NewLogicalAlign ¶
func NewLogicalAlign(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalAlign
func (*LogicalAlign) Clone ¶
func (p *LogicalAlign) Clone() hybridqp.QueryNode
func (*LogicalAlign) DeriveOperations ¶
func (p *LogicalAlign) DeriveOperations()
func (*LogicalAlign) Digest ¶
func (p *LogicalAlign) Digest() string
func (*LogicalAlign) Explain ¶
func (p *LogicalAlign) Explain(writer LogicalPlanWriter)
func (*LogicalAlign) LogicPlanType ¶ added in v1.0.0
func (p *LogicalAlign) LogicPlanType() internal.LogicPlanType
func (*LogicalAlign) New ¶ added in v1.1.0
func (p *LogicalAlign) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalAlign) String ¶
func (p *LogicalAlign) String() string
func (*LogicalAlign) Type ¶
func (p *LogicalAlign) Type() string
type LogicalBinOp ¶ added in v1.3.0
type LogicalBinOp struct {
Para *influxql.BinOp
LogicalPlanBase
// contains filtered or unexported fields
}
func NewLogicalBinOp ¶ added in v1.3.0
func (*LogicalBinOp) Children ¶ added in v1.3.0
func (p *LogicalBinOp) Children() []hybridqp.QueryNode
func (*LogicalBinOp) Clone ¶ added in v1.3.0
func (p *LogicalBinOp) Clone() hybridqp.QueryNode
func (*LogicalBinOp) DeriveOperations ¶ added in v1.3.0
func (p *LogicalBinOp) DeriveOperations()
func (*LogicalBinOp) Digest ¶ added in v1.3.0
func (p *LogicalBinOp) Digest() string
func (*LogicalBinOp) Explain ¶ added in v1.3.0
func (p *LogicalBinOp) Explain(writer LogicalPlanWriter)
func (*LogicalBinOp) LogicPlanType ¶ added in v1.3.0
func (p *LogicalBinOp) LogicPlanType() internal.LogicPlanType
func (*LogicalBinOp) New ¶ added in v1.3.0
func (p *LogicalBinOp) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalBinOp) ReplaceChild ¶ added in v1.3.0
func (p *LogicalBinOp) ReplaceChild(ordinal int, child hybridqp.QueryNode)
func (*LogicalBinOp) ReplaceChildren ¶ added in v1.3.0
func (p *LogicalBinOp) ReplaceChildren(children []hybridqp.QueryNode)
func (*LogicalBinOp) String ¶ added in v1.3.0
func (p *LogicalBinOp) String() string
func (*LogicalBinOp) Type ¶ added in v1.3.0
func (p *LogicalBinOp) Type() string
type LogicalColumnStoreReader ¶ added in v1.1.0
type LogicalColumnStoreReader struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalColumnStoreReader ¶ added in v1.1.0
func NewLogicalColumnStoreReader(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalColumnStoreReader
func (*LogicalColumnStoreReader) Clone ¶ added in v1.1.0
func (p *LogicalColumnStoreReader) Clone() hybridqp.QueryNode
func (*LogicalColumnStoreReader) DeriveOperations ¶ added in v1.1.0
func (p *LogicalColumnStoreReader) DeriveOperations()
func (*LogicalColumnStoreReader) Digest ¶ added in v1.1.0
func (p *LogicalColumnStoreReader) Digest() string
func (*LogicalColumnStoreReader) Explain ¶ added in v1.1.0
func (p *LogicalColumnStoreReader) Explain(writer LogicalPlanWriter)
func (*LogicalColumnStoreReader) ExplainIterms ¶ added in v1.1.0
func (p *LogicalColumnStoreReader) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalColumnStoreReader) LogicPlanType ¶ added in v1.1.0
func (p *LogicalColumnStoreReader) LogicPlanType() internal.LogicPlanType
func (*LogicalColumnStoreReader) MstName ¶ added in v1.1.0
func (p *LogicalColumnStoreReader) MstName() string
func (*LogicalColumnStoreReader) New ¶ added in v1.1.0
func (p *LogicalColumnStoreReader) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalColumnStoreReader) String ¶ added in v1.1.0
func (p *LogicalColumnStoreReader) String() string
func (*LogicalColumnStoreReader) Type ¶ added in v1.1.0
func (p *LogicalColumnStoreReader) Type() string
type LogicalDedupe ¶
type LogicalDedupe struct {
LogicalPlanSingle
}
func NewLogicalDedupe ¶
func NewLogicalDedupe(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalDedupe
NewLogicalDedupe unused
func (*LogicalDedupe) Clone ¶
func (p *LogicalDedupe) Clone() hybridqp.QueryNode
func (*LogicalDedupe) DeriveOperations ¶ added in v1.0.0
func (p *LogicalDedupe) DeriveOperations()
func (*LogicalDedupe) Digest ¶
func (p *LogicalDedupe) Digest() string
func (*LogicalDedupe) Explain ¶
func (p *LogicalDedupe) Explain(writer LogicalPlanWriter)
func (*LogicalDedupe) LogicPlanType ¶ added in v1.0.0
func (p *LogicalDedupe) LogicPlanType() internal.LogicPlanType
func (*LogicalDedupe) New ¶ added in v1.1.0
func (p *LogicalDedupe) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalDedupe) String ¶
func (p *LogicalDedupe) String() string
func (*LogicalDedupe) Type ¶
func (p *LogicalDedupe) Type() string
type LogicalDummyShard ¶
type LogicalDummyShard struct {
LogicalPlanBase
// contains filtered or unexported fields
}
func NewLogicalDummyShard ¶
func NewLogicalDummyShard(info comm.TSIndexInfo) *LogicalDummyShard
func (*LogicalDummyShard) Children ¶
func (p *LogicalDummyShard) Children() []hybridqp.QueryNode
func (*LogicalDummyShard) Clone ¶
func (p *LogicalDummyShard) Clone() hybridqp.QueryNode
func (*LogicalDummyShard) Digest ¶
func (p *LogicalDummyShard) Digest() string
func (*LogicalDummyShard) Explain ¶
func (p *LogicalDummyShard) Explain(writer LogicalPlanWriter)
func (*LogicalDummyShard) ExplainIterms ¶
func (p *LogicalDummyShard) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalDummyShard) GetIndexInfo ¶ added in v1.4.0
func (p *LogicalDummyShard) GetIndexInfo() comm.TSIndexInfo
func (*LogicalDummyShard) LogicPlanType ¶ added in v1.0.0
func (p *LogicalDummyShard) LogicPlanType() internal.LogicPlanType
func (*LogicalDummyShard) New ¶ added in v1.1.0
func (p *LogicalDummyShard) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalDummyShard) ReplaceChild ¶
func (p *LogicalDummyShard) ReplaceChild(ordinal int, child hybridqp.QueryNode)
func (*LogicalDummyShard) ReplaceChildren ¶
func (p *LogicalDummyShard) ReplaceChildren(children []hybridqp.QueryNode)
func (*LogicalDummyShard) String ¶
func (p *LogicalDummyShard) String() string
func (*LogicalDummyShard) Type ¶
func (p *LogicalDummyShard) Type() string
type LogicalExchange ¶
type LogicalExchange struct {
LogicalPlanSingle
LogicalExchangeBase
}
func NewLogicalExchange ¶
func NewLogicalExchange(input hybridqp.QueryNode, eType ExchangeType, eTraits []hybridqp.Trait, schema hybridqp.Catalog) *LogicalExchange
func (*LogicalExchange) AddTrait ¶
func (p *LogicalExchange) AddTrait(trait interface{})
func (*LogicalExchange) Clone ¶
func (p *LogicalExchange) Clone() hybridqp.QueryNode
func (*LogicalExchange) DeriveOperations ¶
func (p *LogicalExchange) DeriveOperations()
func (*LogicalExchange) Digest ¶
func (p *LogicalExchange) Digest() string
func (*LogicalExchange) Explain ¶
func (p *LogicalExchange) Explain(writer LogicalPlanWriter)
func (*LogicalExchange) ExplainIterms ¶
func (p *LogicalExchange) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalExchange) LogicPlanType ¶ added in v1.0.0
func (p *LogicalExchange) LogicPlanType() internal.LogicPlanType
func (*LogicalExchange) Schema ¶ added in v1.2.0
func (p *LogicalExchange) Schema() hybridqp.Catalog
func (*LogicalExchange) String ¶
func (p *LogicalExchange) String() string
func (*LogicalExchange) Type ¶
func (p *LogicalExchange) Type() string
type LogicalExchangeBase ¶ added in v1.2.0
type LogicalExchangeBase struct {
// contains filtered or unexported fields
}
func NewLogicalExchangeBase ¶ added in v1.2.0
func NewLogicalExchangeBase(eType ExchangeType, eRole ExchangeRole, eTraits []hybridqp.Trait) *LogicalExchangeBase
func (*LogicalExchangeBase) ERole ¶ added in v1.2.0
func (p *LogicalExchangeBase) ERole() ExchangeRole
func (*LogicalExchangeBase) ETraits ¶ added in v1.2.0
func (p *LogicalExchangeBase) ETraits() []hybridqp.Trait
func (*LogicalExchangeBase) EType ¶ added in v1.2.0
func (p *LogicalExchangeBase) EType() ExchangeType
func (*LogicalExchangeBase) ToProducer ¶ added in v1.2.0
func (p *LogicalExchangeBase) ToProducer()
type LogicalFill ¶
type LogicalFill struct {
LogicalPlanSingle
}
func NewLogicalFill ¶
func NewLogicalFill(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalFill
func (*LogicalFill) Clone ¶
func (p *LogicalFill) Clone() hybridqp.QueryNode
func (*LogicalFill) DeriveOperations ¶
func (p *LogicalFill) DeriveOperations()
func (*LogicalFill) Digest ¶
func (p *LogicalFill) Digest() string
func (*LogicalFill) Explain ¶
func (p *LogicalFill) Explain(writer LogicalPlanWriter)
func (*LogicalFill) LogicPlanType ¶ added in v1.0.0
func (p *LogicalFill) LogicPlanType() internal.LogicPlanType
func (*LogicalFill) String ¶
func (p *LogicalFill) String() string
func (*LogicalFill) Type ¶
func (p *LogicalFill) Type() string
type LogicalFilter ¶
type LogicalFilter struct {
LogicalPlanSingle
}
func NewLogicalFilter ¶
func NewLogicalFilter(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalFilter
func (*LogicalFilter) Clone ¶
func (p *LogicalFilter) Clone() hybridqp.QueryNode
func (*LogicalFilter) DeriveOperations ¶
func (p *LogicalFilter) DeriveOperations()
func (*LogicalFilter) Digest ¶
func (p *LogicalFilter) Digest() string
func (*LogicalFilter) Explain ¶
func (p *LogicalFilter) Explain(writer LogicalPlanWriter)
func (*LogicalFilter) LogicPlanType ¶ added in v1.0.0
func (p *LogicalFilter) LogicPlanType() internal.LogicPlanType
func (*LogicalFilter) New ¶ added in v1.1.0
func (p *LogicalFilter) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalFilter) String ¶
func (p *LogicalFilter) String() string
func (*LogicalFilter) Type ¶
func (p *LogicalFilter) Type() string
type LogicalFilterBlank ¶
type LogicalFilterBlank struct {
LogicalPlanSingle
}
func NewLogicalFilterBlank ¶
func NewLogicalFilterBlank(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalFilterBlank
func (*LogicalFilterBlank) Clone ¶
func (p *LogicalFilterBlank) Clone() hybridqp.QueryNode
func (*LogicalFilterBlank) DeriveOperations ¶
func (p *LogicalFilterBlank) DeriveOperations()
func (*LogicalFilterBlank) Digest ¶
func (p *LogicalFilterBlank) Digest() string
func (*LogicalFilterBlank) Explain ¶
func (p *LogicalFilterBlank) Explain(writer LogicalPlanWriter)
func (*LogicalFilterBlank) LogicPlanType ¶ added in v1.0.0
func (p *LogicalFilterBlank) LogicPlanType() internal.LogicPlanType
func (*LogicalFilterBlank) New ¶ added in v1.1.0
func (p *LogicalFilterBlank) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalFilterBlank) String ¶
func (p *LogicalFilterBlank) String() string
func (*LogicalFilterBlank) Type ¶
func (p *LogicalFilterBlank) Type() string
type LogicalFullJoin ¶ added in v1.0.0
type LogicalFullJoin struct {
LogicalPlanBase
// contains filtered or unexported fields
}
func NewLogicalFullJoin ¶ added in v1.0.0
func (*LogicalFullJoin) Children ¶ added in v1.0.0
func (p *LogicalFullJoin) Children() []hybridqp.QueryNode
func (*LogicalFullJoin) Clone ¶ added in v1.0.0
func (p *LogicalFullJoin) Clone() hybridqp.QueryNode
func (*LogicalFullJoin) DeriveOperations ¶ added in v1.0.0
func (p *LogicalFullJoin) DeriveOperations()
func (*LogicalFullJoin) Digest ¶ added in v1.0.0
func (p *LogicalFullJoin) Digest() string
func (*LogicalFullJoin) Explain ¶ added in v1.0.0
func (p *LogicalFullJoin) Explain(writer LogicalPlanWriter)
func (*LogicalFullJoin) LogicPlanType ¶ added in v1.0.0
func (p *LogicalFullJoin) LogicPlanType() internal.LogicPlanType
func (*LogicalFullJoin) New ¶ added in v1.1.0
func (p *LogicalFullJoin) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalFullJoin) ReplaceChild ¶ added in v1.0.0
func (p *LogicalFullJoin) ReplaceChild(ordinal int, child hybridqp.QueryNode)
func (*LogicalFullJoin) ReplaceChildren ¶ added in v1.0.0
func (p *LogicalFullJoin) ReplaceChildren(children []hybridqp.QueryNode)
func (*LogicalFullJoin) String ¶ added in v1.0.0
func (p *LogicalFullJoin) String() string
func (*LogicalFullJoin) Type ¶ added in v1.0.0
func (p *LogicalFullJoin) Type() string
type LogicalGroupBy ¶
type LogicalGroupBy struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalGroupBy ¶
func NewLogicalGroupBy(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalGroupBy
func (*LogicalGroupBy) Clone ¶
func (p *LogicalGroupBy) Clone() hybridqp.QueryNode
func (*LogicalGroupBy) DeriveOperations ¶
func (p *LogicalGroupBy) DeriveOperations()
func (*LogicalGroupBy) Digest ¶
func (p *LogicalGroupBy) Digest() string
func (*LogicalGroupBy) Explain ¶
func (p *LogicalGroupBy) Explain(writer LogicalPlanWriter)
func (*LogicalGroupBy) ExplainIterms ¶
func (p *LogicalGroupBy) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalGroupBy) LogicPlanType ¶ added in v1.0.0
func (p *LogicalGroupBy) LogicPlanType() internal.LogicPlanType
func (*LogicalGroupBy) New ¶ added in v1.1.0
func (p *LogicalGroupBy) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalGroupBy) String ¶
func (p *LogicalGroupBy) String() string
func (*LogicalGroupBy) Type ¶
func (p *LogicalGroupBy) Type() string
type LogicalHashAgg ¶ added in v1.1.0
type LogicalHashAgg struct {
LogicalPlanSingle
LogicalExchangeBase
// contains filtered or unexported fields
}
func NewLogicalHashAgg ¶ added in v1.1.0
func NewLogicalHashAgg(input hybridqp.QueryNode, schema hybridqp.Catalog, eType ExchangeType, eTraits []hybridqp.Trait) *LogicalHashAgg
func (*LogicalHashAgg) AddTrait ¶ added in v1.1.0
func (p *LogicalHashAgg) AddTrait(trait interface{})
func (*LogicalHashAgg) Clone ¶ added in v1.1.0
func (p *LogicalHashAgg) Clone() hybridqp.QueryNode
func (*LogicalHashAgg) CountToSum ¶ added in v1.1.0
func (p *LogicalHashAgg) CountToSum()
func (*LogicalHashAgg) DeriveOperations ¶ added in v1.1.0
func (p *LogicalHashAgg) DeriveOperations()
func (*LogicalHashAgg) Digest ¶ added in v1.1.0
func (p *LogicalHashAgg) Digest() string
func (*LogicalHashAgg) Explain ¶ added in v1.1.0
func (p *LogicalHashAgg) Explain(writer LogicalPlanWriter)
func (*LogicalHashAgg) ForwardCallArgs ¶ added in v1.1.0
func (p *LogicalHashAgg) ForwardCallArgs()
func (*LogicalHashAgg) LogicPlanType ¶ added in v1.1.0
func (p *LogicalHashAgg) LogicPlanType() internal.LogicPlanType
func (*LogicalHashAgg) Schema ¶ added in v1.2.0
func (p *LogicalHashAgg) Schema() hybridqp.Catalog
func (*LogicalHashAgg) String ¶ added in v1.1.0
func (p *LogicalHashAgg) String() string
func (*LogicalHashAgg) Type ¶ added in v1.1.0
func (p *LogicalHashAgg) Type() string
type LogicalHashMerge ¶ added in v1.1.0
type LogicalHashMerge struct {
LogicalPlanSingle
LogicalExchangeBase
}
func NewLogicalHashMerge ¶ added in v1.1.0
func NewLogicalHashMerge(input hybridqp.QueryNode, schema hybridqp.Catalog, eType ExchangeType, eTraits []hybridqp.Trait) *LogicalHashMerge
func (*LogicalHashMerge) AddTrait ¶ added in v1.1.0
func (p *LogicalHashMerge) AddTrait(trait interface{})
func (*LogicalHashMerge) Clone ¶ added in v1.1.0
func (p *LogicalHashMerge) Clone() hybridqp.QueryNode
func (*LogicalHashMerge) DeriveOperations ¶ added in v1.1.0
func (p *LogicalHashMerge) DeriveOperations()
func (*LogicalHashMerge) Digest ¶ added in v1.1.0
func (p *LogicalHashMerge) Digest() string
func (*LogicalHashMerge) Explain ¶ added in v1.1.0
func (p *LogicalHashMerge) Explain(writer LogicalPlanWriter)
func (*LogicalHashMerge) ExplainIterms ¶ added in v1.1.0
func (p *LogicalHashMerge) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalHashMerge) LogicPlanType ¶ added in v1.1.0
func (p *LogicalHashMerge) LogicPlanType() internal.LogicPlanType
func (*LogicalHashMerge) String ¶ added in v1.1.0
func (p *LogicalHashMerge) String() string
func (*LogicalHashMerge) Type ¶ added in v1.1.0
func (p *LogicalHashMerge) Type() string
type LogicalHoltWinters ¶ added in v1.0.0
type LogicalHoltWinters struct {
LogicalPlanSingle
}
func NewLogicalHoltWinters ¶ added in v1.0.0
func NewLogicalHoltWinters(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalHoltWinters
func (*LogicalHoltWinters) Clone ¶ added in v1.0.0
func (p *LogicalHoltWinters) Clone() hybridqp.QueryNode
func (*LogicalHoltWinters) DeriveOperations ¶ added in v1.0.0
func (p *LogicalHoltWinters) DeriveOperations()
func (*LogicalHoltWinters) Digest ¶ added in v1.0.0
func (p *LogicalHoltWinters) Digest() string
func (*LogicalHoltWinters) Explain ¶ added in v1.0.0
func (p *LogicalHoltWinters) Explain(writer LogicalPlanWriter)
func (*LogicalHoltWinters) LogicPlanType ¶ added in v1.0.0
func (p *LogicalHoltWinters) LogicPlanType() internal.LogicPlanType
func (*LogicalHoltWinters) New ¶ added in v1.1.0
func (p *LogicalHoltWinters) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalHoltWinters) String ¶ added in v1.0.0
func (p *LogicalHoltWinters) String() string
func (*LogicalHoltWinters) Type ¶ added in v1.0.0
func (p *LogicalHoltWinters) Type() string
type LogicalHttpSender ¶
type LogicalHttpSender struct {
LogicalPlanSingle
}
func NewLogicalHttpSender ¶
func NewLogicalHttpSender(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalHttpSender
func (*LogicalHttpSender) Clone ¶
func (p *LogicalHttpSender) Clone() hybridqp.QueryNode
func (*LogicalHttpSender) DeriveOperations ¶
func (p *LogicalHttpSender) DeriveOperations()
func (*LogicalHttpSender) Digest ¶
func (p *LogicalHttpSender) Digest() string
func (*LogicalHttpSender) Explain ¶
func (p *LogicalHttpSender) Explain(writer LogicalPlanWriter)
func (*LogicalHttpSender) LogicPlanType ¶ added in v1.0.0
func (p *LogicalHttpSender) LogicPlanType() internal.LogicPlanType
func (*LogicalHttpSender) String ¶
func (p *LogicalHttpSender) String() string
func (*LogicalHttpSender) Type ¶
func (p *LogicalHttpSender) Type() string
type LogicalHttpSenderHint ¶
type LogicalHttpSenderHint struct {
LogicalPlanSingle
}
func NewLogicalHttpSenderHint ¶
func NewLogicalHttpSenderHint(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalHttpSenderHint
func (*LogicalHttpSenderHint) Clone ¶
func (p *LogicalHttpSenderHint) Clone() hybridqp.QueryNode
func (*LogicalHttpSenderHint) DeriveOperations ¶
func (p *LogicalHttpSenderHint) DeriveOperations()
func (*LogicalHttpSenderHint) Digest ¶
func (p *LogicalHttpSenderHint) Digest() string
func (*LogicalHttpSenderHint) Explain ¶
func (p *LogicalHttpSenderHint) Explain(writer LogicalPlanWriter)
func (*LogicalHttpSenderHint) LogicPlanType ¶ added in v1.0.0
func (p *LogicalHttpSenderHint) LogicPlanType() internal.LogicPlanType
func (*LogicalHttpSenderHint) New ¶ added in v1.1.0
func (p *LogicalHttpSenderHint) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalHttpSenderHint) String ¶
func (p *LogicalHttpSenderHint) String() string
func (*LogicalHttpSenderHint) Type ¶
func (p *LogicalHttpSenderHint) Type() string
type LogicalIncAgg ¶ added in v1.2.0
type LogicalIncAgg struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalIncAgg ¶ added in v1.2.0
func NewLogicalIncAgg(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalIncAgg
func (*LogicalIncAgg) Clone ¶ added in v1.2.0
func (p *LogicalIncAgg) Clone() hybridqp.QueryNode
func (*LogicalIncAgg) CountToSum ¶ added in v1.2.0
func (p *LogicalIncAgg) CountToSum()
func (*LogicalIncAgg) DeriveOperations ¶ added in v1.2.0
func (p *LogicalIncAgg) DeriveOperations()
func (*LogicalIncAgg) Digest ¶ added in v1.2.0
func (p *LogicalIncAgg) Digest() string
func (*LogicalIncAgg) Explain ¶ added in v1.2.0
func (p *LogicalIncAgg) Explain(writer LogicalPlanWriter)
func (*LogicalIncAgg) ForwardCallArgs ¶ added in v1.2.0
func (p *LogicalIncAgg) ForwardCallArgs()
func (*LogicalIncAgg) String ¶ added in v1.2.0
func (p *LogicalIncAgg) String() string
func (*LogicalIncAgg) Type ¶ added in v1.2.0
func (p *LogicalIncAgg) Type() string
type LogicalIncHashAgg ¶ added in v1.2.0
type LogicalIncHashAgg struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalIncHashAgg ¶ added in v1.2.0
func NewLogicalIncHashAgg(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalIncHashAgg
func (*LogicalIncHashAgg) Clone ¶ added in v1.2.0
func (p *LogicalIncHashAgg) Clone() hybridqp.QueryNode
func (*LogicalIncHashAgg) CountToSum ¶ added in v1.2.0
func (p *LogicalIncHashAgg) CountToSum()
func (*LogicalIncHashAgg) DeriveOperations ¶ added in v1.2.0
func (p *LogicalIncHashAgg) DeriveOperations()
func (*LogicalIncHashAgg) Digest ¶ added in v1.2.0
func (p *LogicalIncHashAgg) Digest() string
func (*LogicalIncHashAgg) Explain ¶ added in v1.2.0
func (p *LogicalIncHashAgg) Explain(writer LogicalPlanWriter)
func (*LogicalIncHashAgg) ForwardCallArgs ¶ added in v1.2.0
func (p *LogicalIncHashAgg) ForwardCallArgs()
func (*LogicalIncHashAgg) String ¶ added in v1.2.0
func (p *LogicalIncHashAgg) String() string
func (*LogicalIncHashAgg) Type ¶ added in v1.2.0
func (p *LogicalIncHashAgg) Type() string
type LogicalIndexScan ¶
type LogicalIndexScan struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalIndexScan ¶
func NewLogicalIndexScan(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalIndexScan
func (*LogicalIndexScan) Clone ¶
func (p *LogicalIndexScan) Clone() hybridqp.QueryNode
func (*LogicalIndexScan) DeriveOperations ¶
func (p *LogicalIndexScan) DeriveOperations()
func (*LogicalIndexScan) Digest ¶
func (p *LogicalIndexScan) Digest() string
func (*LogicalIndexScan) Explain ¶
func (p *LogicalIndexScan) Explain(writer LogicalPlanWriter)
func (*LogicalIndexScan) GetOneShardState ¶ added in v1.2.0
func (p *LogicalIndexScan) GetOneShardState() bool
func (*LogicalIndexScan) LogicPlanType ¶ added in v1.0.0
func (p *LogicalIndexScan) LogicPlanType() internal.LogicPlanType
func (*LogicalIndexScan) SetOneShardState ¶ added in v1.2.0
func (p *LogicalIndexScan) SetOneShardState(enable bool)
func (*LogicalIndexScan) String ¶
func (p *LogicalIndexScan) String() string
func (*LogicalIndexScan) Type ¶
func (p *LogicalIndexScan) Type() string
type LogicalInterval ¶
type LogicalInterval struct {
LogicalPlanSingle
}
func NewLogicalInterval ¶
func NewLogicalInterval(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalInterval
func (*LogicalInterval) Clone ¶
func (p *LogicalInterval) Clone() hybridqp.QueryNode
func (*LogicalInterval) DeriveOperations ¶
func (p *LogicalInterval) DeriveOperations()
func (*LogicalInterval) Digest ¶
func (p *LogicalInterval) Digest() string
func (*LogicalInterval) Explain ¶
func (p *LogicalInterval) Explain(writer LogicalPlanWriter)
func (*LogicalInterval) LogicPlanType ¶ added in v1.0.0
func (p *LogicalInterval) LogicPlanType() internal.LogicPlanType
func (*LogicalInterval) String ¶
func (p *LogicalInterval) String() string
func (*LogicalInterval) Type ¶
func (p *LogicalInterval) Type() string
type LogicalJoin ¶ added in v1.1.0
type LogicalJoin struct {
LogicalPlanMulti
}
func NewLogicalJoin ¶ added in v1.1.0
func NewLogicalJoin(inputs []hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalJoin
func (*LogicalJoin) Clone ¶ added in v1.1.0
func (p *LogicalJoin) Clone() hybridqp.QueryNode
func (*LogicalJoin) DeriveOperations ¶ added in v1.1.0
func (p *LogicalJoin) DeriveOperations()
func (*LogicalJoin) Digest ¶ added in v1.1.0
func (p *LogicalJoin) Digest() string
func (*LogicalJoin) Explain ¶ added in v1.1.0
func (p *LogicalJoin) Explain(writer LogicalPlanWriter)
func (*LogicalJoin) LogicPlanType ¶ added in v1.1.0
func (p *LogicalJoin) LogicPlanType() internal.LogicPlanType
func (*LogicalJoin) New ¶ added in v1.1.0
func (p *LogicalJoin) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalJoin) String ¶ added in v1.1.0
func (p *LogicalJoin) String() string
func (*LogicalJoin) Type ¶ added in v1.1.0
func (p *LogicalJoin) Type() string
type LogicalLimit ¶
type LogicalLimit struct {
LimitPara LimitTransformParameters
LogicalPlanSingle
}
func NewLogicalLimit ¶
func NewLogicalLimit(input hybridqp.QueryNode, schema hybridqp.Catalog, parameters LimitTransformParameters) *LogicalLimit
func (*LogicalLimit) Clone ¶
func (p *LogicalLimit) Clone() hybridqp.QueryNode
func (*LogicalLimit) DeriveOperations ¶
func (p *LogicalLimit) DeriveOperations()
func (*LogicalLimit) Digest ¶
func (p *LogicalLimit) Digest() string
func (*LogicalLimit) Explain ¶
func (p *LogicalLimit) Explain(writer LogicalPlanWriter)
func (*LogicalLimit) ExplainIterms ¶ added in v1.2.0
func (p *LogicalLimit) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalLimit) LogicPlanType ¶ added in v1.0.0
func (p *LogicalLimit) LogicPlanType() internal.LogicPlanType
func (*LogicalLimit) String ¶
func (p *LogicalLimit) String() string
func (*LogicalLimit) Type ¶
func (p *LogicalLimit) Type() string
type LogicalMerge ¶
type LogicalMerge struct {
LogicalPlanMulti
}
func NewLogicalMerge ¶
func NewLogicalMerge(inputs []hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalMerge
func (*LogicalMerge) Clone ¶
func (p *LogicalMerge) Clone() hybridqp.QueryNode
func (*LogicalMerge) DeriveOperations ¶
func (p *LogicalMerge) DeriveOperations()
func (*LogicalMerge) Digest ¶
func (p *LogicalMerge) Digest() string
func (*LogicalMerge) Explain ¶
func (p *LogicalMerge) Explain(writer LogicalPlanWriter)
func (*LogicalMerge) LogicPlanType ¶ added in v1.0.0
func (p *LogicalMerge) LogicPlanType() internal.LogicPlanType
func (*LogicalMerge) New ¶ added in v1.1.0
func (p *LogicalMerge) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalMerge) String ¶
func (p *LogicalMerge) String() string
func (*LogicalMerge) Type ¶
func (p *LogicalMerge) Type() string
type LogicalMst ¶
type LogicalMst struct {
LogicalPlanBase
}
func NewLogicalMst ¶
func NewLogicalMst(rt hybridqp.RowDataType) *LogicalMst
func (*LogicalMst) Children ¶
func (p *LogicalMst) Children() []hybridqp.QueryNode
func (*LogicalMst) Clone ¶
func (p *LogicalMst) Clone() hybridqp.QueryNode
func (*LogicalMst) Digest ¶
func (p *LogicalMst) Digest() string
func (*LogicalMst) Dummy ¶
func (p *LogicalMst) Dummy() bool
func (*LogicalMst) Explain ¶
func (p *LogicalMst) Explain(writer LogicalPlanWriter)
func (*LogicalMst) LogicPlanType ¶ added in v1.0.0
func (p *LogicalMst) LogicPlanType() internal.LogicPlanType
func (*LogicalMst) New ¶ added in v1.1.0
func (p *LogicalMst) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalMst) ReplaceChild ¶
func (p *LogicalMst) ReplaceChild(ordinal int, child hybridqp.QueryNode)
func (*LogicalMst) ReplaceChildren ¶
func (p *LogicalMst) ReplaceChildren(children []hybridqp.QueryNode)
func (*LogicalMst) String ¶
func (p *LogicalMst) String() string
func (*LogicalMst) Type ¶
func (p *LogicalMst) Type() string
type LogicalOrderBy ¶
type LogicalOrderBy struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalOrderBy ¶
func NewLogicalOrderBy(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalOrderBy
func (*LogicalOrderBy) Clone ¶
func (p *LogicalOrderBy) Clone() hybridqp.QueryNode
func (*LogicalOrderBy) DeriveOperations ¶
func (p *LogicalOrderBy) DeriveOperations()
func (*LogicalOrderBy) Digest ¶
func (p *LogicalOrderBy) Digest() string
func (*LogicalOrderBy) Explain ¶
func (p *LogicalOrderBy) Explain(writer LogicalPlanWriter)
func (*LogicalOrderBy) ExplainIterms ¶
func (p *LogicalOrderBy) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalOrderBy) LogicPlanType ¶ added in v1.0.0
func (p *LogicalOrderBy) LogicPlanType() internal.LogicPlanType
func (*LogicalOrderBy) New ¶ added in v1.1.0
func (p *LogicalOrderBy) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalOrderBy) String ¶
func (p *LogicalOrderBy) String() string
func (*LogicalOrderBy) Type ¶
func (p *LogicalOrderBy) Type() string
type LogicalPlan ¶
type LogicalPlan interface {
hybridqp.QueryNode
Explain(LogicalPlanWriter)
Schema() hybridqp.Catalog
}
type LogicalPlanBase ¶
type LogicalPlanBase struct {
// contains filtered or unexported fields
}
func NewLogicalPlanBase ¶
func NewLogicalPlanBase(schema hybridqp.Catalog, rt hybridqp.RowDataType, ops []hybridqp.ExprOptions) *LogicalPlanBase
func (*LogicalPlanBase) ApplyTrait ¶
func (p *LogicalPlanBase) ApplyTrait(trait hybridqp.Trait)
func (*LogicalPlanBase) Children ¶ added in v1.0.0
func (p *LogicalPlanBase) Children() []hybridqp.QueryNode
func (*LogicalPlanBase) DeriveOperations ¶
func (p *LogicalPlanBase) DeriveOperations()
func (*LogicalPlanBase) Dummy ¶
func (p *LogicalPlanBase) Dummy() bool
func (*LogicalPlanBase) ExplainIterms ¶
func (p *LogicalPlanBase) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalPlanBase) ForwardInit ¶
func (p *LogicalPlanBase) ForwardInit(input hybridqp.QueryNode)
func (*LogicalPlanBase) ID ¶
func (p *LogicalPlanBase) ID() uint64
func (*LogicalPlanBase) InitRef ¶ added in v1.1.0
func (p *LogicalPlanBase) InitRef(input hybridqp.QueryNode)
func (*LogicalPlanBase) PreAggInit ¶ added in v1.0.0
func (p *LogicalPlanBase) PreAggInit()
func (*LogicalPlanBase) RowDataType ¶
func (p *LogicalPlanBase) RowDataType() hybridqp.RowDataType
func (*LogicalPlanBase) RowExprOptions ¶
func (p *LogicalPlanBase) RowExprOptions() []hybridqp.ExprOptions
func (*LogicalPlanBase) Schema ¶
func (p *LogicalPlanBase) Schema() hybridqp.Catalog
func (*LogicalPlanBase) SetInputs ¶
func (p *LogicalPlanBase) SetInputs(inputs []hybridqp.QueryNode)
func (*LogicalPlanBase) SetSchema ¶
func (p *LogicalPlanBase) SetSchema(schema hybridqp.Catalog)
func (*LogicalPlanBase) Trait ¶
func (p *LogicalPlanBase) Trait() hybridqp.Trait
type LogicalPlanBuilder ¶
type LogicalPlanBuilder interface {
Build() (hybridqp.QueryNode, error)
Push(hybridqp.QueryNode) LogicalPlanBuilder
Aggregate() LogicalPlanBuilder
SlidingWindow() LogicalPlanBuilder
CountDistinct() LogicalPlanBuilder
Limit(parameters LimitTransformParameters) LogicalPlanBuilder
Filter() LogicalPlanBuilder
Merge() LogicalPlanBuilder
Dedupe() LogicalPlanBuilder
Interval() LogicalPlanBuilder
IndexScan() LogicalPlanBuilder
FilterBlank() LogicalPlanBuilder
Fill() LogicalPlanBuilder
Reader(config.EngineType) LogicalPlanBuilder
GroupBy() LogicalPlanBuilder
OrderBy() LogicalPlanBuilder
SubQuery() LogicalPlanBuilder
TagSubset() LogicalPlanBuilder
Project() LogicalPlanBuilder
HttpSender() LogicalPlanBuilder
SplitGroup() LogicalPlanBuilder
Exchange(eType ExchangeType, eTraits []hybridqp.Trait) LogicalPlanBuilder
CreateSeriesPlan() (hybridqp.QueryNode, error)
CreateSegmentPlan(schema hybridqp.Catalog) (hybridqp.QueryNode, error)
CreateMeasurementPlan(hybridqp.QueryNode) (hybridqp.QueryNode, error)
CreateShardPlan(hybridqp.QueryNode) (hybridqp.QueryNode, error)
CreateNodePlan(hybridqp.QueryNode, []hybridqp.Trait) (hybridqp.QueryNode, error)
CreateLimit(hybridqp.QueryNode) (hybridqp.QueryNode, error)
CreateAggregate(hybridqp.QueryNode) (hybridqp.QueryNode, error)
}
type LogicalPlanBuilderImpl ¶
type LogicalPlanBuilderImpl struct {
// contains filtered or unexported fields
}
func NewLogicalPlanBuilderImpl ¶
func NewLogicalPlanBuilderImpl(schema hybridqp.Catalog) *LogicalPlanBuilderImpl
func (*LogicalPlanBuilderImpl) Aggregate ¶
func (b *LogicalPlanBuilderImpl) Aggregate() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Build ¶
func (b *LogicalPlanBuilderImpl) Build() (hybridqp.QueryNode, error)
func (*LogicalPlanBuilderImpl) CountDistinct ¶
func (b *LogicalPlanBuilderImpl) CountDistinct() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) CreateAggregate ¶
func (*LogicalPlanBuilderImpl) CreateColStoreCursorPlan ¶ added in v1.2.0
func (b *LogicalPlanBuilderImpl) CreateColStoreCursorPlan() (hybridqp.QueryNode, error)
func (*LogicalPlanBuilderImpl) CreateColStoreReaderPlan ¶ added in v1.2.0
func (*LogicalPlanBuilderImpl) CreateInterval ¶
func (*LogicalPlanBuilderImpl) CreateLimit ¶
func (*LogicalPlanBuilderImpl) CreateMeasurementPlan ¶
func (*LogicalPlanBuilderImpl) CreateNodePlan ¶
func (*LogicalPlanBuilderImpl) CreatePartitionPlan ¶ added in v1.2.0
func (*LogicalPlanBuilderImpl) CreateProject ¶
func (*LogicalPlanBuilderImpl) CreateScanPlan ¶
func (*LogicalPlanBuilderImpl) CreateSegmentPlan ¶ added in v1.1.0
func (*LogicalPlanBuilderImpl) CreateSeriesPlan ¶
func (b *LogicalPlanBuilderImpl) CreateSeriesPlan() (hybridqp.QueryNode, error)
func (*LogicalPlanBuilderImpl) CreateShardPlan ¶
func (*LogicalPlanBuilderImpl) CreateSlideWindow ¶
func (*LogicalPlanBuilderImpl) CreateSparseIndexScanPlan ¶ added in v1.1.0
func (*LogicalPlanBuilderImpl) Dedupe ¶
func (b *LogicalPlanBuilderImpl) Dedupe() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Exchange ¶
func (b *LogicalPlanBuilderImpl) Exchange(eType ExchangeType, eTraits []hybridqp.Trait) LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Fill ¶
func (b *LogicalPlanBuilderImpl) Fill() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Filter ¶
func (b *LogicalPlanBuilderImpl) Filter() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) FilterBlank ¶
func (b *LogicalPlanBuilderImpl) FilterBlank() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) GroupBy ¶
func (b *LogicalPlanBuilderImpl) GroupBy() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) HashAgg ¶ added in v1.3.0
func (b *LogicalPlanBuilderImpl) HashAgg() LogicalPlanBuilder
only use for prom for build hashAggNode
func (*LogicalPlanBuilderImpl) HashMerge ¶ added in v1.1.0
func (b *LogicalPlanBuilderImpl) HashMerge(eType ExchangeType, eTraits []hybridqp.Trait) LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) HoltWinters ¶ added in v1.0.0
func (b *LogicalPlanBuilderImpl) HoltWinters() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) HttpSender ¶
func (b *LogicalPlanBuilderImpl) HttpSender() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) HttpSenderHint ¶
func (b *LogicalPlanBuilderImpl) HttpSenderHint() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) IncAgg ¶ added in v1.2.0
func (b *LogicalPlanBuilderImpl) IncAgg() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) IncHashAgg ¶ added in v1.2.0
func (b *LogicalPlanBuilderImpl) IncHashAgg() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) IndexScan ¶
func (b *LogicalPlanBuilderImpl) IndexScan() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Interval ¶
func (b *LogicalPlanBuilderImpl) Interval() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Limit ¶
func (b *LogicalPlanBuilderImpl) Limit(para LimitTransformParameters) LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Merge ¶
func (b *LogicalPlanBuilderImpl) Merge() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) OrderBy ¶
func (b *LogicalPlanBuilderImpl) OrderBy() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Project ¶
func (b *LogicalPlanBuilderImpl) Project() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) PromSort ¶ added in v1.4.0
func (b *LogicalPlanBuilderImpl) PromSort() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) PromSubquery ¶ added in v1.3.0
func (b *LogicalPlanBuilderImpl) PromSubquery(call *influxql.PromSubCall) LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Push ¶
func (b *LogicalPlanBuilderImpl) Push(node hybridqp.QueryNode) LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Reader ¶
func (b *LogicalPlanBuilderImpl) Reader(engineType config.EngineType) LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Rewrite ¶
func (b *LogicalPlanBuilderImpl) Rewrite() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Series ¶
func (b *LogicalPlanBuilderImpl) Series() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) SlidingWindow ¶
func (b *LogicalPlanBuilderImpl) SlidingWindow() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Sort ¶ added in v1.1.0
func (b *LogicalPlanBuilderImpl) Sort() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) SparseIndexScan ¶ added in v1.1.0
func (b *LogicalPlanBuilderImpl) SparseIndexScan() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) SplitGroup ¶ added in v0.2.0
func (b *LogicalPlanBuilderImpl) SplitGroup() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) SubQuery ¶
func (b *LogicalPlanBuilderImpl) SubQuery() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) TagSetAggregate ¶
func (b *LogicalPlanBuilderImpl) TagSetAggregate() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) TagSubset ¶
func (b *LogicalPlanBuilderImpl) TagSubset() LogicalPlanBuilder
func (*LogicalPlanBuilderImpl) Target ¶ added in v1.0.0
func (b *LogicalPlanBuilderImpl) Target(mst *influxql.Measurement) LogicalPlanBuilder
type LogicalPlanMulti ¶ added in v1.0.0
type LogicalPlanMulti struct {
LogicalPlanBase
}
func (*LogicalPlanMulti) ReplaceChild ¶ added in v1.0.0
func (p *LogicalPlanMulti) ReplaceChild(ordinal int, child hybridqp.QueryNode)
func (*LogicalPlanMulti) ReplaceChildren ¶ added in v1.0.0
func (p *LogicalPlanMulti) ReplaceChildren(children []hybridqp.QueryNode)
type LogicalPlanRewriter ¶
type LogicalPlanRewriter interface {
// contains filtered or unexported methods
}
type LogicalPlanRewriterImpl ¶
type LogicalPlanRewriterImpl struct {
}
type LogicalPlanSingle ¶ added in v1.0.0
type LogicalPlanSingle struct {
LogicalPlanBase
}
func NewLogicalPlanSingle ¶ added in v1.0.0
func NewLogicalPlanSingle(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalPlanSingle
func (*LogicalPlanSingle) ReplaceChild ¶ added in v1.0.0
func (p *LogicalPlanSingle) ReplaceChild(ordinal int, child hybridqp.QueryNode)
func (*LogicalPlanSingle) ReplaceChildren ¶ added in v1.0.0
func (p *LogicalPlanSingle) ReplaceChildren(children []hybridqp.QueryNode)
func (*LogicalPlanSingle) SetHoltWintersType ¶ added in v1.1.0
func (p *LogicalPlanSingle) SetHoltWintersType(setOps bool, fields influxql.Fields)
type LogicalPlanVisitor ¶
type LogicalPlanVisitor interface {
Visit(hybridqp.QueryNode) LogicalPlanVisitor
}
type LogicalPlanWriter ¶
type LogicalPlanWriter interface {
Explain(LogicalPlan)
Item(string, interface{})
String() string
}
type LogicalPlanWriterImpl ¶
func NewLogicalPlanWriterImpl ¶
func NewLogicalPlanWriterImpl(builder *strings.Builder) *LogicalPlanWriterImpl
func (*LogicalPlanWriterImpl) Explain ¶
func (w *LogicalPlanWriterImpl) Explain(node LogicalPlan)
func (*LogicalPlanWriterImpl) ExplainChildren ¶
func (w *LogicalPlanWriterImpl) ExplainChildren(children []hybridqp.QueryNode)
func (*LogicalPlanWriterImpl) Item ¶
func (w *LogicalPlanWriterImpl) Item(term string, value interface{})
func (*LogicalPlanWriterImpl) String ¶
func (w *LogicalPlanWriterImpl) String() string
type LogicalPlaner ¶ added in v1.0.0
type LogicalPlaner interface {
RowDataType() hybridqp.RowDataType
RowExprOptions() []hybridqp.ExprOptions
SetInputs(inputs []hybridqp.QueryNode)
LogicPlanType() internal.LogicPlanType
}
type LogicalProject ¶
type LogicalProject struct {
LogicalPlanSingle
}
func NewLogicalProject ¶
func NewLogicalProject(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalProject
func (*LogicalProject) Clone ¶
func (p *LogicalProject) Clone() hybridqp.QueryNode
func (*LogicalProject) DeriveOperations ¶
func (p *LogicalProject) DeriveOperations()
func (*LogicalProject) Digest ¶
func (p *LogicalProject) Digest() string
func (*LogicalProject) Explain ¶
func (p *LogicalProject) Explain(writer LogicalPlanWriter)
func (*LogicalProject) LogicPlanType ¶ added in v1.0.0
func (p *LogicalProject) LogicPlanType() internal.LogicPlanType
func (*LogicalProject) String ¶
func (p *LogicalProject) String() string
func (*LogicalProject) Type ¶
func (p *LogicalProject) Type() string
type LogicalPromSort ¶ added in v1.4.0
type LogicalPromSort struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalPromSort ¶ added in v1.4.0
func NewLogicalPromSort(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalPromSort
func (*LogicalPromSort) Clone ¶ added in v1.4.0
func (p *LogicalPromSort) Clone() hybridqp.QueryNode
func (*LogicalPromSort) DeriveOperations ¶ added in v1.4.0
func (p *LogicalPromSort) DeriveOperations()
func (*LogicalPromSort) Digest ¶ added in v1.4.0
func (p *LogicalPromSort) Digest() string
func (*LogicalPromSort) Explain ¶ added in v1.4.0
func (p *LogicalPromSort) Explain(writer LogicalPlanWriter)
func (*LogicalPromSort) ExplainIterms ¶ added in v1.4.0
func (p *LogicalPromSort) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalPromSort) New ¶ added in v1.4.0
func (p *LogicalPromSort) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalPromSort) String ¶ added in v1.4.0
func (p *LogicalPromSort) String() string
func (*LogicalPromSort) Type ¶ added in v1.4.0
func (p *LogicalPromSort) Type() string
type LogicalPromSubquery ¶ added in v1.3.0
type LogicalPromSubquery struct {
Call *influxql.PromSubCall
LogicalPlanBase
// contains filtered or unexported fields
}
func NewLogicalPromSubquery ¶ added in v1.3.0
func NewLogicalPromSubquery(input hybridqp.QueryNode, schema hybridqp.Catalog, Call *influxql.PromSubCall) *LogicalPromSubquery
func (*LogicalPromSubquery) Children ¶ added in v1.3.0
func (p *LogicalPromSubquery) Children() []hybridqp.QueryNode
func (*LogicalPromSubquery) Clone ¶ added in v1.3.0
func (p *LogicalPromSubquery) Clone() hybridqp.QueryNode
func (*LogicalPromSubquery) DeriveOperations ¶ added in v1.3.0
func (p *LogicalPromSubquery) DeriveOperations()
func (*LogicalPromSubquery) Digest ¶ added in v1.3.0
func (p *LogicalPromSubquery) Digest() string
func (*LogicalPromSubquery) Explain ¶ added in v1.3.0
func (p *LogicalPromSubquery) Explain(writer LogicalPlanWriter)
func (*LogicalPromSubquery) LogicPlanType ¶ added in v1.3.0
func (p *LogicalPromSubquery) LogicPlanType() internal.LogicPlanType
func (*LogicalPromSubquery) New ¶ added in v1.3.0
func (p *LogicalPromSubquery) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalPromSubquery) ReplaceChild ¶ added in v1.3.0
func (p *LogicalPromSubquery) ReplaceChild(ordinal int, child hybridqp.QueryNode)
func (*LogicalPromSubquery) ReplaceChildren ¶ added in v1.3.0
func (p *LogicalPromSubquery) ReplaceChildren(children []hybridqp.QueryNode)
func (*LogicalPromSubquery) String ¶ added in v1.3.0
func (p *LogicalPromSubquery) String() string
func (*LogicalPromSubquery) Type ¶ added in v1.3.0
func (p *LogicalPromSubquery) Type() string
type LogicalReader ¶
type LogicalReader struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalReader ¶
func NewLogicalReader(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalReader
func (*LogicalReader) Clone ¶
func (p *LogicalReader) Clone() hybridqp.QueryNode
func (*LogicalReader) Cursors ¶
func (p *LogicalReader) Cursors() []interface{}
func (*LogicalReader) DeriveOperations ¶
func (p *LogicalReader) DeriveOperations()
func (*LogicalReader) Digest ¶
func (p *LogicalReader) Digest() string
func (*LogicalReader) Explain ¶
func (p *LogicalReader) Explain(writer LogicalPlanWriter)
func (*LogicalReader) ExplainIterms ¶
func (p *LogicalReader) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalReader) GetOneReaderState ¶ added in v1.1.0
func (p *LogicalReader) GetOneReaderState() bool
func (*LogicalReader) HasPreAgg ¶
func (p *LogicalReader) HasPreAgg() bool
func (*LogicalReader) LogicPlanType ¶ added in v1.0.0
func (p *LogicalReader) LogicPlanType() internal.LogicPlanType
func (*LogicalReader) MstName ¶
func (p *LogicalReader) MstName() string
func (*LogicalReader) SetCursor ¶
func (p *LogicalReader) SetCursor(cursor []interface{})
func (*LogicalReader) SetOneReaderState ¶ added in v1.1.0
func (p *LogicalReader) SetOneReaderState(state bool)
func (*LogicalReader) String ¶
func (p *LogicalReader) String() string
func (*LogicalReader) Type ¶
func (p *LogicalReader) Type() string
type LogicalSequenceAggregate ¶ added in v1.0.0
type LogicalSequenceAggregate struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalSequenceAggregate ¶ added in v1.0.0
func NewLogicalSequenceAggregate(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalSequenceAggregate
func (*LogicalSequenceAggregate) Clone ¶ added in v1.0.0
func (p *LogicalSequenceAggregate) Clone() hybridqp.QueryNode
func (*LogicalSequenceAggregate) DeriveOperations ¶ added in v1.0.0
func (p *LogicalSequenceAggregate) DeriveOperations()
func (*LogicalSequenceAggregate) Digest ¶ added in v1.0.0
func (p *LogicalSequenceAggregate) Digest() string
func (*LogicalSequenceAggregate) Explain ¶ added in v1.0.0
func (p *LogicalSequenceAggregate) Explain(writer LogicalPlanWriter)
func (*LogicalSequenceAggregate) LogicPlanType ¶ added in v1.0.0
func (p *LogicalSequenceAggregate) LogicPlanType() internal.LogicPlanType
func (*LogicalSequenceAggregate) New ¶ added in v1.1.0
func (p *LogicalSequenceAggregate) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalSequenceAggregate) String ¶ added in v1.0.0
func (p *LogicalSequenceAggregate) String() string
func (*LogicalSequenceAggregate) Type ¶ added in v1.0.0
func (p *LogicalSequenceAggregate) Type() string
type LogicalSeries ¶
type LogicalSeries struct {
LogicalPlanBase
// contains filtered or unexported fields
}
func NewLogicalSeries ¶
func NewLogicalSeries(schema hybridqp.Catalog) *LogicalSeries
func (*LogicalSeries) Children ¶
func (p *LogicalSeries) Children() []hybridqp.QueryNode
func (*LogicalSeries) Clone ¶
func (p *LogicalSeries) Clone() hybridqp.QueryNode
func (*LogicalSeries) DeriveOperations ¶
func (p *LogicalSeries) DeriveOperations()
func (*LogicalSeries) Digest ¶
func (p *LogicalSeries) Digest() string
func (*LogicalSeries) Explain ¶
func (p *LogicalSeries) Explain(writer LogicalPlanWriter)
func (*LogicalSeries) ExplainIterms ¶
func (p *LogicalSeries) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalSeries) LogicPlanType ¶ added in v1.0.0
func (p *LogicalSeries) LogicPlanType() internal.LogicPlanType
func (*LogicalSeries) ReplaceChild ¶
func (p *LogicalSeries) ReplaceChild(ordinal int, child hybridqp.QueryNode)
func (*LogicalSeries) ReplaceChildren ¶
func (p *LogicalSeries) ReplaceChildren(children []hybridqp.QueryNode)
func (*LogicalSeries) String ¶
func (p *LogicalSeries) String() string
func (*LogicalSeries) Type ¶
func (p *LogicalSeries) Type() string
type LogicalSlidingWindow ¶
type LogicalSlidingWindow struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalSlidingWindow ¶
func NewLogicalSlidingWindow(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalSlidingWindow
func (*LogicalSlidingWindow) Clone ¶
func (p *LogicalSlidingWindow) Clone() hybridqp.QueryNode
func (*LogicalSlidingWindow) CountToSum ¶
func (p *LogicalSlidingWindow) CountToSum()
func (*LogicalSlidingWindow) DeriveOperations ¶
func (p *LogicalSlidingWindow) DeriveOperations()
func (*LogicalSlidingWindow) Digest ¶
func (p *LogicalSlidingWindow) Digest() string
func (*LogicalSlidingWindow) Explain ¶
func (p *LogicalSlidingWindow) Explain(writer LogicalPlanWriter)
func (*LogicalSlidingWindow) ForwardCallArgs ¶
func (p *LogicalSlidingWindow) ForwardCallArgs()
func (*LogicalSlidingWindow) LogicPlanType ¶ added in v1.0.0
func (p *LogicalSlidingWindow) LogicPlanType() internal.LogicPlanType
func (*LogicalSlidingWindow) New ¶ added in v1.1.0
func (p *LogicalSlidingWindow) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalSlidingWindow) String ¶
func (p *LogicalSlidingWindow) String() string
func (*LogicalSlidingWindow) Type ¶
func (p *LogicalSlidingWindow) Type() string
type LogicalSort ¶ added in v1.1.0
type LogicalSort struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalSort ¶ added in v1.1.0
func NewLogicalSort(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalSort
func (*LogicalSort) Clone ¶ added in v1.1.0
func (p *LogicalSort) Clone() hybridqp.QueryNode
func (*LogicalSort) DeriveOperations ¶ added in v1.1.0
func (p *LogicalSort) DeriveOperations()
func (*LogicalSort) Digest ¶ added in v1.1.0
func (p *LogicalSort) Digest() string
func (*LogicalSort) Explain ¶ added in v1.1.0
func (p *LogicalSort) Explain(writer LogicalPlanWriter)
func (*LogicalSort) ExplainIterms ¶ added in v1.1.0
func (p *LogicalSort) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalSort) LogicPlanType ¶ added in v1.1.0
func (p *LogicalSort) LogicPlanType() internal.LogicPlanType
func (*LogicalSort) New ¶ added in v1.1.0
func (p *LogicalSort) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalSort) String ¶ added in v1.1.0
func (p *LogicalSort) String() string
func (*LogicalSort) Type ¶ added in v1.1.0
func (p *LogicalSort) Type() string
type LogicalSortAppend ¶
type LogicalSortAppend struct {
LogicalPlanMulti
}
func NewLogicalSortAppend ¶
func NewLogicalSortAppend(inputs []hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalSortAppend
func (*LogicalSortAppend) Clone ¶
func (p *LogicalSortAppend) Clone() hybridqp.QueryNode
func (*LogicalSortAppend) DeriveOperations ¶
func (p *LogicalSortAppend) DeriveOperations()
func (*LogicalSortAppend) Digest ¶
func (p *LogicalSortAppend) Digest() string
func (*LogicalSortAppend) Explain ¶
func (p *LogicalSortAppend) Explain(writer LogicalPlanWriter)
func (*LogicalSortAppend) LogicPlanType ¶ added in v1.0.0
func (p *LogicalSortAppend) LogicPlanType() internal.LogicPlanType
func (*LogicalSortAppend) New ¶ added in v1.1.0
func (p *LogicalSortAppend) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalSortAppend) String ¶
func (p *LogicalSortAppend) String() string
func (*LogicalSortAppend) Type ¶
func (p *LogicalSortAppend) Type() string
type LogicalSortMerge ¶
type LogicalSortMerge struct {
LogicalPlanMulti
}
func NewLogicalSortMerge ¶
func NewLogicalSortMerge(inputs []hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalSortMerge
func (*LogicalSortMerge) Clone ¶
func (p *LogicalSortMerge) Clone() hybridqp.QueryNode
func (*LogicalSortMerge) DeriveOperations ¶
func (p *LogicalSortMerge) DeriveOperations()
func (*LogicalSortMerge) Digest ¶
func (p *LogicalSortMerge) Digest() string
func (*LogicalSortMerge) Explain ¶
func (p *LogicalSortMerge) Explain(writer LogicalPlanWriter)
func (*LogicalSortMerge) LogicPlanType ¶ added in v1.0.0
func (p *LogicalSortMerge) LogicPlanType() internal.LogicPlanType
func (*LogicalSortMerge) New ¶ added in v1.1.0
func (p *LogicalSortMerge) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalSortMerge) String ¶
func (p *LogicalSortMerge) String() string
func (*LogicalSortMerge) Type ¶
func (p *LogicalSortMerge) Type() string
type LogicalSparseIndexScan ¶ added in v1.1.0
type LogicalSparseIndexScan struct {
LogicalPlanSingle
}
func NewLogicalSparseIndexScan ¶ added in v1.1.0
func NewLogicalSparseIndexScan(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalSparseIndexScan
func (*LogicalSparseIndexScan) Clone ¶ added in v1.1.0
func (p *LogicalSparseIndexScan) Clone() hybridqp.QueryNode
func (*LogicalSparseIndexScan) DeriveOperations ¶ added in v1.1.0
func (p *LogicalSparseIndexScan) DeriveOperations()
func (*LogicalSparseIndexScan) Digest ¶ added in v1.1.0
func (p *LogicalSparseIndexScan) Digest() string
func (*LogicalSparseIndexScan) Explain ¶ added in v1.1.0
func (p *LogicalSparseIndexScan) Explain(writer LogicalPlanWriter)
func (*LogicalSparseIndexScan) LogicPlanType ¶ added in v1.1.0
func (p *LogicalSparseIndexScan) LogicPlanType() internal.LogicPlanType
func (*LogicalSparseIndexScan) New ¶ added in v1.1.0
func (p *LogicalSparseIndexScan) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalSparseIndexScan) String ¶ added in v1.1.0
func (p *LogicalSparseIndexScan) String() string
func (*LogicalSparseIndexScan) Type ¶ added in v1.1.0
func (p *LogicalSparseIndexScan) Type() string
type LogicalSplitGroup ¶ added in v0.2.0
type LogicalSplitGroup struct {
LogicalPlanSingle
}
func NewLogicalSplitGroup ¶ added in v0.2.0
func NewLogicalSplitGroup(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalSplitGroup
func (*LogicalSplitGroup) Clone ¶ added in v0.2.0
func (p *LogicalSplitGroup) Clone() hybridqp.QueryNode
func (*LogicalSplitGroup) DeriveOperations ¶ added in v0.2.0
func (p *LogicalSplitGroup) DeriveOperations()
func (*LogicalSplitGroup) Digest ¶ added in v0.2.0
func (p *LogicalSplitGroup) Digest() string
func (*LogicalSplitGroup) Explain ¶ added in v0.2.0
func (p *LogicalSplitGroup) Explain(writer LogicalPlanWriter)
func (*LogicalSplitGroup) LogicPlanType ¶ added in v1.0.0
func (p *LogicalSplitGroup) LogicPlanType() internal.LogicPlanType
func (*LogicalSplitGroup) New ¶ added in v1.1.0
func (p *LogicalSplitGroup) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalSplitGroup) String ¶ added in v0.2.0
func (p *LogicalSplitGroup) String() string
func (*LogicalSplitGroup) Type ¶ added in v0.2.0
func (p *LogicalSplitGroup) Type() string
type LogicalSubQuery ¶
type LogicalSubQuery struct {
LogicalPlanSingle
}
func NewLogicalSubQuery ¶
func NewLogicalSubQuery(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalSubQuery
func (*LogicalSubQuery) Clone ¶
func (p *LogicalSubQuery) Clone() hybridqp.QueryNode
func (*LogicalSubQuery) DeriveOperations ¶
func (p *LogicalSubQuery) DeriveOperations()
func (*LogicalSubQuery) Digest ¶
func (p *LogicalSubQuery) Digest() string
func (*LogicalSubQuery) Explain ¶
func (p *LogicalSubQuery) Explain(writer LogicalPlanWriter)
func (*LogicalSubQuery) LogicPlanType ¶ added in v1.0.0
func (p *LogicalSubQuery) LogicPlanType() internal.LogicPlanType
func (*LogicalSubQuery) New ¶ added in v1.1.0
func (p *LogicalSubQuery) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalSubQuery) String ¶
func (p *LogicalSubQuery) String() string
func (*LogicalSubQuery) Type ¶
func (p *LogicalSubQuery) Type() string
type LogicalTSSPScan ¶ added in v1.0.0
type LogicalTSSPScan struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalTSSPScan ¶ added in v1.0.0
func NewLogicalTSSPScan(schema hybridqp.Catalog) *LogicalTSSPScan
func (*LogicalTSSPScan) Children ¶ added in v1.0.0
func (p *LogicalTSSPScan) Children() []hybridqp.QueryNode
func (*LogicalTSSPScan) Clone ¶ added in v1.0.0
func (p *LogicalTSSPScan) Clone() hybridqp.QueryNode
func (*LogicalTSSPScan) DeriveOperations ¶ added in v1.0.0
func (p *LogicalTSSPScan) DeriveOperations()
func (*LogicalTSSPScan) Digest ¶ added in v1.0.0
func (p *LogicalTSSPScan) Digest() string
func (*LogicalTSSPScan) Explain ¶ added in v1.0.0
func (p *LogicalTSSPScan) Explain(writer LogicalPlanWriter)
func (*LogicalTSSPScan) ExplainIterms ¶ added in v1.0.0
func (p *LogicalTSSPScan) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalTSSPScan) GetFiles ¶ added in v1.0.0
func (p *LogicalTSSPScan) GetFiles() *immutable.TSSPFiles
func (*LogicalTSSPScan) GetNewSeqs ¶ added in v1.0.0
func (p *LogicalTSSPScan) GetNewSeqs() []uint64
func (*LogicalTSSPScan) LogicPlanType ¶ added in v1.0.0
func (p *LogicalTSSPScan) LogicPlanType() internal.LogicPlanType
func (*LogicalTSSPScan) MstName ¶ added in v1.0.0
func (p *LogicalTSSPScan) MstName() string
func (*LogicalTSSPScan) New ¶ added in v1.1.0
func (p *LogicalTSSPScan) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalTSSPScan) ReplaceChild ¶ added in v1.0.0
func (p *LogicalTSSPScan) ReplaceChild(ordinal int, child hybridqp.QueryNode)
func (*LogicalTSSPScan) ReplaceChildren ¶ added in v1.0.0
func (p *LogicalTSSPScan) ReplaceChildren(children []hybridqp.QueryNode)
func (*LogicalTSSPScan) SetFiles ¶ added in v1.0.0
func (p *LogicalTSSPScan) SetFiles(files *immutable.TSSPFiles)
func (*LogicalTSSPScan) SetNewSeqs ¶ added in v1.0.0
func (p *LogicalTSSPScan) SetNewSeqs(seqs []uint64)
func (*LogicalTSSPScan) String ¶ added in v1.0.0
func (p *LogicalTSSPScan) String() string
func (*LogicalTSSPScan) Type ¶ added in v1.0.0
func (p *LogicalTSSPScan) Type() string
type LogicalTagSubset ¶
type LogicalTagSubset struct {
LogicalPlanSingle
}
func NewLogicalTagSubset ¶
func NewLogicalTagSubset(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalTagSubset
NewLogicalTagSubset unused
func (*LogicalTagSubset) Clone ¶
func (p *LogicalTagSubset) Clone() hybridqp.QueryNode
func (*LogicalTagSubset) DeriveOperations ¶ added in v1.0.0
func (p *LogicalTagSubset) DeriveOperations()
func (*LogicalTagSubset) Digest ¶
func (p *LogicalTagSubset) Digest() string
func (*LogicalTagSubset) Explain ¶
func (p *LogicalTagSubset) Explain(writer LogicalPlanWriter)
func (*LogicalTagSubset) LogicPlanType ¶ added in v1.0.0
func (p *LogicalTagSubset) LogicPlanType() internal.LogicPlanType
func (*LogicalTagSubset) New ¶ added in v1.1.0
func (p *LogicalTagSubset) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalTagSubset) String ¶
func (p *LogicalTagSubset) String() string
func (*LogicalTagSubset) Type ¶
func (p *LogicalTagSubset) Type() string
type LogicalTarget ¶ added in v1.0.0
type LogicalTarget struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalTarget ¶ added in v1.0.0
func NewLogicalTarget(input hybridqp.QueryNode, schema hybridqp.Catalog, mst *influxql.Measurement) *LogicalTarget
func (*LogicalTarget) Clone ¶ added in v1.0.0
func (p *LogicalTarget) Clone() hybridqp.QueryNode
func (*LogicalTarget) DeriveOperations ¶ added in v1.0.0
func (p *LogicalTarget) DeriveOperations()
func (*LogicalTarget) Digest ¶ added in v1.0.0
func (p *LogicalTarget) Digest() string
func (*LogicalTarget) Explain ¶ added in v1.0.0
func (p *LogicalTarget) Explain(writer LogicalPlanWriter)
func (*LogicalTarget) LogicPlanType ¶ added in v1.0.0
func (p *LogicalTarget) LogicPlanType() internal.LogicPlanType
func (*LogicalTarget) New ¶ added in v1.1.0
func (p *LogicalTarget) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalTarget) String ¶ added in v1.0.0
func (p *LogicalTarget) String() string
func (*LogicalTarget) TargetMeasurement ¶ added in v1.0.0
func (p *LogicalTarget) TargetMeasurement() *influxql.Measurement
func (*LogicalTarget) Type ¶ added in v1.0.0
func (p *LogicalTarget) Type() string
type LogicalWriteIntoStorage ¶ added in v1.0.0
type LogicalWriteIntoStorage struct {
LogicalPlanSingle
// contains filtered or unexported fields
}
func NewLogicalWriteIntoStorage ¶ added in v1.0.0
func NewLogicalWriteIntoStorage(input hybridqp.QueryNode, schema hybridqp.Catalog) *LogicalWriteIntoStorage
func (*LogicalWriteIntoStorage) Clone ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) Clone() hybridqp.QueryNode
func (*LogicalWriteIntoStorage) DeriveOperations ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) DeriveOperations()
func (*LogicalWriteIntoStorage) Digest ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) Digest() string
func (*LogicalWriteIntoStorage) Explain ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) Explain(writer LogicalPlanWriter)
func (*LogicalWriteIntoStorage) ExplainIterms ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) ExplainIterms(writer LogicalPlanWriter)
func (*LogicalWriteIntoStorage) GetMmsTables ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) GetMmsTables() *immutable.MmsTables
func (*LogicalWriteIntoStorage) LogicPlanType ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) LogicPlanType() internal.LogicPlanType
func (*LogicalWriteIntoStorage) MstName ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) MstName() string
func (*LogicalWriteIntoStorage) New ¶ added in v1.1.0
func (p *LogicalWriteIntoStorage) New(inputs []hybridqp.QueryNode, schema hybridqp.Catalog, eTrait []hybridqp.Trait) hybridqp.QueryNode
impl me
func (*LogicalWriteIntoStorage) ReplaceChild ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) ReplaceChild(ordinal int, child hybridqp.QueryNode)
func (*LogicalWriteIntoStorage) ReplaceChildren ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) ReplaceChildren(children []hybridqp.QueryNode)
func (*LogicalWriteIntoStorage) SetMmsTables ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) SetMmsTables(m *immutable.MmsTables)
func (*LogicalWriteIntoStorage) String ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) String() string
func (*LogicalWriteIntoStorage) Type ¶ added in v1.0.0
func (p *LogicalWriteIntoStorage) Type() string
type MaterializeTransform ¶
type MaterializeTransform struct {
BaseProcessor
ResetTime bool
HasBinaryExpr bool
ColumnMap [][]int
// contains filtered or unexported fields
}
func NewMaterializeTransform ¶
func NewMaterializeTransform(inRowDataType hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, ops []hybridqp.ExprOptions, opt *query.ProcessorOptions, writer ChunkWriter, schema *QuerySchema) *MaterializeTransform
func (*MaterializeTransform) Close ¶
func (trans *MaterializeTransform) Close()
func (*MaterializeTransform) ColumnMapInit ¶
func (trans *MaterializeTransform) ColumnMapInit()
func (*MaterializeTransform) Explain ¶
func (trans *MaterializeTransform) Explain() []ValuePair
func (*MaterializeTransform) GetInputNumber ¶
func (trans *MaterializeTransform) GetInputNumber(_ Port) int
func (*MaterializeTransform) GetInputs ¶
func (trans *MaterializeTransform) GetInputs() Ports
func (*MaterializeTransform) GetOutputNumber ¶
func (trans *MaterializeTransform) GetOutputNumber(_ Port) int
func (*MaterializeTransform) GetOutputs ¶
func (trans *MaterializeTransform) GetOutputs() Ports
func (*MaterializeTransform) Name ¶
func (trans *MaterializeTransform) Name() string
func (*MaterializeTransform) ResetTransparents ¶ added in v1.2.0
func (trans *MaterializeTransform) ResetTransparents()
type MaterializeTransformCreator ¶
type MaterializeTransformCreator struct {
}
func (*MaterializeTransformCreator) Create ¶
func (c *MaterializeTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type MaxOp ¶ added in v1.3.0
type MaxOp struct{}
func (*MaxOp) CreateRoutine ¶ added in v1.3.0
func (c *MaxOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type MaxPromOp ¶ added in v1.3.0
type MaxPromOp struct {
BasePromOp
}
func (*MaxPromOp) CreateRoutine ¶ added in v1.3.0
func (c *MaxPromOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type MergeTransf ¶ added in v1.0.0
type MergeTransf struct {
}
func (*MergeTransf) CostName ¶ added in v1.0.0
func (t *MergeTransf) CostName() string
func (*MergeTransf) GetType ¶ added in v1.0.0
func (t *MergeTransf) GetType() MergeTransformType
func (*MergeTransf) InitColumnsIteratorHelper ¶ added in v1.0.0
func (t *MergeTransf) InitColumnsIteratorHelper(rt hybridqp.RowDataType) CoProcessor
func (*MergeTransf) InitHeapItems ¶ added in v1.0.0
func (t *MergeTransf) InitHeapItems(inRowDataLen int, _ hybridqp.RowDataType, schema *QuerySchema) BaseHeapItems
func (*MergeTransf) Name ¶ added in v1.0.0
func (t *MergeTransf) Name() string
type MergeTransform ¶
type MergeTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
BreakPoint BaseBreakPoint
HeapItems BaseHeapItems
NewChunk Chunk
CoProcessor CoProcessor
WaitMerge chan Semaphore
NextChunk []chan Semaphore
ReflectionTables
// contains filtered or unexported fields
}
func NewBaseMergeTransform ¶ added in v1.0.0
func NewBaseMergeTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, schema *QuerySchema, children []hybridqp.QueryNode, mergeType MergeType) *MergeTransform
func NewMergeTransform ¶
func NewMergeTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, _ []hybridqp.ExprOptions, schema *QuerySchema) *MergeTransform
func NewSortAppendTransform ¶
func NewSortAppendTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, schema *QuerySchema, children []hybridqp.QueryNode) *MergeTransform
func NewSortedMergeTransform ¶
func NewSortedMergeTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType, _ []hybridqp.ExprOptions, schema *QuerySchema) *MergeTransform
func (*MergeTransform) AddIntervalIndex ¶
func (trans *MergeTransform) AddIntervalIndex(chunk Chunk, i int, opt *query.ProcessorOptions, flag bool) bool
func (*MergeTransform) AddTagAndIndexes ¶
func (trans *MergeTransform) AddTagAndIndexes(tag ChunkTags, iLen int, i int, flag bool)
func (*MergeTransform) AppendToHeap ¶
func (trans *MergeTransform) AppendToHeap(in int, c Chunk)
func (*MergeTransform) Close ¶
func (trans *MergeTransform) Close()
func (*MergeTransform) CostName ¶ added in v1.0.0
func (trans *MergeTransform) CostName() string
func (*MergeTransform) Explain ¶
func (trans *MergeTransform) Explain() []ValuePair
func (*MergeTransform) GetInputNumber ¶
func (trans *MergeTransform) GetInputNumber(port Port) int
func (*MergeTransform) GetInputs ¶
func (trans *MergeTransform) GetInputs() Ports
func (*MergeTransform) GetMstName ¶ added in v1.0.0
func (trans *MergeTransform) GetMstName() string
func (*MergeTransform) GetOutputNumber ¶
func (trans *MergeTransform) GetOutputNumber(port Port) int
func (*MergeTransform) GetOutputs ¶
func (trans *MergeTransform) GetOutputs() Ports
func (*MergeTransform) InitHeapItems ¶ added in v1.0.0
func (trans *MergeTransform) InitHeapItems(inRowDataLen int, rt hybridqp.RowDataType, schema *QuerySchema)
func (*MergeTransform) IsNewMstName ¶ added in v1.0.0
func (trans *MergeTransform) IsNewMstName() bool
func (*MergeTransform) Merge ¶
func (trans *MergeTransform) Merge(ctx context.Context, errs *errno.Errs)
Merge used to merge chunks to a sorted chunks.
func (*MergeTransform) Name ¶
func (trans *MergeTransform) Name() string
func (*MergeTransform) SendChunk ¶
func (trans *MergeTransform) SendChunk()
func (*MergeTransform) UpdateWithSingleChunk ¶
func (trans *MergeTransform) UpdateWithSingleChunk()
type MergeTransformCreator ¶
type MergeTransformCreator struct {
}
func (*MergeTransformCreator) Create ¶
func (c *MergeTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type MergeTransformType ¶ added in v1.0.0
type MergeTransformType int
const ( MergeTrans MergeTransformType = iota SortMergeTrans SortAppendTrans )
type MergeType ¶ added in v1.0.0
type MergeType interface {
Name() string
CostName() string
GetType() MergeTransformType
InitHeapItems(inRowDataLen int, rt hybridqp.RowDataType, schema *QuerySchema) BaseHeapItems
InitColumnsIteratorHelper(rt hybridqp.RowDataType) CoProcessor
// contains filtered or unexported methods
}
type MinOp ¶ added in v1.3.0
type MinOp struct{}
func (*MinOp) CreateRoutine ¶ added in v1.3.0
func (c *MinOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type MinPromOp ¶ added in v1.3.0
type MinPromOp struct {
BasePromOp
}
func (*MinPromOp) CreateRoutine ¶ added in v1.3.0
func (c *MinPromOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type MultiMstReqs ¶ added in v1.2.0
type MultiMstReqs struct {
// contains filtered or unexported fields
}
func NewMultiMstReqs ¶ added in v1.2.0
func NewMultiMstReqs() *MultiMstReqs
func (*MultiMstReqs) SetReqs ¶ added in v1.4.0
func (m *MultiMstReqs) SetReqs(reqs []*RemoteQuery)
type NewAggOperator ¶ added in v1.1.0
type NewAggOperator func() aggOperator
type NilSink ¶
type NilSink struct {
BaseProcessor
Input *ChunkPort
}
func NewNilSink ¶
func NewNilSink(rowDataType hybridqp.RowDataType) *NilSink
func (*NilSink) GetInputNumber ¶
func (*NilSink) GetOutputNumber ¶
func (*NilSink) GetOutputs ¶
type NilTransform ¶
type NilTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
}
func NewNilTransform ¶
func NewNilTransform(inRowDataTypes []hybridqp.RowDataType, outRowDataTypes []hybridqp.RowDataType) *NilTransform
func (*NilTransform) Close ¶
func (trans *NilTransform) Close()
func (*NilTransform) Explain ¶
func (trans *NilTransform) Explain() []ValuePair
func (*NilTransform) GetInputNumber ¶
func (trans *NilTransform) GetInputNumber(port Port) int
func (*NilTransform) GetInputs ¶
func (trans *NilTransform) GetInputs() Ports
func (*NilTransform) GetOutputNumber ¶
func (trans *NilTransform) GetOutputNumber(port Port) int
func (*NilTransform) GetOutputs ¶
func (trans *NilTransform) GetOutputs() Ports
func (*NilTransform) Name ¶
func (trans *NilTransform) Name() string
type OGSketch ¶ added in v1.0.0
type OGSketch interface {
InsertPoints(...float64)
InsertClusters(...floatTuple)
DeletePoints(...float64)
DeleteClusters(...floatTuple)
Merge(*OGSketchImpl)
Percentile(float64) float64
Rank(float64) int64
Clusters() ClusterSet
Reset()
Len() int
EquiHeightHistogram(int, float64, float64) []float64
DemarcationHistogram(float64, float64, int, int) []int64
}
type OGSketchImpl ¶ added in v1.0.0
type OGSketchImpl struct {
// contains filtered or unexported fields
}
func NewOGSketchImpl ¶ added in v1.0.0
func NewOGSketchImpl(c float64) *OGSketchImpl
func (*OGSketchImpl) Clusters ¶ added in v1.0.0
func (s *OGSketchImpl) Clusters() ClusterSet
func (*OGSketchImpl) DeleteClusters ¶ added in v1.0.0
func (s *OGSketchImpl) DeleteClusters(cluster ...floatTuple)
func (*OGSketchImpl) DeletePoints ¶ added in v1.0.0
func (s *OGSketchImpl) DeletePoints(m ...float64)
func (*OGSketchImpl) DemarcationHistogram ¶ added in v1.0.0
func (s *OGSketchImpl) DemarcationHistogram(begin, width float64, binsNum, binsType int) []int64
func (*OGSketchImpl) EquiHeightHistogram ¶ added in v1.0.0
func (s *OGSketchImpl) EquiHeightHistogram(binNum int, begin float64, end float64) []float64
func (*OGSketchImpl) InsertClusters ¶ added in v1.0.0
func (s *OGSketchImpl) InsertClusters(cluster ...floatTuple)
func (*OGSketchImpl) InsertPoints ¶ added in v1.0.0
func (s *OGSketchImpl) InsertPoints(m ...float64)
func (*OGSketchImpl) Len ¶ added in v1.0.0
func (s *OGSketchImpl) Len() int
func (*OGSketchImpl) Merge ¶ added in v1.0.0
func (s *OGSketchImpl) Merge(s1 *OGSketchImpl)
func (*OGSketchImpl) Percentile ¶ added in v1.0.0
func (s *OGSketchImpl) Percentile(q float64) float64
func (*OGSketchImpl) Rank ¶ added in v1.0.0
func (s *OGSketchImpl) Rank(Q float64) int64
func (*OGSketchImpl) Reset ¶ added in v1.0.0
func (s *OGSketchImpl) Reset()
type OGSketchItem ¶ added in v1.0.0
type OGSketchIterator ¶ added in v1.0.0
type OGSketchIterator struct {
// contains filtered or unexported fields
}
func NewOGSketchIterator ¶ added in v1.0.0
func NewOGSketchIterator( isSingleCall bool, inOrdinal, outOrdinal int, clusterNum int, opt *query.ProcessorOptions, sketch OGSketchItem, ) *OGSketchIterator
func (*OGSketchIterator) Next ¶ added in v1.0.0
func (r *OGSketchIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type OGSketchMergeItem ¶ added in v1.0.0
type OGSketchMergeItem struct {
// contains filtered or unexported fields
}
func NewOGSketchMergeItem ¶ added in v1.0.0
func NewOGSketchMergeItem(isSingleCall bool, inOrdinal, outOrdinal, clusterNum int, percentile float64) *OGSketchMergeItem
func (*OGSketchMergeItem) IsNil ¶ added in v1.0.0
func (o *OGSketchMergeItem) IsNil() bool
func (*OGSketchMergeItem) Reset ¶ added in v1.0.0
func (o *OGSketchMergeItem) Reset()
func (*OGSketchMergeItem) UpdateCluster ¶ added in v1.0.0
func (o *OGSketchMergeItem) UpdateCluster(inChunk Chunk, start, end int)
func (*OGSketchMergeItem) WriteResult ¶ added in v1.0.0
func (o *OGSketchMergeItem) WriteResult(outChunk Chunk, time int64)
type OptRule ¶
type OptRule interface {
Initialize(rule OptRule, operand OptRuleOperand, description string)
ToString() string
Description() string
Catagory() OptRuleCatagory
Equals(OptRule) bool
GetOperand() OptRuleOperand
Matches(call *OptRuleCall) bool
OnMatch(call *OptRuleCall)
}
type OptRuleBase ¶
type OptRuleBase struct {
// contains filtered or unexported fields
}
func (*OptRuleBase) Description ¶
func (r *OptRuleBase) Description() string
func (*OptRuleBase) Equals ¶
func (r *OptRuleBase) Equals(rhs *OptRuleBase) bool
func (*OptRuleBase) GetOperand ¶
func (r *OptRuleBase) GetOperand() OptRuleOperand
func (*OptRuleBase) Initialize ¶
func (r *OptRuleBase) Initialize(rule OptRule, operand OptRuleOperand, description string)
func (*OptRuleBase) Matches ¶
func (r *OptRuleBase) Matches(_ *OptRuleCall) bool
type OptRuleCall ¶
type OptRuleCall struct {
// contains filtered or unexported fields
}
func NewOptRuleCall ¶
func NewOptRuleCall(planner HeuPlanner, operand OptRuleOperand, nodes []hybridqp.QueryNode, ) *OptRuleCall
func (*OptRuleCall) GetResult ¶
func (c *OptRuleCall) GetResult() []hybridqp.QueryNode
func (*OptRuleCall) Rule ¶
func (c *OptRuleCall) Rule() OptRule
func (*OptRuleCall) TransformTo ¶
func (c *OptRuleCall) TransformTo(to hybridqp.QueryNode) []hybridqp.QueryNode
type OptRuleCatagory ¶
type OptRuleCatagory int
const ( RULE_TEST OptRuleCatagory = iota RULE_PUSHDOWN_LIMIT RULE_PUSHDOWN_AGG RULE_SPREAD_AGG RULE_SUBQUERY RULE_HEIMADLL_PUSHDOWN )
type OptRuleOperand ¶
type OptRuleOperand interface {
Equals(rhs OptRuleOperand) bool
SetParent(parent OptRuleOperand)
Parent() OptRuleOperand
Matches(node hybridqp.QueryNode) bool
Policy() OptRuleOperandChildPolicy
SetRule(rule OptRule)
Rule() OptRule
SetOrdinalInParent(int)
SetOrdinalInRule(int)
Children() []OptRuleOperand
}
type OptRuleOperandBase ¶
type OptRuleOperandBase struct {
// contains filtered or unexported fields
}
func NewOptRuleOperandBase ¶
func NewOptRuleOperandBase(planType string, policy OptRuleOperandChildPolicy, children []OptRuleOperand) *OptRuleOperandBase
func (*OptRuleOperandBase) Children ¶
func (ob *OptRuleOperandBase) Children() []OptRuleOperand
func (*OptRuleOperandBase) Equals ¶
func (ob *OptRuleOperandBase) Equals(rhs OptRuleOperand) bool
func (*OptRuleOperandBase) Matches ¶
func (ob *OptRuleOperandBase) Matches(node hybridqp.QueryNode) bool
func (*OptRuleOperandBase) Parent ¶
func (ob *OptRuleOperandBase) Parent() OptRuleOperand
func (*OptRuleOperandBase) Policy ¶
func (ob *OptRuleOperandBase) Policy() OptRuleOperandChildPolicy
func (*OptRuleOperandBase) Rule ¶
func (ob *OptRuleOperandBase) Rule() OptRule
func (*OptRuleOperandBase) SetOrdinalInParent ¶
func (ob *OptRuleOperandBase) SetOrdinalInParent(ordinal int)
func (*OptRuleOperandBase) SetOrdinalInRule ¶
func (ob *OptRuleOperandBase) SetOrdinalInRule(ordinal int)
func (*OptRuleOperandBase) SetParent ¶
func (ob *OptRuleOperandBase) SetParent(parent OptRuleOperand)
func (*OptRuleOperandBase) SetRule ¶
func (ob *OptRuleOperandBase) SetRule(rule OptRule)
type OptRuleOperandBuilder ¶
type OptRuleOperandBuilder interface {
NoInput(planType string)
AnyInput(planType string)
OneInput(planType string, input OptRuleOperand)
WildCardInput(planType string)
Inputs(planType string, inputs ...OptRuleOperand)
UnorderedInputs(planType string, inputs ...OptRuleOperand)
Operands() []OptRuleOperand
Operand() OptRuleOperand
}
type OptRuleOperandBuilderBase ¶
type OptRuleOperandBuilderBase struct {
// contains filtered or unexported fields
}
func NewOptRuleOperandBuilderBase ¶
func NewOptRuleOperandBuilderBase() *OptRuleOperandBuilderBase
func (*OptRuleOperandBuilderBase) AfterInput ¶
func (builder *OptRuleOperandBuilderBase) AfterInput(planType string)
func (*OptRuleOperandBuilderBase) AnyInput ¶
func (builder *OptRuleOperandBuilderBase) AnyInput(planType string)
func (*OptRuleOperandBuilderBase) Inputs ¶
func (builder *OptRuleOperandBuilderBase) Inputs(planType string, inputs ...OptRuleOperand)
func (*OptRuleOperandBuilderBase) NoInput ¶
func (builder *OptRuleOperandBuilderBase) NoInput(planType string)
func (*OptRuleOperandBuilderBase) OneInput ¶
func (builder *OptRuleOperandBuilderBase) OneInput(planType string, input OptRuleOperand)
func (*OptRuleOperandBuilderBase) Operand ¶
func (builder *OptRuleOperandBuilderBase) Operand() OptRuleOperand
func (*OptRuleOperandBuilderBase) Operands ¶
func (builder *OptRuleOperandBuilderBase) Operands() []OptRuleOperand
func (*OptRuleOperandBuilderBase) UnorderedInputs ¶
func (builder *OptRuleOperandBuilderBase) UnorderedInputs(planType string, inputs ...OptRuleOperand)
func (*OptRuleOperandBuilderBase) WildCardInput ¶
func (builder *OptRuleOperandBuilderBase) WildCardInput(planType string, input OptRuleOperand)
type OptRuleOperandChildPolicy ¶
type OptRuleOperandChildPolicy int
const ( ANY OptRuleOperandChildPolicy = iota LEAF SOME UNORDERED WILDCARD AFTER )
type OptRuleOperands ¶
type OptRuleOperands []OptRuleOperand
func (OptRuleOperands) Equals ¶
func (operands OptRuleOperands) Equals(rhs OptRuleOperands) bool
type OrderByTransform ¶
type OrderByTransform struct {
BaseProcessor
ResultChunkPool *CircularChunkPool
CoProcessor CoProcessor
// contains filtered or unexported fields
}
func NewOrderByTransform ¶
func NewOrderByTransform(inRowDataType hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, ops []hybridqp.ExprOptions, opt *query.ProcessorOptions, dimensions []string) *OrderByTransform
func (*OrderByTransform) Close ¶
func (trans *OrderByTransform) Close()
func (*OrderByTransform) Explain ¶
func (trans *OrderByTransform) Explain() []ValuePair
func (*OrderByTransform) GetCurrTags ¶ added in v1.3.0
func (trans *OrderByTransform) GetCurrTags(i int) string
func (*OrderByTransform) GetInputNumber ¶
func (trans *OrderByTransform) GetInputNumber(_ Port) int
func (*OrderByTransform) GetInputs ¶
func (trans *OrderByTransform) GetInputs() Ports
func (*OrderByTransform) GetOutputNumber ¶
func (trans *OrderByTransform) GetOutputNumber(_ Port) int
func (*OrderByTransform) GetOutputs ¶
func (trans *OrderByTransform) GetOutputs() Ports
func (*OrderByTransform) GetTagAndIndexes ¶
func (trans *OrderByTransform) GetTagAndIndexes(chunk Chunk)
func (*OrderByTransform) GetTagsResetTagIndexes ¶
func (trans *OrderByTransform) GetTagsResetTagIndexes(chunk Chunk)
func (*OrderByTransform) IntervalIndexReGen ¶
func (trans *OrderByTransform) IntervalIndexReGen()
func (*OrderByTransform) Name ¶
func (trans *OrderByTransform) Name() string
func (*OrderByTransform) OrderTime ¶
func (trans *OrderByTransform) OrderTime()
func (*OrderByTransform) RebuildChunk ¶
func (trans *OrderByTransform) RebuildChunk()
func (*OrderByTransform) Release ¶
func (trans *OrderByTransform) Release() error
func (*OrderByTransform) SendChunk ¶
func (trans *OrderByTransform) SendChunk()
func (*OrderByTransform) TagAndTagIndexHandler ¶
func (trans *OrderByTransform) TagAndTagIndexHandler()
type OrderByTransformCreator ¶
type OrderByTransformCreator struct {
}
func (*OrderByTransformCreator) Create ¶
func (c *OrderByTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type ParaPointers ¶ added in v1.0.0
type ParaPointers []*Para
func (ParaPointers) Len ¶ added in v1.0.0
func (a ParaPointers) Len() int
Len implements sort.Interface.
func (ParaPointers) Less ¶ added in v1.0.0
func (a ParaPointers) Less(i, j int) bool
Less implements sort.Interface.
func (ParaPointers) Swap ¶ added in v1.0.0
func (a ParaPointers) Swap(i, j int)
Swap implements sort.Interface.
type PercentileApproxOp ¶ added in v1.3.0
type PercentileApproxOp struct{}
func (*PercentileApproxOp) CreateRoutine ¶ added in v1.3.0
func (c *PercentileApproxOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type PipelineExecutor ¶
type PipelineExecutor struct {
Query string
RunTimeStats *statistics.StatisticTimer
// contains filtered or unexported fields
}
func NewPipelineExecutor ¶
func NewPipelineExecutor(processors Processors) *PipelineExecutor
func NewPipelineExecutorFromDag ¶
func NewPipelineExecutorFromDag(dag *TransformDag, root *TransformVertex) *PipelineExecutor
func (*PipelineExecutor) Abort ¶
func (exec *PipelineExecutor) Abort()
func (*PipelineExecutor) Aborted ¶
func (exec *PipelineExecutor) Aborted() bool
func (*PipelineExecutor) Crash ¶
func (exec *PipelineExecutor) Crash()
func (*PipelineExecutor) Crashed ¶
func (exec *PipelineExecutor) Crashed() bool
func (*PipelineExecutor) ExecuteExecutor ¶
func (exec *PipelineExecutor) ExecuteExecutor(ctx context.Context) error
func (*PipelineExecutor) GetProcessors ¶ added in v1.0.0
func (exec *PipelineExecutor) GetProcessors() Processors
func (*PipelineExecutor) GetRoot ¶ added in v1.0.0
func (exec *PipelineExecutor) GetRoot() *TransformVertex
func (*PipelineExecutor) InitContext ¶ added in v1.3.0
func (exec *PipelineExecutor) InitContext(ctx context.Context) error
func (*PipelineExecutor) NoMarkCrash ¶ added in v1.4.0
func (exec *PipelineExecutor) NoMarkCrash()
func (*PipelineExecutor) Release ¶
func (exec *PipelineExecutor) Release()
func (*PipelineExecutor) SetDag ¶ added in v1.0.0
func (exec *PipelineExecutor) SetDag(d *TransformDag)
func (*PipelineExecutor) SetProcessors ¶ added in v1.0.0
func (exec *PipelineExecutor) SetProcessors(pro Processors)
func (*PipelineExecutor) SetRoot ¶ added in v1.0.0
func (exec *PipelineExecutor) SetRoot(r *TransformVertex)
func (*PipelineExecutor) Visit ¶
func (exec *PipelineExecutor) Visit(vertex *TransformVertex) TransformVertexVisitor
type PlanFrame ¶
type PlanFrame struct {
// contains filtered or unexported fields
}
func NewPlanFrame ¶
type PlanTemplate ¶ added in v1.1.0
type PlanTemplate struct {
// contains filtered or unexported fields
}
func NewOneShardStorePlanTemplate ¶ added in v1.1.0
func NewOneShardStorePlanTemplate(t PlanType) *PlanTemplate
func NewSqlPlanTemplate ¶ added in v1.1.0
func NewSqlPlanTemplate(t PlanType) *PlanTemplate
func NewStorePlanTemplate ¶ added in v1.1.0
func NewStorePlanTemplate(t PlanType) *PlanTemplate
func (*PlanTemplate) GetLocalStorePlan ¶ added in v1.2.0
func (pp *PlanTemplate) GetLocalStorePlan() []hybridqp.QueryNode
func (*PlanTemplate) GetPlan ¶ added in v1.1.0
func (pp *PlanTemplate) GetPlan() []hybridqp.QueryNode
func (*PlanTemplate) NewLocalStoreSqlPlanTemplate ¶ added in v1.2.0
func (pp *PlanTemplate) NewLocalStoreSqlPlanTemplate()
type PlanType ¶ added in v1.1.0
type PlanType uint32
func MatchAggGroup ¶ added in v1.1.0
func MatchAggInterval ¶ added in v1.1.0
func MatchAggIntervalLimit ¶ added in v1.1.0
func MatchNoAggNoGroup ¶ added in v1.1.0
func MatchNoAggNoGroupLimit ¶ added in v1.2.0
func NilGetPlanType ¶ added in v1.1.0
func NilGetPlanType(schema hybridqp.Catalog, stmt *influxql.SelectStatement) PlanType
func NormalGetPlanType ¶ added in v1.1.0
func NormalGetPlanType(schema hybridqp.Catalog, stmt *influxql.SelectStatement) PlanType
type PlanTypeInitShard ¶ added in v1.1.0
type PlanTypeInitShard struct {
// contains filtered or unexported fields
}
func NewPlanTypeInitShardGroup ¶ added in v1.1.0
func NewPlanTypeInitShardGroup() *PlanTypeInitShard
func (*PlanTypeInitShard) Close ¶ added in v1.1.0
func (pts *PlanTypeInitShard) Close() error
func (*PlanTypeInitShard) CreateLogicalPlan ¶ added in v1.1.0
func (*PlanTypeInitShard) FieldDimensions ¶ added in v1.1.0
func (pts *PlanTypeInitShard) FieldDimensions( m *influxql.Measurement) (map[string]influxql.DataType, map[string]struct{}, *influxql.Schema, error)
func (*PlanTypeInitShard) GetETraits ¶ added in v1.1.0
func (*PlanTypeInitShard) GetSeriesKey ¶ added in v1.1.0
func (pts *PlanTypeInitShard) GetSeriesKey() []byte
func (*PlanTypeInitShard) GetSources ¶ added in v1.1.0
func (pts *PlanTypeInitShard) GetSources(sources influxql.Sources) influxql.Sources
func (*PlanTypeInitShard) LogicalPlanCost ¶ added in v1.1.0
func (pts *PlanTypeInitShard) LogicalPlanCost(source *influxql.Measurement, opt query.ProcessorOptions) (hybridqp.LogicalPlanCost, error)
func (*PlanTypeInitShard) MapType ¶ added in v1.1.0
func (pts *PlanTypeInitShard) MapType(m *influxql.Measurement, field string) influxql.DataType
func (*PlanTypeInitShard) MapTypeBatch ¶ added in v1.1.0
func (pts *PlanTypeInitShard) MapTypeBatch(m *influxql.Measurement, fields map[string]*influxql.FieldNameSpace, schema *influxql.Schema) error
type PlanTypeInitShardMapper ¶ added in v1.1.0
type PlanTypeInitShardMapper struct {
}
func NewPlanTypeInitShardMapper ¶ added in v1.1.0
func NewPlanTypeInitShardMapper() *PlanTypeInitShardMapper
func (*PlanTypeInitShardMapper) Close ¶ added in v1.1.0
func (pts *PlanTypeInitShardMapper) Close() error
func (*PlanTypeInitShardMapper) MapShards ¶ added in v1.1.0
func (pts *PlanTypeInitShardMapper) MapShards(sources influxql.Sources, t influxql.TimeRange, opt query.SelectOptions, condition influxql.Expr) (query.ShardGroup, error)
type Point ¶ added in v1.3.0
type Point[T util.ExceptString] struct { // contains filtered or unexported fields }
type PointMerge ¶ added in v1.3.0
type PointMerge[T util.ExceptString] func(prevPoint, currPoint *Point[T])
type PointRowIterator ¶ added in v1.0.0
type PointRowIterator interface {
GetNext(row *influx.Row, tuple *TargetTuple)
HasMore() bool
}
type PreAggregateCallMapping ¶
type PreAggregateCallMapping struct {
// contains filtered or unexported fields
}
func GetPreAggregateCallMapping ¶
func GetPreAggregateCallMapping() *PreAggregateCallMapping
func NewPreAggregateCallMapping ¶
func NewPreAggregateCallMapping() *PreAggregateCallMapping
func (*PreAggregateCallMapping) Contains ¶
func (mapping *PreAggregateCallMapping) Contains(name string) bool
type PrepareStmtBuilderCreator ¶
type PrepareStmtBuilderCreator struct {
}
func (*PrepareStmtBuilderCreator) Create ¶
func (p *PrepareStmtBuilderCreator) Create(stmt *influxql.SelectStatement, opt hybridqp.Options, shards interface { query.LogicalPlanCreator io.Closer }, columns []string, MaxPointN int, now time.Time) query.PreparedStatement
type Processor ¶
type Processor interface {
Work(ctx context.Context) error
Close()
Abort()
Release() error
Name() string
GetOutputs() Ports
GetInputs() Ports
GetOutputNumber(port Port) int
GetInputNumber(port Port) int
IsSink() bool
Explain() []ValuePair
Analyze(span *tracing.Span)
StartSpan(name string, withPP bool) *tracing.Span
FinishSpan()
Interrupt()
InterruptWithoutMark()
}
func CreateBaseMergeTransform ¶ added in v1.0.0
func CreateBaseMergeTransform(plan LogicalPlan, mergeType MergeType) (Processor, error)
func NewHashAggTransform ¶ added in v1.1.0
func NewHashAggTransform( inRowDataType, outRowDataType []hybridqp.RowDataType, exprOpt []hybridqp.ExprOptions, s *QuerySchema, t HashAggType) (Processor, error)
func NewTopNTransform ¶ added in v1.4.0
func NewTopNTransform( inRowDataType, outRowDataType []hybridqp.RowDataType, exprOpt []hybridqp.ExprOptions, s *QuerySchema, t HashAggType) (Processor, error)
type Processors ¶
type Processors []Processor
func (Processors) Close ¶
func (ps Processors) Close()
func (Processors) Empty ¶
func (ps Processors) Empty() bool
func (Processors) Interrupt ¶ added in v1.3.0
func (ps Processors) Interrupt()
func (Processors) InterruptWithoutMark ¶ added in v1.4.0
func (ps Processors) InterruptWithoutMark()
func (Processors) Peek ¶
func (ps Processors) Peek() Processor
func (*Processors) Pop ¶
func (ps *Processors) Pop() Processor
func (*Processors) Push ¶
func (ps *Processors) Push(p Processor)
func (Processors) Size ¶
func (ps Processors) Size() int
type PromAbsentOp ¶ added in v1.4.0
type PromAbsentOp struct{}
func (*PromAbsentOp) CreateRoutine ¶ added in v1.4.0
func (c *PromAbsentOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type PromGroupOp ¶ added in v1.3.0
type PromGroupOp struct{}
func (*PromGroupOp) CreateRoutine ¶ added in v1.3.0
func (c *PromGroupOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type PromInstantVectorTransform ¶ added in v1.4.0
type PromInstantVectorTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewPromInstantVectorTransform ¶ added in v1.4.0
func NewPromInstantVectorTransform(inRowDataType hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, schema *QuerySchema, call *influxql.PromSubCall) (*PromInstantVectorTransform, error)
func (*PromInstantVectorTransform) Close ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) Close()
func (*PromInstantVectorTransform) Explain ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) Explain() []ValuePair
func (*PromInstantVectorTransform) GetGroupRange ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) GetGroupRange(i int, chunk Chunk) (int, int)
func (*PromInstantVectorTransform) GetInputNumber ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) GetInputNumber(_ Port) int
func (*PromInstantVectorTransform) GetInputs ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) GetInputs() Ports
func (*PromInstantVectorTransform) GetOutputNumber ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) GetOutputNumber(_ Port) int
func (*PromInstantVectorTransform) GetOutputs ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) GetOutputs() Ports
func (*PromInstantVectorTransform) GroupCall ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) GroupCall(startIdx, endIdx int)
func (*PromInstantVectorTransform) Name ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) Name() string
func (*PromInstantVectorTransform) RangeCall ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) RangeCall(startCurrLoc, endCurrLoc int, start, rangeMaxt int64)
func (*PromInstantVectorTransform) UpdateLoc ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) UpdateLoc(startCurrLoc, endCurrLoc int)
func (*PromInstantVectorTransform) Work ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) Work(ctx context.Context) error
func (*PromInstantVectorTransform) WorkHelper ¶ added in v1.4.0
func (trans *PromInstantVectorTransform) WorkHelper(ctx context.Context, errs *errno.Errs)
type PromInstantVectorTransformCreator ¶ added in v1.4.0
type PromInstantVectorTransformCreator struct {
}
func (*PromInstantVectorTransformCreator) Create ¶ added in v1.4.0
func (c *PromInstantVectorTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type PromQuantileOp ¶ added in v1.3.0
type PromQuantileOp struct{}
func (*PromQuantileOp) CreateRoutine ¶ added in v1.3.0
func (c *PromQuantileOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type PromRangeVectorTransform ¶ added in v1.3.0
type PromRangeVectorTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewPromRangeVectorTransform ¶ added in v1.3.0
func NewPromRangeVectorTransform(inRowDataType hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, schema *QuerySchema, call *influxql.PromSubCall) (*PromRangeVectorTransform, error)
func (*PromRangeVectorTransform) Close ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) Close()
func (*PromRangeVectorTransform) Explain ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) Explain() []ValuePair
func (*PromRangeVectorTransform) GetGroupRange ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) GetGroupRange(i int, chunk Chunk) (int, int)
func (*PromRangeVectorTransform) GetInputNumber ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) GetInputNumber(_ Port) int
func (*PromRangeVectorTransform) GetInputs ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) GetInputs() Ports
func (*PromRangeVectorTransform) GetOutputNumber ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) GetOutputNumber(_ Port) int
func (*PromRangeVectorTransform) GetOutputs ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) GetOutputs() Ports
func (*PromRangeVectorTransform) GroupCall ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) GroupCall(startIdx, endIdx int)
func (*PromRangeVectorTransform) Name ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) Name() string
func (*PromRangeVectorTransform) NewPromSubqueryCallFunc ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) NewPromSubqueryCallFunc(call *influxql.PromSubCall) (CallFn, error)
func (*PromRangeVectorTransform) RangeCall ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) RangeCall(startPreLoc, endPreLoc, startCurrLoc, endCurrLoc int, start, rangeMaxt int64)
func (*PromRangeVectorTransform) UpdateLoc ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) UpdateLoc(startPreLoc, endPreLoc, startCurrLoc, endCurrLoc int)
func (*PromRangeVectorTransform) Work ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) Work(ctx context.Context) error
func (*PromRangeVectorTransform) WorkHelper ¶ added in v1.3.0
func (trans *PromRangeVectorTransform) WorkHelper(ctx context.Context, errs *errno.Errs)
type PromRangeVectorTransformCreator ¶ added in v1.3.0
type PromRangeVectorTransformCreator struct {
}
func (*PromRangeVectorTransformCreator) Create ¶ added in v1.3.0
func (c *PromRangeVectorTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type PromScalarOp ¶ added in v1.3.0
type PromScalarOp struct{}
func (*PromScalarOp) CreateRoutine ¶ added in v1.3.0
func (c *PromScalarOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type PromSortGroups ¶ added in v1.4.0
type PromSortGroups struct {
// contains filtered or unexported fields
}
func NewPromSortGroups ¶ added in v1.4.0
func NewPromSortGroups() PromSortGroups
func (*PromSortGroups) AppendMany ¶ added in v1.4.0
func (rows *PromSortGroups) AppendMany(tagKey, tagValue []string, value []float64, timestamp []int64)
type PromSortSeries ¶ added in v1.4.0
type PromSortSeries struct {
// contains filtered or unexported fields
}
func NewPromSortSeries ¶ added in v1.4.0
func NewPromSortSeries(tagKey, tagValue []string, value []float64, timestamp []int64) *PromSortSeries
func (*PromSortSeries) Value ¶ added in v1.4.0
func (r *PromSortSeries) Value() float64
As range query results always have a fixed output ordering, we don't care how values are comparing in such a situation. So we simply take the first sample value for each series.
type PromSortTransform ¶ added in v1.4.0
type PromSortTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewPromSortTransform ¶ added in v1.4.0
func NewPromSortTransform(inRowDataType, outRowDataType hybridqp.RowDataType, s *QuerySchema, sortFields influxql.SortFields) (*PromSortTransform, error)
func (*PromSortTransform) Close ¶ added in v1.4.0
func (trans *PromSortTransform) Close()
func (*PromSortTransform) Explain ¶ added in v1.4.0
func (trans *PromSortTransform) Explain() []ValuePair
func (*PromSortTransform) GetInputNumber ¶ added in v1.4.0
func (trans *PromSortTransform) GetInputNumber(_ Port) int
func (*PromSortTransform) GetInputs ¶ added in v1.4.0
func (trans *PromSortTransform) GetInputs() Ports
func (*PromSortTransform) GetOutputNumber ¶ added in v1.4.0
func (trans *PromSortTransform) GetOutputNumber(_ Port) int
func (*PromSortTransform) GetOutputs ¶ added in v1.4.0
func (trans *PromSortTransform) GetOutputs() Ports
func (*PromSortTransform) Name ¶ added in v1.4.0
func (trans *PromSortTransform) Name() string
func (*PromSortTransform) Work ¶ added in v1.4.0
func (trans *PromSortTransform) Work(ctx context.Context) error
func (*PromSortTransform) WorkHelper ¶ added in v1.4.0
func (trans *PromSortTransform) WorkHelper(ctx context.Context, errs *errno.Errs)
type PromSortTransformCreator ¶ added in v1.4.0
type PromSortTransformCreator struct {
}
func (*PromSortTransformCreator) Create ¶ added in v1.4.0
func (c *PromSortTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type PromStdOp ¶ added in v1.3.0
type PromStdOp struct {
// contains filtered or unexported fields
}
func (*PromStdOp) CreateRoutine ¶ added in v1.3.0
func (c *PromStdOp) CreateRoutine(params *AggCallFuncParams) (Routine, error)
type PromStepInvariantType ¶ added in v1.4.0
type PromStepInvariantType int
const ( SkipLastGroup PromStepInvariantType = iota OnlyLastGroup )
type PromTimeFunction ¶ added in v1.3.0
type PromTimeValuer ¶ added in v1.3.0
type PromTimeValuer struct{}
valuer
func (PromTimeValuer) Call ¶ added in v1.3.0
func (v PromTimeValuer) Call(name string, args []interface{}) (interface{}, bool)
func (PromTimeValuer) SetValuer ¶ added in v1.3.0
func (PromTimeValuer) SetValuer(_ influxql.Valuer, _ int)
func (PromTimeValuer) Value ¶ added in v1.3.0
func (PromTimeValuer) Value(_ string) (interface{}, bool)
type PtQuery ¶ added in v1.2.0
func UnmarshalPtQuerys ¶ added in v1.2.0
type QueryNodeStack ¶
func (*QueryNodeStack) Empty ¶
func (s *QueryNodeStack) Empty() bool
func (*QueryNodeStack) Peek ¶
func (s *QueryNodeStack) Peek() hybridqp.QueryNode
func (*QueryNodeStack) Pop ¶
func (s *QueryNodeStack) Pop() hybridqp.QueryNode
func (*QueryNodeStack) Push ¶
func (s *QueryNodeStack) Push(node hybridqp.QueryNode)
func (*QueryNodeStack) Size ¶
func (s *QueryNodeStack) Size() int
type QuerySchema ¶
type QuerySchema struct {
PromSubCalls []*influxql.PromSubCall
// contains filtered or unexported fields
}
func NewQuerySchema ¶
func NewQuerySchema(fields influxql.Fields, columnNames []string, opt hybridqp.Options, sortFields influxql.SortFields) *QuerySchema
func NewQuerySchemaWithJoinCase ¶ added in v1.0.0
func NewQuerySchemaWithSources ¶
func NewQuerySchemaWithSources(fields influxql.Fields, sources influxql.Sources, columnNames []string, opt hybridqp.Options, sortFields influxql.SortFields) *QuerySchema
func (*QuerySchema) AddHoltWinters ¶ added in v1.0.0
func (qs *QuerySchema) AddHoltWinters(call *influxql.Call, alias string)
func (*QuerySchema) AddLabelCalls ¶ added in v1.3.0
func (qs *QuerySchema) AddLabelCalls(key string, labelCalls *influxql.Call)
func (*QuerySchema) AddPromTimeCalls ¶ added in v1.3.0
func (qs *QuerySchema) AddPromTimeCalls(key string, promTimeCalls *influxql.Call)
func (*QuerySchema) AddSlidingWindow ¶
func (qs *QuerySchema) AddSlidingWindow(key string, str *influxql.Call)
func (*QuerySchema) AddTable ¶
func (qs *QuerySchema) AddTable(m *influxql.Measurement, refs []influxql.VarRef)
func (*QuerySchema) Binarys ¶
func (qs *QuerySchema) Binarys() map[string]*influxql.BinaryExpr
func (*QuerySchema) BuildDownSampleSchema ¶ added in v1.0.0
func (qs *QuerySchema) BuildDownSampleSchema(addPrefix bool) record.Schemas
func (*QuerySchema) CanAggPushDown ¶
func (qs *QuerySchema) CanAggPushDown() bool
func (*QuerySchema) CanAggTagSet ¶ added in v1.3.0
func (qs *QuerySchema) CanAggTagSet() bool
CanAggTagSet indicates that aggregation is performed among multiple TagSets. File traversal and SeqAgg optimization are used.
func (*QuerySchema) CanCallsPushdown ¶
func (qs *QuerySchema) CanCallsPushdown() bool
func (*QuerySchema) CanLimitCut ¶
func (qs *QuerySchema) CanLimitCut() bool
func (*QuerySchema) CanSeqAggPushDown ¶ added in v1.2.0
func (qs *QuerySchema) CanSeqAggPushDown() bool
CanSeqAggPushDown determines whether the csstore engine performs seqAgg optimization.
func (*QuerySchema) CloneField ¶
func (qs *QuerySchema) CloneField(f *influxql.Field) *influxql.Field
func (*QuerySchema) CompositeCall ¶ added in v1.0.0
func (qs *QuerySchema) CompositeCall() map[string]*hybridqp.OGSketchCompositeOperator
func (*QuerySchema) ContainSeriesIgnoreCall ¶
func (qs *QuerySchema) ContainSeriesIgnoreCall() bool
func (*QuerySchema) CountDistinct ¶
func (qs *QuerySchema) CountDistinct() *influxql.Call
func (*QuerySchema) CountField ¶
func (qs *QuerySchema) CountField() map[int]bool
func (*QuerySchema) DerivedOrigCall ¶
func (qs *QuerySchema) DerivedOrigCall(call *influxql.Call) influxql.VarRef
func (*QuerySchema) DerivedRef ¶
func (qs *QuerySchema) DerivedRef(ref *influxql.VarRef) influxql.VarRef
func (*QuerySchema) Fields ¶
func (qs *QuerySchema) Fields() influxql.Fields
func (*QuerySchema) FieldsRef ¶
func (qs *QuerySchema) FieldsRef() influxql.VarRefs
func (*QuerySchema) GetColumnNames ¶
func (qs *QuerySchema) GetColumnNames() []string
func (*QuerySchema) GetFieldType ¶ added in v1.0.0
func (qs *QuerySchema) GetFieldType(i int) (int64, error)
func (*QuerySchema) GetJoinCaseCount ¶ added in v1.0.0
func (qs *QuerySchema) GetJoinCaseCount() int
func (*QuerySchema) GetJoinCases ¶ added in v1.0.0
func (qs *QuerySchema) GetJoinCases() []*influxql.Join
func (*QuerySchema) GetOptions ¶
func (qs *QuerySchema) GetOptions() hybridqp.Options
func (*QuerySchema) GetPlanType ¶ added in v1.1.0
func (qs *QuerySchema) GetPlanType() PlanType
func (*QuerySchema) GetPromCalls ¶ added in v1.3.0
func (qs *QuerySchema) GetPromCalls() []*influxql.PromSubCall
func (*QuerySchema) GetQueryFields ¶
func (qs *QuerySchema) GetQueryFields() influxql.Fields
func (*QuerySchema) GetSortFields ¶ added in v1.1.0
func (qs *QuerySchema) GetSortFields() influxql.SortFields
func (*QuerySchema) GetSourcesNames ¶ added in v1.0.0
func (qs *QuerySchema) GetSourcesNames() []string
func (*QuerySchema) GetTimeRangeByTC ¶ added in v1.2.0
func (qs *QuerySchema) GetTimeRangeByTC() util.TimeRange
func (*QuerySchema) GetUnnests ¶ added in v1.2.0
func (qs *QuerySchema) GetUnnests() influxql.Unnests
func (*QuerySchema) HasAuxTag ¶ added in v1.0.0
func (qs *QuerySchema) HasAuxTag() bool
func (*QuerySchema) HasBlankRowCall ¶
func (qs *QuerySchema) HasBlankRowCall() bool
func (*QuerySchema) HasCall ¶
func (qs *QuerySchema) HasCall() bool
func (*QuerySchema) HasCastorCall ¶ added in v0.2.0
func (qs *QuerySchema) HasCastorCall() bool
func (*QuerySchema) HasExcatLimit ¶ added in v1.0.0
func (qs *QuerySchema) HasExcatLimit() bool
func (*QuerySchema) HasFieldCondition ¶
func (qs *QuerySchema) HasFieldCondition() bool
func (*QuerySchema) HasGroupBy ¶
func (qs *QuerySchema) HasGroupBy() bool
func (*QuerySchema) HasHoltWintersCall ¶ added in v1.0.0
func (qs *QuerySchema) HasHoltWintersCall() bool
func (*QuerySchema) HasInSeriesAgg ¶
func (qs *QuerySchema) HasInSeriesAgg() bool
func (*QuerySchema) HasInterval ¶
func (qs *QuerySchema) HasInterval() bool
func (*QuerySchema) HasLabelCalls ¶ added in v1.3.0
func (qs *QuerySchema) HasLabelCalls() bool
func (*QuerySchema) HasLimit ¶
func (qs *QuerySchema) HasLimit() bool
func (*QuerySchema) HasMath ¶
func (qs *QuerySchema) HasMath() bool
func (*QuerySchema) HasMeanCall ¶
func (qs *QuerySchema) HasMeanCall() bool
func (*QuerySchema) HasNonPreCall ¶
func (qs *QuerySchema) HasNonPreCall() bool
func (*QuerySchema) HasNotInSeriesAgg ¶
func (qs *QuerySchema) HasNotInSeriesAgg() bool
func (*QuerySchema) HasOptimizeAgg ¶ added in v1.0.0
func (qs *QuerySchema) HasOptimizeAgg() bool
func (*QuerySchema) HasOptimizeCall ¶ added in v1.1.0
func (qs *QuerySchema) HasOptimizeCall() bool
func (*QuerySchema) HasPercentileOGSketch ¶ added in v1.0.0
func (qs *QuerySchema) HasPercentileOGSketch() bool
func (*QuerySchema) HasPromAbsentCall ¶ added in v1.4.0
func (qs *QuerySchema) HasPromAbsentCall() bool
func (*QuerySchema) HasPromNestedCall ¶ added in v1.3.0
func (qs *QuerySchema) HasPromNestedCall() bool
func (*QuerySchema) HasPromTimeCalls ¶ added in v1.3.0
func (qs *QuerySchema) HasPromTimeCalls() bool
func (*QuerySchema) HasRowCount ¶ added in v1.1.0
func (qs *QuerySchema) HasRowCount() bool
HasRowCount check whether all data is queried to use mst-level pre-aggregation.
func (*QuerySchema) HasSlidingWindowCall ¶
func (qs *QuerySchema) HasSlidingWindowCall() bool
func (*QuerySchema) HasSort ¶ added in v1.1.0
func (qs *QuerySchema) HasSort() bool
func (*QuerySchema) HasStreamCall ¶
func (qs *QuerySchema) HasStreamCall() bool
func (*QuerySchema) HasString ¶
func (qs *QuerySchema) HasString() bool
func (*QuerySchema) HasSubQuery ¶
func (qs *QuerySchema) HasSubQuery() bool
func (*QuerySchema) HasTopNDDCM ¶ added in v1.4.0
func (qs *QuerySchema) HasTopNDDCM() bool
func (*QuerySchema) HasUnnests ¶ added in v1.2.0
func (qs *QuerySchema) HasUnnests() bool
func (*QuerySchema) HoltWinters ¶ added in v1.0.0
func (qs *QuerySchema) HoltWinters() []*influxql.Field
func (*QuerySchema) InitFieldCondition ¶ added in v1.0.0
func (qs *QuerySchema) InitFieldCondition()
func (*QuerySchema) IsHoltWinters ¶ added in v1.1.0
func (qs *QuerySchema) IsHoltWinters(val string) bool
func (*QuerySchema) IsMultiMeasurements ¶
func (qs *QuerySchema) IsMultiMeasurements() bool
func (*QuerySchema) IsPromAbsentCall ¶ added in v1.4.0
func (qs *QuerySchema) IsPromAbsentCall() bool
func (*QuerySchema) IsPromNestedCall ¶ added in v1.3.0
func (qs *QuerySchema) IsPromNestedCall(call *influxql.Call) bool
func (*QuerySchema) IsPromNestedCountCall ¶ added in v1.4.0
func (qs *QuerySchema) IsPromNestedCountCall() bool
func (*QuerySchema) IsRefInQueryFields ¶
func (qs *QuerySchema) IsRefInQueryFields(ref *influxql.VarRef) bool
func (*QuerySchema) IsRefInSymbolFields ¶
func (qs *QuerySchema) IsRefInSymbolFields(ref *influxql.VarRef) bool
func (*QuerySchema) IsTimeZero ¶
func (qs *QuerySchema) IsTimeZero() bool
func (*QuerySchema) LimitAndOffset ¶
func (qs *QuerySchema) LimitAndOffset() (int, int)
func (*QuerySchema) LimitType ¶
func (qs *QuerySchema) LimitType() hybridqp.LimitType
func (*QuerySchema) MakeRefs ¶
func (qs *QuerySchema) MakeRefs() []influxql.VarRef
func (*QuerySchema) MatchPreAgg ¶
func (qs *QuerySchema) MatchPreAgg() bool
func (*QuerySchema) OnlyOneCallRef ¶
func (qs *QuerySchema) OnlyOneCallRef() *influxql.VarRef
func (*QuerySchema) Options ¶
func (qs *QuerySchema) Options() hybridqp.Options
func (*QuerySchema) PromNestedCall ¶ added in v1.3.0
func (qs *QuerySchema) PromNestedCall() map[string]*hybridqp.PromNestedCall
func (*QuerySchema) PromResetTime ¶ added in v1.3.0
func (qs *QuerySchema) PromResetTime() bool
PromResetTime is used to determine whether to set the time of result to the end time of the query, according to the semantics of the prom instant query,
func (*QuerySchema) SetFill ¶ added in v1.1.0
func (qs *QuerySchema) SetFill(fill influxql.FillOption)
func (*QuerySchema) SetHoltWinters ¶ added in v1.0.0
func (qs *QuerySchema) SetHoltWinters(calls []*influxql.Call)
func (*QuerySchema) SetOpt ¶
func (qs *QuerySchema) SetOpt(opt hybridqp.Options)
func (*QuerySchema) SetPlanType ¶ added in v1.1.0
func (qs *QuerySchema) SetPlanType(planType PlanType)
func (*QuerySchema) SetPromCalls ¶ added in v1.3.0
func (qs *QuerySchema) SetPromCalls(calls []*influxql.PromSubCall)
func (*QuerySchema) SetSimpleTagset ¶ added in v1.3.0
func (qs *QuerySchema) SetSimpleTagset()
func (*QuerySchema) SetUnnests ¶ added in v1.2.0
func (qs *QuerySchema) SetUnnests(unnests []*influxql.Unnest)
func (*QuerySchema) SlidingWindow ¶
func (qs *QuerySchema) SlidingWindow() map[string]*influxql.Call
func (*QuerySchema) Sources ¶
func (qs *QuerySchema) Sources() influxql.Sources
func (*QuerySchema) Table ¶
func (qs *QuerySchema) Table(name string) *QueryTable
type QuerySchemaCreator ¶
type QuerySchemaCreator struct {
}
type QueryTable ¶
type QueryTable struct {
// contains filtered or unexported fields
}
func NewQueryTable ¶
func NewQueryTable(m *influxql.Measurement, refs []influxql.VarRef) *QueryTable
func (*QueryTable) Name ¶
func (b *QueryTable) Name() string
func (*QueryTable) RowDataType ¶
func (b *QueryTable) RowDataType() hybridqp.RowDataType
type RPCClient ¶
type RPCClient struct {
// contains filtered or unexported fields
}
func NewRPCClient ¶
func NewRPCClient(query *RemoteQuery) *RPCClient
func (*RPCClient) AddHandler ¶
func (*RPCClient) FinishAnalyze ¶
func (c *RPCClient) FinishAnalyze()
func (*RPCClient) StartAnalyze ¶
type RPCReaderTransform ¶
type RPCReaderTransform struct {
BaseProcessor
Output *ChunkPort
NoMarkCrash bool
// contains filtered or unexported fields
}
func NewRPCReaderTransform ¶
func NewRPCReaderTransform(outRowDataType hybridqp.RowDataType, queryId uint64, rq *RemoteQuery) *RPCReaderTransform
func (*RPCReaderTransform) Abort ¶
func (t *RPCReaderTransform) Abort()
func (*RPCReaderTransform) Close ¶
func (t *RPCReaderTransform) Close()
func (*RPCReaderTransform) Distribute ¶
func (t *RPCReaderTransform) Distribute(node hybridqp.QueryNode)
func (*RPCReaderTransform) Explain ¶
func (t *RPCReaderTransform) Explain() []ValuePair
func (*RPCReaderTransform) GetInputNumber ¶
func (t *RPCReaderTransform) GetInputNumber(_ Port) int
func (*RPCReaderTransform) GetInputs ¶
func (t *RPCReaderTransform) GetInputs() Ports
func (*RPCReaderTransform) GetOutputNumber ¶
func (t *RPCReaderTransform) GetOutputNumber(_ Port) int
func (*RPCReaderTransform) GetOutputs ¶
func (t *RPCReaderTransform) GetOutputs() Ports
func (*RPCReaderTransform) Interrupt ¶ added in v1.3.0
func (t *RPCReaderTransform) Interrupt()
func (*RPCReaderTransform) InterruptWithoutMark ¶ added in v1.4.0
func (t *RPCReaderTransform) InterruptWithoutMark()
func (*RPCReaderTransform) IsSink ¶
func (t *RPCReaderTransform) IsSink() bool
func (*RPCReaderTransform) Name ¶
func (t *RPCReaderTransform) Name() string
func (*RPCReaderTransform) Release ¶
func (t *RPCReaderTransform) Release() error
type RPCSenderTransform ¶
type RPCSenderTransform struct {
BaseProcessor
Input *ChunkPort
// contains filtered or unexported fields
}
func NewRPCSenderTransform ¶
func NewRPCSenderTransform(rt hybridqp.RowDataType, w spdy.Responser) *RPCSenderTransform
func (*RPCSenderTransform) Close ¶
func (t *RPCSenderTransform) Close()
func (*RPCSenderTransform) Explain ¶
func (t *RPCSenderTransform) Explain() []ValuePair
func (*RPCSenderTransform) GetInputNumber ¶
func (t *RPCSenderTransform) GetInputNumber(_ Port) int
func (*RPCSenderTransform) GetInputs ¶
func (t *RPCSenderTransform) GetInputs() Ports
func (*RPCSenderTransform) GetOutputNumber ¶
func (t *RPCSenderTransform) GetOutputNumber(_ Port) int
func (*RPCSenderTransform) GetOutputs ¶
func (t *RPCSenderTransform) GetOutputs() Ports
func (*RPCSenderTransform) Name ¶
func (t *RPCSenderTransform) Name() string
type RateFinalReduceFunc ¶ added in v1.3.0
type RateMergeFunc ¶ added in v1.3.0
type RateMiddleReduceFunc ¶ added in v1.3.0
type RateUpdateFunc ¶ added in v1.3.0
type RateUpdateFunc[T util.NumberOnly] func(prevPoints, currPoints [2]*Point[T])
type ReaderCreator ¶ added in v1.1.0
type ReaderCreatorFactory ¶ added in v1.1.0
type ReaderCreatorFactory struct {
// contains filtered or unexported fields
}
func GetReaderFactoryInstance ¶ added in v1.1.0
func GetReaderFactoryInstance() *ReaderCreatorFactory
func NewReaderCreatorFactory ¶ added in v1.1.0
func NewReaderCreatorFactory() *ReaderCreatorFactory
func (*ReaderCreatorFactory) Add ¶ added in v1.1.0
func (r *ReaderCreatorFactory) Add(name string, creator ReaderCreator)
func (*ReaderCreatorFactory) Find ¶ added in v1.1.0
func (r *ReaderCreatorFactory) Find(name string) (ReaderCreator, bool)
type ReaderUpdateInSubQueryRule ¶
type ReaderUpdateInSubQueryRule struct {
OptRuleBase
}
func NewReaderUpdateInSubQueryRule ¶
func NewReaderUpdateInSubQueryRule(description string) *ReaderUpdateInSubQueryRule
func (*ReaderUpdateInSubQueryRule) Catagory ¶
func (r *ReaderUpdateInSubQueryRule) Catagory() OptRuleCatagory
func (*ReaderUpdateInSubQueryRule) Equals ¶
func (r *ReaderUpdateInSubQueryRule) Equals(rhs OptRule) bool
func (*ReaderUpdateInSubQueryRule) OnMatch ¶
func (r *ReaderUpdateInSubQueryRule) OnMatch(call *OptRuleCall)
func (*ReaderUpdateInSubQueryRule) ToString ¶
func (r *ReaderUpdateInSubQueryRule) ToString() string
type ReflectionTable ¶
type ReflectionTable []int
type ReflectionTables ¶
type ReflectionTables []ReflectionTable
type RemoteQuery ¶
type RemoteQuery struct {
Database string
PtID uint32 // for tsstore
NodeID uint64
ShardIDs []uint64 // for tsstore
PtQuerys []PtQuery // for csstore
Opt query.ProcessorOptions
Analyze bool
Node []byte
}
func (*RemoteQuery) Empty ¶ added in v1.2.0
func (c *RemoteQuery) Empty() bool
func (*RemoteQuery) HaveLocalMst ¶ added in v1.2.0
func (c *RemoteQuery) HaveLocalMst() bool
func (*RemoteQuery) Instance ¶
func (c *RemoteQuery) Instance() transport.Codec
func (*RemoteQuery) Len ¶ added in v1.2.0
func (c *RemoteQuery) Len() int
func (*RemoteQuery) Size ¶
func (c *RemoteQuery) Size() int
func (*RemoteQuery) Unmarshal ¶
func (c *RemoteQuery) Unmarshal(buf []byte) error
type ResultEval ¶ added in v1.2.0
type ResultEval struct {
// contains filtered or unexported fields
}
func (*ResultEval) IsNil ¶ added in v1.2.0
func (re *ResultEval) IsNil(i int) bool
type ResultEvalPool ¶ added in v1.2.0
type ResultEvalPool struct {
// contains filtered or unexported fields
}
func NewResultEvalPool ¶ added in v1.2.0
func NewResultEvalPool(len int, isPromQuery bool) *ResultEvalPool
type RetryErrTransform ¶ added in v1.4.0
type RetryErrTransform struct {
BaseProcessor
}
func NewRetryErrTransform ¶ added in v1.4.0
func NewRetryErrTransform() *RetryErrTransform
func (*RetryErrTransform) Close ¶ added in v1.4.0
func (source *RetryErrTransform) Close()
func (*RetryErrTransform) Explain ¶ added in v1.4.0
func (source *RetryErrTransform) Explain() []ValuePair
func (*RetryErrTransform) GetInputNumber ¶ added in v1.4.0
func (source *RetryErrTransform) GetInputNumber(_ Port) int
func (*RetryErrTransform) GetInputs ¶ added in v1.4.0
func (source *RetryErrTransform) GetInputs() Ports
func (*RetryErrTransform) GetOutputNumber ¶ added in v1.4.0
func (source *RetryErrTransform) GetOutputNumber(_ Port) int
func (*RetryErrTransform) GetOutputs ¶ added in v1.4.0
func (source *RetryErrTransform) GetOutputs() Ports
func (*RetryErrTransform) Name ¶ added in v1.4.0
func (source *RetryErrTransform) Name() string
type Routine ¶
type Routine interface {
WorkOnChunk(Chunk, Chunk, *IteratorParams)
}
func NewAbsentRoutineImpl ¶
func NewAbsentRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool) (Routine, error)
func NewBottomRoutineImpl ¶
func NewBottomRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, auxProcessor []*AuxProcessor, ops *query.ProcessorOptions) (Routine, error)
func NewCountRoutineImpl ¶
func NewCountRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool) (Routine, error)
func NewCumulativeSumRoutineImpl ¶
func NewCumulativeSumRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool, ) (Routine, error)
func NewDerivativeRoutineImpl ¶
func NewDerivativeRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall, isNonNegative, ascending bool, interval hybridqp.Interval, ) (Routine, error)
func NewDifferenceRoutineImpl ¶
func NewDifferenceRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall, isNonNegative bool, ) (Routine, error)
func NewDistinctRoutineImpl ¶
func NewDistinctRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions) (Routine, error)
func NewElapsedRoutineImpl ¶
func NewElapsedRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool, ) (Routine, error)
func NewFirstRoutineImpl ¶
func NewFirstRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool, auxProcessor []*AuxProcessor) (Routine, error)
func NewIntegralRoutineImpl ¶
func NewIntegralRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, opts *query.ProcessorOptions, isSingleCall bool, ) (Routine, error)
func NewLastRoutineImpl ¶
func NewLastRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool, auxProcessor []*AuxProcessor) (Routine, error)
func NewMedianRoutineImpl ¶
func NewMedianRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool) (Routine, error)
func NewModeRoutineImpl ¶
func NewModeRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool) (Routine, error)
func NewMovingAverageRoutineImpl ¶
func NewMovingAverageRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool) (Routine, error)
func NewPercentileApproxRoutineImpl ¶ added in v1.0.0
func NewPercentileApproxRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, exprOpt hybridqp.ExprOptions, isSingleCall bool, opt *query.ProcessorOptions, name string, clusterNum int, percentile float64) (Routine, error)
func NewPercentileRoutineImpl ¶
func NewPercentileRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool, auxProcessor []*AuxProcessor) (Routine, error)
func NewRateRoutineImpl ¶
func NewRateRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall, isRate bool, interval hybridqp.Interval, ) (Routine, error)
func NewSampleRoutineImpl ¶
func NewSampleRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool, auxProcessor []*AuxProcessor) (Routine, error)
func NewSlidingWindowCountRoutineImpl ¶
func NewSlidingWindowCountRoutineImpl( inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, slidingNum int, ) Routine
func NewSlidingWindowMaxRoutineImpl ¶
func NewSlidingWindowMaxRoutineImpl( inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, slidingNum int, ) Routine
func NewSlidingWindowMinRoutineImpl ¶
func NewSlidingWindowMinRoutineImpl( inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, slidingNum int, ) Routine
func NewSlidingWindowSumRoutineImpl ¶
func NewSlidingWindowSumRoutineImpl( inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, slidingNum int, ) Routine
func NewStddevRoutineImpl ¶
func NewStddevRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool, ) (Routine, error)
func NewSumRoutineImpl ¶
func NewSumRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, isSingleCall bool) (Routine, error)
func NewTopRoutineImpl ¶
func NewTopRoutineImpl(inRowDataType, outRowDataType hybridqp.RowDataType, opt hybridqp.ExprOptions, auxProcessor []*AuxProcessor, ops *query.ProcessorOptions) (Routine, error)
type RoutineImpl ¶
type RoutineImpl struct {
// contains filtered or unexported fields
}
func NewRoutineImpl ¶
func NewRoutineImpl(iterator Iterator, inOrdinal int, outOrdinal int) *RoutineImpl
func (*RoutineImpl) WorkOnChunk ¶
func (r *RoutineImpl) WorkOnChunk(in Chunk, out Chunk, params *IteratorParams)
type RowsGenerator ¶ added in v1.1.0
type RowsGenerator struct {
// contains filtered or unexported fields
}
func NewRowsGenerator ¶ added in v1.1.0
func NewRowsGenerator() *RowsGenerator
func (*RowsGenerator) GetColValue ¶ added in v1.1.0
func (g *RowsGenerator) GetColValue(col2 Column, idx int) interface{}
func (*RowsGenerator) Release ¶ added in v1.1.0
func (g *RowsGenerator) Release()
func (*RowsGenerator) Reset ¶ added in v1.1.0
func (g *RowsGenerator) Reset()
type RuleInstruction ¶
type RuleInstruction struct {
// contains filtered or unexported fields
}
func NewRuleInstruction ¶
func NewRuleInstruction(ruleCatatory OptRuleCatagory) *RuleInstruction
func (*RuleInstruction) Execute ¶
func (g *RuleInstruction) Execute(planner HeuPlanner)
func (*RuleInstruction) Initialize ¶
func (g *RuleInstruction) Initialize(clearCache bool)
func (*RuleInstruction) RuleCatagory ¶
func (g *RuleInstruction) RuleCatagory() OptRuleCatagory
func (*RuleInstruction) SkippingGroup ¶ added in v1.1.0
func (g *RuleInstruction) SkippingGroup(schema hybridqp.Catalog) bool
type SampleItem ¶ added in v1.3.0
func NewSampleItem ¶ added in v1.3.0
func NewSampleItem[T util.BasicType](items []PointItem[T]) *SampleItem[T]
func (*SampleItem[T]) Len ¶ added in v1.3.0
func (f *SampleItem[T]) Len() int
func (*SampleItem[T]) Less ¶ added in v1.3.0
func (f *SampleItem[T]) Less(i, j int) bool
func (*SampleItem[T]) Reset ¶ added in v1.3.0
func (f *SampleItem[T]) Reset()
func (*SampleItem[T]) Swap ¶ added in v1.3.0
func (f *SampleItem[T]) Swap(i, j int)
type ScalarBuf ¶ added in v1.3.0
type ScalarBuf struct {
// contains filtered or unexported fields
}
type ScalarIterator ¶ added in v1.3.0
type ScalarIterator struct {
// contains filtered or unexported fields
}
func NewScalarIterator ¶ added in v1.3.0
func NewScalarIterator(inOrdinal, outOrdinal int) *ScalarIterator
func (*ScalarIterator) Next ¶ added in v1.3.0
func (r *ScalarIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type SeriesRecord ¶ added in v1.0.0
type SeriesRecord struct {
// contains filtered or unexported fields
}
func NewSeriesRecord ¶ added in v1.0.0
func (*SeriesRecord) GetErr ¶ added in v1.0.0
func (r *SeriesRecord) GetErr() error
func (*SeriesRecord) GetRec ¶ added in v1.0.0
func (r *SeriesRecord) GetRec() *record.Record
func (*SeriesRecord) GetSeq ¶ added in v1.0.0
func (r *SeriesRecord) GetSeq() uint64
func (*SeriesRecord) GetSid ¶ added in v1.0.0
func (r *SeriesRecord) GetSid() uint64
func (*SeriesRecord) GetTr ¶ added in v1.0.1
func (r *SeriesRecord) GetTr() *util.TimeRange
func (*SeriesRecord) GetTsspFile ¶ added in v1.0.0
func (r *SeriesRecord) GetTsspFile() immutable.TSSPFile
func (*SeriesRecord) SetRec ¶ added in v1.0.1
func (r *SeriesRecord) SetRec(re *record.Record)
type SeriesRecordPort ¶ added in v1.0.0
type SeriesRecordPort struct {
RowDataType hybridqp.RowDataType
State chan *SeriesRecord
OrigiState chan *SeriesRecord
Redirected bool
// contains filtered or unexported fields
}
func NewSeriesRecordPort ¶ added in v1.0.0
func NewSeriesRecordPort(rowDataType hybridqp.RowDataType) *SeriesRecordPort
func (*SeriesRecordPort) Close ¶ added in v1.0.0
func (p *SeriesRecordPort) Close()
func (*SeriesRecordPort) Connect ¶ added in v1.0.0
func (p *SeriesRecordPort) Connect(to Port)
func (*SeriesRecordPort) ConnectWithoutCache ¶ added in v1.0.0
func (p *SeriesRecordPort) ConnectWithoutCache(to Port)
func (*SeriesRecordPort) ConnectionId ¶ added in v1.0.0
func (p *SeriesRecordPort) ConnectionId() uintptr
func (*SeriesRecordPort) Equal ¶ added in v1.0.0
func (p *SeriesRecordPort) Equal(to Port) bool
func (*SeriesRecordPort) Redirect ¶ added in v1.0.0
func (p *SeriesRecordPort) Redirect(to Port)
func (*SeriesRecordPort) Release ¶ added in v1.0.0
func (p *SeriesRecordPort) Release()
type SetSchemaVisitor ¶
type SetSchemaVisitor struct {
// contains filtered or unexported fields
}
func (*SetSchemaVisitor) Visit ¶
func (v *SetSchemaVisitor) Visit(node hybridqp.QueryNode) hybridqp.QueryNodeVisitor
type ShardFileFragment ¶ added in v1.1.0
type ShardFileFragment struct {
// contains filtered or unexported fields
}
func NewShardFileFragment ¶ added in v1.1.0
func NewShardFileFragment(shardId uint64, item FileFragment) *ShardFileFragment
type ShardInfo ¶ added in v1.2.0
type ShardInfo struct {
ID uint64
Path string // used for remote storage
Version uint32 // identify data from different layouts
}
func UnmarshalShardInfos ¶ added in v1.2.0
type ShardsFragments ¶ added in v1.1.0
type ShardsFragments map[uint64]*FileFragments
func NewShardsFragments ¶ added in v1.1.0
func NewShardsFragments() ShardsFragments
func (*ShardsFragments) String ¶ added in v1.1.0
func (sfs *ShardsFragments) String() string
type ShardsFragmentsGroup ¶ added in v1.1.0
type ShardsFragmentsGroup struct {
// contains filtered or unexported fields
}
func NewShardsFragmentsGroup ¶ added in v1.1.0
func NewShardsFragmentsGroup(frags ShardsFragments, fragmentCount int64) *ShardsFragmentsGroup
func (*ShardsFragmentsGroup) GetFragmentCount ¶ added in v1.1.0
func (sfg *ShardsFragmentsGroup) GetFragmentCount() int64
func (*ShardsFragmentsGroup) GetFrags ¶ added in v1.1.0
func (sfg *ShardsFragmentsGroup) GetFrags() ShardsFragments
func (*ShardsFragmentsGroup) MoveTo ¶ added in v1.1.0
func (sfg *ShardsFragmentsGroup) MoveTo(des *ShardsFragmentsGroup, id uint64, filePath string)
func (*ShardsFragmentsGroup) MoveToFileNotExist ¶ added in v1.1.0
func (sfg *ShardsFragmentsGroup) MoveToFileNotExist(des *ShardsFragmentsGroup)
func (*ShardsFragmentsGroup) SearchAndMoveExistFile ¶ added in v1.1.0
func (sfg *ShardsFragmentsGroup) SearchAndMoveExistFile(des *ShardsFragmentsGroup)
type ShardsFragmentsGroups ¶ added in v1.1.0
type ShardsFragmentsGroups struct {
Items []*ShardsFragmentsGroup
// contains filtered or unexported fields
}
func DistributeFragments ¶ added in v1.1.0
func DistributeFragments(frags ShardsFragments, parallel int) (*ShardsFragmentsGroups, error)
DistributeFragments used for balanced fragment allocation of data files. Get a complete view and assign it directly. Considering the total number of fragments, only about the same number of fragments are placed in a group during initialization.
func DistributeFragmentsV2 ¶ added in v1.1.0
func DistributeFragmentsV2(frags ShardsFragments, parallel int) (*ShardsFragmentsGroups, error)
DistributeFragmentsV2 allocates fragments based on the parallel number so that the difference number of fragments between two groups is less than or equal to 1.
func NewShardsFragmentsGroups ¶ added in v1.1.0
func NewShardsFragmentsGroups(parallel int) *ShardsFragmentsGroups
func (*ShardsFragmentsGroups) Balance ¶ added in v1.1.0
func (fgs *ShardsFragmentsGroups) Balance()
func (*ShardsFragmentsGroups) HasGroup ¶ added in v1.2.0
func (fgs *ShardsFragmentsGroups) HasGroup() bool
func (*ShardsFragmentsGroups) Len ¶ added in v1.1.0
func (fgs *ShardsFragmentsGroups) Len() int
func (*ShardsFragmentsGroups) Less ¶ added in v1.1.0
func (fgs *ShardsFragmentsGroups) Less(i, j int) bool
func (*ShardsFragmentsGroups) MoveFrags ¶ added in v1.1.0
func (fgs *ShardsFragmentsGroups) MoveFrags(from, to int)
func (*ShardsFragmentsGroups) NextGroup ¶ added in v1.2.0
func (fgs *ShardsFragmentsGroups) NextGroup() *ShardsFragmentsGroup
func (*ShardsFragmentsGroups) PeekGroup ¶ added in v1.2.0
func (fgs *ShardsFragmentsGroups) PeekGroup() *ShardsFragmentsGroup
func (*ShardsFragmentsGroups) Pop ¶ added in v1.1.0
func (fgs *ShardsFragmentsGroups) Pop() interface{}
func (*ShardsFragmentsGroups) Push ¶ added in v1.1.0
func (fgs *ShardsFragmentsGroups) Push(x interface{})
func (*ShardsFragmentsGroups) String ¶ added in v1.1.0
func (fgs *ShardsFragmentsGroups) String() string
func (*ShardsFragmentsGroups) Swap ¶ added in v1.1.0
func (fgs *ShardsFragmentsGroups) Swap(i, j int)
type SinkFromFunction ¶
type SinkFromFunction struct {
BaseProcessor
Input *ChunkPort
Function func(chunk Chunk) error
}
func NewSinkFromFunction ¶
func NewSinkFromFunction(rowDataType hybridqp.RowDataType, function func(chunk Chunk) error) *SinkFromFunction
func (*SinkFromFunction) Close ¶
func (sink *SinkFromFunction) Close()
func (*SinkFromFunction) Explain ¶
func (sink *SinkFromFunction) Explain() []ValuePair
func (*SinkFromFunction) GetInputNumber ¶
func (sink *SinkFromFunction) GetInputNumber(_ Port) int
func (*SinkFromFunction) GetInputs ¶
func (sink *SinkFromFunction) GetInputs() Ports
func (*SinkFromFunction) GetOutputNumber ¶
func (sink *SinkFromFunction) GetOutputNumber(_ Port) int
func (*SinkFromFunction) GetOutputs ¶
func (sink *SinkFromFunction) GetOutputs() Ports
func (*SinkFromFunction) Name ¶
func (sink *SinkFromFunction) Name() string
type SliceItem ¶ added in v1.3.0
type SliceItem[T util.ExceptBool] struct { // contains filtered or unexported fields }
func NewSliceItem ¶ added in v1.3.0
func NewSliceItem[T util.ExceptBool]() *SliceItem[T]
func (*SliceItem[T]) AppendItem ¶ added in v1.3.0
type SliceReduce ¶ added in v1.3.0
type SliceReduce[T util.NumberOnly] func(floatItem *SliceItem[T]) (index int, time int64, value float64, isNil bool)
func NewPercentileReduce ¶ added in v1.3.0
func NewPercentileReduce[T util.NumberOnly](percentile float64) SliceReduce[T]
func NewStdDevReduce ¶ added in v1.3.0
func NewStdDevReduce[T util.NumberOnly]() SliceReduce[T]
func NewStdReduce ¶ added in v1.3.0
func NewStdReduce(isStddev bool) SliceReduce[float64]
func QuantileReduce ¶ added in v1.3.0
func QuantileReduce(percentile float64) SliceReduce[float64]
type SlideWindowSpreadRule ¶
type SlideWindowSpreadRule struct {
OptRuleBase
}
func NewSlideWindowSpreadRule ¶
func NewSlideWindowSpreadRule(description string) *SlideWindowSpreadRule
func (*SlideWindowSpreadRule) Catagory ¶
func (r *SlideWindowSpreadRule) Catagory() OptRuleCatagory
func (*SlideWindowSpreadRule) Equals ¶
func (r *SlideWindowSpreadRule) Equals(rhs OptRule) bool
func (*SlideWindowSpreadRule) OnMatch ¶
func (r *SlideWindowSpreadRule) OnMatch(call *OptRuleCall)
func (*SlideWindowSpreadRule) ToString ¶
func (r *SlideWindowSpreadRule) ToString() string
type SlidingWindow ¶ added in v1.3.0
type SlidingWindow[T util.ExceptString] struct { // contains filtered or unexported fields }
func NewSlidingWindow ¶ added in v1.3.0
func NewSlidingWindow[T util.ExceptString](slidingNum int) *SlidingWindow[T]
func (*SlidingWindow[T]) IsNil ¶ added in v1.3.0
func (w *SlidingWindow[T]) IsNil() bool
func (*SlidingWindow[T]) Len ¶ added in v1.3.0
func (w *SlidingWindow[T]) Len() int
func (*SlidingWindow[T]) Reset ¶ added in v1.3.0
func (w *SlidingWindow[T]) Reset()
func (*SlidingWindow[T]) SetPoint ¶ added in v1.3.0
func (w *SlidingWindow[T]) SetPoint(value T, isNil bool, index int)
type SlidingWindowBooleanIterator ¶ added in v1.3.0
type SlidingWindowBooleanIterator struct {
// contains filtered or unexported fields
}
func NewSlidingWindowBooleanIterator ¶ added in v1.3.0
func NewSlidingWindowBooleanIterator( fwr BooleanColBooleanWindowReduce, fpm PointMerge[bool], fwm WindowMerge[bool], inOrdinal, outOrdinal int, slidingNum int, ) *SlidingWindowBooleanIterator
func (*SlidingWindowBooleanIterator) Next ¶ added in v1.3.0
func (r *SlidingWindowBooleanIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type SlidingWindowFloatIterator ¶ added in v1.3.0
type SlidingWindowFloatIterator struct {
// contains filtered or unexported fields
}
func NewSlidingWindowFloatIterator ¶ added in v1.3.0
func NewSlidingWindowFloatIterator( fwr ColReduceFunc[float64], fpm PointMerge[float64], fwm WindowMerge[float64], inOrdinal, outOrdinal int, slidingNum int, ) *SlidingWindowFloatIterator
func (*SlidingWindowFloatIterator) Next ¶ added in v1.3.0
func (r *SlidingWindowFloatIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type SlidingWindowIntegerIterator ¶ added in v1.3.0
type SlidingWindowIntegerIterator struct {
// contains filtered or unexported fields
}
func NewSlidingWindowIntegerIterator ¶ added in v1.3.0
func NewSlidingWindowIntegerIterator( fwr ColReduceFunc[int64], fpm PointMerge[int64], fwm WindowMerge[int64], inOrdinal, outOrdinal int, slidingNum int, ) *SlidingWindowIntegerIterator
func (*SlidingWindowIntegerIterator) Next ¶ added in v1.3.0
func (r *SlidingWindowIntegerIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type SlidingWindowTransform ¶
type SlidingWindowTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
// contains filtered or unexported fields
}
func NewSlidingWindowTransform ¶
func NewSlidingWindowTransform( inRowDataType, outRowDataType []hybridqp.RowDataType, exprOpt []hybridqp.ExprOptions, opt *query.ProcessorOptions, schema hybridqp.Catalog, ) *SlidingWindowTransform
func (*SlidingWindowTransform) Close ¶
func (trans *SlidingWindowTransform) Close()
func (*SlidingWindowTransform) Explain ¶
func (trans *SlidingWindowTransform) Explain() []ValuePair
func (*SlidingWindowTransform) GetInputNumber ¶
func (trans *SlidingWindowTransform) GetInputNumber(port Port) int
func (*SlidingWindowTransform) GetInputs ¶
func (trans *SlidingWindowTransform) GetInputs() Ports
func (*SlidingWindowTransform) GetOutputNumber ¶
func (trans *SlidingWindowTransform) GetOutputNumber(port Port) int
func (*SlidingWindowTransform) GetOutputs ¶
func (trans *SlidingWindowTransform) GetOutputs() Ports
func (*SlidingWindowTransform) Name ¶
func (trans *SlidingWindowTransform) Name() string
type SlidingWindowTransformCreator ¶
type SlidingWindowTransformCreator struct {
}
func (*SlidingWindowTransformCreator) Create ¶
func (c *SlidingWindowTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type SortAppendTransf ¶ added in v1.0.0
type SortAppendTransf struct {
}
func (*SortAppendTransf) CostName ¶ added in v1.0.0
func (t *SortAppendTransf) CostName() string
func (*SortAppendTransf) GetType ¶ added in v1.0.0
func (t *SortAppendTransf) GetType() MergeTransformType
func (*SortAppendTransf) InitColumnsIteratorHelper ¶ added in v1.0.0
func (t *SortAppendTransf) InitColumnsIteratorHelper(rt hybridqp.RowDataType) CoProcessor
func (*SortAppendTransf) InitHeapItems ¶ added in v1.0.0
func (t *SortAppendTransf) InitHeapItems(inRowDataLen int, _ hybridqp.RowDataType, schema *QuerySchema) BaseHeapItems
func (*SortAppendTransf) Name ¶ added in v1.0.0
func (t *SortAppendTransf) Name() string
type SortAppendTransformCreator ¶
type SortAppendTransformCreator struct {
}
func (*SortAppendTransformCreator) Create ¶
func (c *SortAppendTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type SortMergeTransf ¶ added in v1.0.0
type SortMergeTransf struct {
}
func (*SortMergeTransf) CostName ¶ added in v1.0.0
func (t *SortMergeTransf) CostName() string
func (*SortMergeTransf) GetType ¶ added in v1.0.0
func (t *SortMergeTransf) GetType() MergeTransformType
func (*SortMergeTransf) InitColumnsIteratorHelper ¶ added in v1.0.0
func (t *SortMergeTransf) InitColumnsIteratorHelper(rt hybridqp.RowDataType) CoProcessor
func (*SortMergeTransf) InitHeapItems ¶ added in v1.0.0
func (t *SortMergeTransf) InitHeapItems(inRowDataLen int, rt hybridqp.RowDataType, schema *QuerySchema) BaseHeapItems
func (*SortMergeTransf) Name ¶ added in v1.0.0
func (t *SortMergeTransf) Name() string
type SortMergeTransformCreator ¶
type SortMergeTransformCreator struct {
}
func (*SortMergeTransformCreator) Create ¶
func (c *SortMergeTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type SortTransform ¶ added in v1.1.0
type SortTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewSortTransform ¶ added in v1.1.0
func NewSortTransform( inRowDataType, outRowDataType []hybridqp.RowDataType, s *QuerySchema, sortFields influxql.SortFields) (*SortTransform, error)
func (*SortTransform) Close ¶ added in v1.1.0
func (trans *SortTransform) Close()
func (*SortTransform) Explain ¶ added in v1.1.0
func (trans *SortTransform) Explain() []ValuePair
func (*SortTransform) GetInputNumber ¶ added in v1.1.0
func (trans *SortTransform) GetInputNumber(_ Port) int
func (*SortTransform) GetInputs ¶ added in v1.1.0
func (trans *SortTransform) GetInputs() Ports
func (*SortTransform) GetOutputNumber ¶ added in v1.1.0
func (trans *SortTransform) GetOutputNumber(_ Port) int
func (*SortTransform) GetOutputs ¶ added in v1.1.0
func (trans *SortTransform) GetOutputs() Ports
func (*SortTransform) Name ¶ added in v1.1.0
func (trans *SortTransform) Name() string
func (*SortTransform) Release ¶ added in v1.2.0
func (trans *SortTransform) Release() error
type SortTransformCreator ¶ added in v1.1.0
type SortTransformCreator struct {
}
func (*SortTransformCreator) Create ¶ added in v1.1.0
func (c *SortTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type SortedBreakPoint ¶
type SortedBreakPoint struct {
Tag ChunkTags
Time int64
ValuePosition int
AuxCompareHelpers SortedMergeAuxHelpers
// contains filtered or unexported fields
}
SortedBreakPoint is the point we peek from the 2nd. less chunk, if the value is bigger than the SortedBreakPoint, which means we Need to change the chunk.
type SortedHeapItems ¶
type SortedHeapItems struct {
Items []*Item
AuxCompareHelpers SortedMergeAuxHelpers
// contains filtered or unexported fields
}
func (*SortedHeapItems) GetBreakPoint ¶ added in v1.0.0
func (h *SortedHeapItems) GetBreakPoint() BaseBreakPoint
GetBreakPoint used to get the break point of the records
func (*SortedHeapItems) GetOption ¶ added in v1.0.0
func (h *SortedHeapItems) GetOption() *query.ProcessorOptions
func (*SortedHeapItems) Len ¶
func (h *SortedHeapItems) Len() int
func (*SortedHeapItems) Less ¶
func (h *SortedHeapItems) Less(i, j int) bool
func (*SortedHeapItems) Pop ¶
func (h *SortedHeapItems) Pop() interface{}
func (*SortedHeapItems) Push ¶
func (h *SortedHeapItems) Push(x interface{})
func (*SortedHeapItems) Swap ¶
func (h *SortedHeapItems) Swap(i, j int)
type SortedMergeAuxHelper ¶
type SortedMergeAuxHelper struct {
// contains filtered or unexported fields
}
type SortedMergeAuxHelpers ¶
type SortedMergeAuxHelpers []*SortedMergeAuxHelper
func AuxHelper ¶
func AuxHelper(opt query.ProcessorOptions, rt hybridqp.RowDataType, filedMap map[string]influxql.VarRef) SortedMergeAuxHelpers
func (SortedMergeAuxHelpers) Len ¶
func (s SortedMergeAuxHelpers) Len() int
func (SortedMergeAuxHelpers) Less ¶
func (s SortedMergeAuxHelpers) Less(i, j int) bool
func (SortedMergeAuxHelpers) Swap ¶
func (s SortedMergeAuxHelpers) Swap(i, j int)
type SourceFromSingleChunk ¶
type SourceFromSingleChunk struct {
BaseProcessor
Output *ChunkPort
Chunk Chunk
}
func NewSourceFromSingleChunk ¶
func NewSourceFromSingleChunk(rowDataType hybridqp.RowDataType, chunk Chunk) *SourceFromSingleChunk
func (*SourceFromSingleChunk) Close ¶
func (source *SourceFromSingleChunk) Close()
func (*SourceFromSingleChunk) Explain ¶
func (source *SourceFromSingleChunk) Explain() []ValuePair
func (*SourceFromSingleChunk) GetInputNumber ¶
func (source *SourceFromSingleChunk) GetInputNumber(_ Port) int
func (*SourceFromSingleChunk) GetInputs ¶
func (source *SourceFromSingleChunk) GetInputs() Ports
func (*SourceFromSingleChunk) GetOutputNumber ¶
func (source *SourceFromSingleChunk) GetOutputNumber(_ Port) int
func (*SourceFromSingleChunk) GetOutputs ¶
func (source *SourceFromSingleChunk) GetOutputs() Ports
func (*SourceFromSingleChunk) Name ¶
func (source *SourceFromSingleChunk) Name() string
type SparseIndexScanTransform ¶ added in v1.1.0
type SparseIndexScanTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewSparseIndexScanTransform ¶ added in v1.1.0
func NewSparseIndexScanTransform(inRowDataType hybridqp.RowDataType, node hybridqp.QueryNode, ops []hybridqp.ExprOptions, info *IndexScanExtraInfo, schema hybridqp.Catalog) *SparseIndexScanTransform
func (*SparseIndexScanTransform) Abort ¶ added in v1.2.0
func (trans *SparseIndexScanTransform) Abort()
func (*SparseIndexScanTransform) Close ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) Close()
func (*SparseIndexScanTransform) Counting ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) Counting(ctx context.Context)
func (*SparseIndexScanTransform) Explain ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) Explain() []ValuePair
func (*SparseIndexScanTransform) GetInputNumber ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) GetInputNumber(_ Port) int
func (*SparseIndexScanTransform) GetInputs ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) GetInputs() Ports
func (*SparseIndexScanTransform) GetOutputNumber ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) GetOutputNumber(_ Port) int
func (*SparseIndexScanTransform) GetOutputs ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) GetOutputs() Ports
func (*SparseIndexScanTransform) IsSink ¶ added in v1.2.0
func (trans *SparseIndexScanTransform) IsSink() bool
func (*SparseIndexScanTransform) Name ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) Name() string
func (*SparseIndexScanTransform) Release ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) Release() error
func (*SparseIndexScanTransform) Running ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) Running(ctx context.Context)
func (*SparseIndexScanTransform) Work ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) Work(ctx context.Context) error
func (*SparseIndexScanTransform) WorkHelper ¶ added in v1.1.0
func (trans *SparseIndexScanTransform) WorkHelper(ctx context.Context) error
type SparseIndexScanTransformCreator ¶ added in v1.1.0
type SparseIndexScanTransformCreator struct {
}
func (*SparseIndexScanTransformCreator) Create ¶ added in v1.1.0
func (c *SparseIndexScanTransformCreator) Create(plan LogicalPlan, _ *query.ProcessorOptions) (Processor, error)
type SplitTransformTransform ¶ added in v0.2.0
type SplitTransformTransform struct {
BaseProcessor
CoProcessor CoProcessor
NewChunk Chunk
// contains filtered or unexported fields
}
func NewSplitTransformTransform ¶ added in v0.2.0
func NewSplitTransformTransform(inRowDataType hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, ops []hybridqp.ExprOptions, opt *query.ProcessorOptions) *SplitTransformTransform
func (*SplitTransformTransform) Close ¶ added in v0.2.0
func (trans *SplitTransformTransform) Close()
func (*SplitTransformTransform) Explain ¶ added in v0.2.0
func (trans *SplitTransformTransform) Explain() []ValuePair
func (*SplitTransformTransform) GetInputNumber ¶ added in v0.2.0
func (trans *SplitTransformTransform) GetInputNumber(_ Port) int
func (*SplitTransformTransform) GetInputs ¶ added in v0.2.0
func (trans *SplitTransformTransform) GetInputs() Ports
func (*SplitTransformTransform) GetOutputNumber ¶ added in v0.2.0
func (trans *SplitTransformTransform) GetOutputNumber(_ Port) int
func (*SplitTransformTransform) GetOutputs ¶ added in v0.2.0
func (trans *SplitTransformTransform) GetOutputs() Ports
func (*SplitTransformTransform) Name ¶ added in v0.2.0
func (trans *SplitTransformTransform) Name() string
func (*SplitTransformTransform) Release ¶ added in v0.2.0
func (trans *SplitTransformTransform) Release() error
func (*SplitTransformTransform) SendChunk ¶ added in v0.2.0
func (trans *SplitTransformTransform) SendChunk()
type SplitTransformTransformCreator ¶ added in v0.2.0
type SplitTransformTransformCreator struct {
}
func (*SplitTransformTransformCreator) Create ¶ added in v0.2.0
func (c *SplitTransformTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type StdoutChunkWriter ¶
type StdoutChunkWriter struct{}
func NewStdoutChunkWriter ¶
func NewStdoutChunkWriter() *StdoutChunkWriter
func (*StdoutChunkWriter) Close ¶
func (w *StdoutChunkWriter) Close()
func (*StdoutChunkWriter) Write ¶
func (w *StdoutChunkWriter) Write(chunk Chunk)
type StoreExchangeTraits ¶
type StoreExchangeTraits struct {
// contains filtered or unexported fields
}
func NewStoreExchangeTraits ¶
func NewStoreExchangeTraits(w spdy.Responser, mapShardsToReaders map[uint64][][]interface{}) *StoreExchangeTraits
func (*StoreExchangeTraits) HasReader ¶
func (t *StoreExchangeTraits) HasReader() bool
func (*StoreExchangeTraits) HasShard ¶
func (t *StoreExchangeTraits) HasShard() bool
func (*StoreExchangeTraits) NextReader ¶
func (t *StoreExchangeTraits) NextReader() []interface{}
func (*StoreExchangeTraits) NextShard ¶
func (t *StoreExchangeTraits) NextShard() uint64
func (*StoreExchangeTraits) PeekReader ¶
func (t *StoreExchangeTraits) PeekReader() []interface{}
func (*StoreExchangeTraits) PeekShard ¶
func (t *StoreExchangeTraits) PeekShard() uint64
func (*StoreExchangeTraits) Readers ¶
func (t *StoreExchangeTraits) Readers(shard uint64) [][]interface{}
func (*StoreExchangeTraits) Reset ¶
func (t *StoreExchangeTraits) Reset()
type StreamAggregateTransform ¶
type StreamAggregateTransform struct {
BaseProcessor
Inputs ChunkPorts
Outputs ChunkPorts
// contains filtered or unexported fields
}
func NewStreamAggregateTransform ¶
func NewStreamAggregateTransform( inRowDataType, outRowDataType []hybridqp.RowDataType, exprOpt []hybridqp.ExprOptions, opt *query.ProcessorOptions, isSubQuery bool, ) (*StreamAggregateTransform, error)
func (*StreamAggregateTransform) Close ¶
func (trans *StreamAggregateTransform) Close()
func (*StreamAggregateTransform) Explain ¶
func (trans *StreamAggregateTransform) Explain() []ValuePair
func (*StreamAggregateTransform) GetInputNumber ¶
func (trans *StreamAggregateTransform) GetInputNumber(port Port) int
func (*StreamAggregateTransform) GetInputs ¶
func (trans *StreamAggregateTransform) GetInputs() Ports
func (*StreamAggregateTransform) GetOutputNumber ¶
func (trans *StreamAggregateTransform) GetOutputNumber(port Port) int
func (*StreamAggregateTransform) GetOutputs ¶
func (trans *StreamAggregateTransform) GetOutputs() Ports
func (*StreamAggregateTransform) Name ¶
func (trans *StreamAggregateTransform) Name() string
func (*StreamAggregateTransform) NextChunk ¶ added in v1.4.0
func (trans *StreamAggregateTransform) NextChunk()
type StreamAggregateTransformCreator ¶
type StreamAggregateTransformCreator struct {
}
func (*StreamAggregateTransformCreator) Create ¶
func (c *StreamAggregateTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type StringAlignIterator ¶
type StringAlignIterator struct{}
func NewStringAlignIterator ¶
func NewStringAlignIterator() *StringAlignIterator
func (*StringAlignIterator) Next ¶
func (f *StringAlignIterator) Next(endpoint *IteratorEndpoint, _ *IteratorParams)
type StringAppendIterator ¶
type StringAppendIterator struct {
// contains filtered or unexported fields
}
func NewStringAppendIterator ¶
func NewStringAppendIterator() *StringAppendIterator
func (*StringAppendIterator) Next ¶
func (f *StringAppendIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
nolint
type StringColStringDistinctIterator ¶
type StringColStringDistinctIterator struct {
// contains filtered or unexported fields
}
func NewStringColStringDistinctIterator ¶
func NewStringColStringDistinctIterator( inOrdinal, outOrdinal int, ) *StringColStringDistinctIterator
func (*StringColStringDistinctIterator) Next ¶
func (r *StringColStringDistinctIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type StringColStringSampleIterator ¶
type StringColStringSampleIterator struct {
// contains filtered or unexported fields
}
func NewStringColStringSampleIterator ¶
func NewStringColStringSampleIterator(sampleNum int, isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *StringColStringSampleIterator
func (*StringColStringSampleIterator) Next ¶
func (r *StringColStringSampleIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type StringColStringSliceIterator ¶
type StringColStringSliceIterator struct {
// contains filtered or unexported fields
}
func NewStringColStringSliceIterator ¶
func NewStringColStringSliceIterator(fn StringColReduceSliceReduce, isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *StringColStringSliceIterator
func (*StringColStringSliceIterator) Next ¶
func (r *StringColStringSliceIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type StringFieldValuer ¶ added in v1.0.0
type StringFieldValuer struct {
// contains filtered or unexported fields
}
type StringIntervalIterator ¶
type StringIntervalIterator struct{}
func NewStringIntervalIterator ¶
func NewStringIntervalIterator() *StringIntervalIterator
func (*StringIntervalIterator) Next ¶
func (f *StringIntervalIterator) Next(endpoint *IteratorEndpoint, _ *IteratorParams)
type StringIterator ¶ added in v1.3.0
type StringIterator struct {
// contains filtered or unexported fields
}
func NewStringIterator ¶ added in v1.3.0
func NewStringIterator(fn ColReduceFunc[string], fv StringMerge, isSingleCall bool, inOrdinal, outOrdinal int, auxProcessor []*AuxProcessor, rowDataType hybridqp.RowDataType, ) *StringIterator
func (*StringIterator) Next ¶ added in v1.3.0
func (r *StringIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type StringLimitIterator ¶
type StringLimitIterator struct {
// contains filtered or unexported fields
}
func NewStringLimitIterator ¶
func NewStringLimitIterator() *StringLimitIterator
func (*StringLimitIterator) Next ¶
func (f *StringLimitIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type StringLinearFillProcessor ¶
type StringLinearFillProcessor struct {
// contains filtered or unexported fields
}
func NewStringLinearFillProcessor ¶
func NewStringLinearFillProcessor(inOrdinal, outOrdinal int) *StringLinearFillProcessor
type StringMerge ¶ added in v1.3.0
type StringMerge func(prevPoint, currPoint *StringPoint)
type StringMergeIterator ¶
type StringMergeIterator struct {
BaseMergeIterator
// contains filtered or unexported fields
}
func NewStringMergeIterator ¶
func NewStringMergeIterator() *StringMergeIterator
func (*StringMergeIterator) Next ¶
func (f *StringMergeIterator) Next(endpoint *IteratorEndpoint, params *IteratorParams)
type StringNullFillProcessor ¶
type StringNullFillProcessor struct {
// contains filtered or unexported fields
}
func NewStringNullFillProcessor ¶
func NewStringNullFillProcessor(inOrdinal, outOrdinal int) *StringNullFillProcessor
type StringNumberFillProcessor ¶
type StringNumberFillProcessor struct {
// contains filtered or unexported fields
}
func NewStringNumberFillProcessor ¶
func NewStringNumberFillProcessor(inOrdinal, outOrdinal int) *StringNumberFillProcessor
type StringPoint ¶
type StringPoint struct {
// contains filtered or unexported fields
}
func (*StringPoint) Assign ¶
func (p *StringPoint) Assign(c *StringPoint)
func (*StringPoint) Reset ¶
func (p *StringPoint) Reset()
type StringPreviousFillProcessor ¶
type StringPreviousFillProcessor struct {
// contains filtered or unexported fields
}
func NewStringPreviousFillProcessor ¶
func NewStringPreviousFillProcessor(inOrdinal, outOrdinal int) *StringPreviousFillProcessor
type StringTimeColStringIterator ¶
type StringTimeColStringIterator struct {
// contains filtered or unexported fields
}
func NewStringTimeColStringIterator ¶
func NewStringTimeColStringIterator( fn TimeColReduceFunc[string], fv StringTimeColStringMerge, inOrdinal, outOrdinal int, ) *StringTimeColStringIterator
func (*StringTimeColStringIterator) Next ¶
func (r *StringTimeColStringIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type StringTimeColStringMerge ¶
type StringTimeColStringMerge func(prevPoint, currPoint *StringPoint)
type StringValuer ¶
type StringValuer struct{}
func (StringValuer) Call ¶
func (v StringValuer) Call(name string, args []interface{}) (interface{}, bool)
func (StringValuer) Value ¶
func (StringValuer) Value(_ string) (interface{}, bool)
type SubQueryBuilder ¶
type SubQueryBuilder struct {
// contains filtered or unexported fields
}
func (*SubQueryBuilder) Build ¶
func (b *SubQueryBuilder) Build(ctx context.Context, opt *query.ProcessorOptions) (hybridqp.QueryNode, error)
type SubQueryTransform ¶
type SubQueryTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewSubQueryTransform ¶
func NewSubQueryTransform(inRowDataType hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, ops []hybridqp.ExprOptions, opt *query.ProcessorOptions) *SubQueryTransform
func (*SubQueryTransform) Close ¶
func (trans *SubQueryTransform) Close()
func (*SubQueryTransform) Explain ¶
func (trans *SubQueryTransform) Explain() []ValuePair
func (*SubQueryTransform) GetInputNumber ¶
func (trans *SubQueryTransform) GetInputNumber(_ Port) int
func (*SubQueryTransform) GetInputs ¶
func (trans *SubQueryTransform) GetInputs() Ports
func (*SubQueryTransform) GetOutputNumber ¶
func (trans *SubQueryTransform) GetOutputNumber(_ Port) int
func (*SubQueryTransform) GetOutputs ¶
func (trans *SubQueryTransform) GetOutputs() Ports
func (*SubQueryTransform) Name ¶
func (trans *SubQueryTransform) Name() string
func (*SubQueryTransform) Release ¶
func (trans *SubQueryTransform) Release() error
type SubQueryTransformCreator ¶
type SubQueryTransformCreator struct {
}
func (*SubQueryTransformCreator) Create ¶
func (c *SubQueryTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type TCountMinSketch ¶ added in v1.4.0
func NewTCountMinSketch ¶ added in v1.4.0
func NewTCountMinSketch(depth int, widthLog2 int) TCountMinSketch
func (*TCountMinSketch) Add ¶ added in v1.4.0
func (cms *TCountMinSketch) Add(indices []int, value TCounter)
func (*TCountMinSketch) Get ¶ added in v1.4.0
func (cms *TCountMinSketch) Get(indices []int) TCounter
func (*TCountMinSketch) GetCounter ¶ added in v1.4.0
func (cms *TCountMinSketch) GetCounter(depth int, index int) TCounter
type TDdcm ¶ added in v1.4.0
type TDdcm struct {
Parameters TDdcmParameters
RandomEngine *rand.Rand
TotalCount TCounter
LargeSketch TCountMinSketch
Hashers []THasher
HashersLastLevels []int
CycleManager TDdcmCycleManagerBase
SmallSketches []TCountMinSketch
SmallSketchesHasherIds []int
SmallSketchesNextSameHasherLevel []int
// for hash calculation, only surrport single hash per sketch, todo
PrecalculatedHashes []THashVector
SmallSketchIndices []int
LargeSketchIndices []int
SargeSketchHashes THashVector
LargeSketchHashes THashVector
}
func CreateDdcmWithWdm ¶ added in v1.4.0
func CreateDdcmWithWdm(failureProbability, wrongAnswerProbability, errRate, minSearchableFrequency float64, seed uint64) TDdcm
sigma, delta, epsilon, Phi
func NewTDdcm ¶ added in v1.4.0
func NewTDdcm(parameters *TDdcmParameters, seed uint64, cycleManager TDdcmCycleManagerBase) TDdcm
func (*TDdcm) AddKeyCount ¶ added in v1.4.0
func (*TDdcm) CalcHashesAndGetIndices ¶ added in v1.4.0
func (*TDdcm) CalcLargeSketchIndices ¶ added in v1.4.0
func (*TDdcm) ExtendLevels ¶ added in v1.4.0
func (*TDdcm) GetFrequentKeys ¶ added in v1.4.0
func (*TDdcm) GetFrequentKeysOfSize ¶ added in v1.4.0
func (*TDdcm) GetKeyCount ¶ added in v1.4.0
func (*TDdcm) GetTotalCount ¶ added in v1.4.0
type TDdcmCycleManagerBase ¶ added in v1.4.0
type TDdcmCycleManagerBase interface {
AddNewLevel() int
Copy() TDdcmCycleManagerBase
}
type TDdcmCycleManagerWdm ¶ added in v1.4.0
type TDdcmCycleManagerWdm struct {
CyclesNumberExponent float64
CurrentNumCyclesFractional float64
CurrentNumCycles int
CurrentCyclePos int
CurrentCycleLength int
CurrentPosInCycle int
}
func NewTDdcmCycleManagerWdm ¶ added in v1.4.0
func NewTDdcmCycleManagerWdm(cyclesNumberExponent float64, firstCycleLength int) *TDdcmCycleManagerWdm
func (*TDdcmCycleManagerWdm) AddNewLevel ¶ added in v1.4.0
func (ddcmw *TDdcmCycleManagerWdm) AddNewLevel() int
func (*TDdcmCycleManagerWdm) Copy ¶ added in v1.4.0
func (ddcmw *TDdcmCycleManagerWdm) Copy() TDdcmCycleManagerBase
type TDdcmParameters ¶ added in v1.4.0
type TDdcmParameters struct {
CountMinSketchWidthLog2 int
SmallCountMinSketchDepth int
LargeCountMinSketchDepth int
}
func CalcDdcmParameters ¶ added in v1.4.0
func CalcDdcmParameters(errRate, minSearchableFrequency, wrongAnswerProbability float64) (TDdcmParameters, error)
type TExtendedHashValue ¶ added in v1.4.0
type TExtendedHashValue uint64
const MersennePrime TExtendedHashValue = (TExtendedHashValue(1) << MersennePower) - 1
type THashValue ¶ added in v1.4.0
type THashValue uint32
func ModuleHash ¶ added in v1.4.0
func ModuleHash(hash TExtendedHashValue) THashValue
type THashVector ¶ added in v1.4.0
type THashVector THashValue
only support single hash per sketch, todo
type THasher ¶ added in v1.4.0
type THasher struct {
Depth int
WidthLog2 int
PolynomialHashBases []TExtendedHashValue
MultiplicativeHashCoefficients [][]TExtendedHashValue
}
func (*THasher) GetInitialHashVector ¶ added in v1.4.0
func (h *THasher) GetInitialHashVector(hashVector *THashVector)
only support single hash per sketch, todo
func (*THasher) TurnHashesIntoIndices ¶ added in v1.4.0
func (h *THasher) TurnHashesIntoIndices(hashes THashVector, indices *[]int)
only support single hash per sketch, todo
func (*THasher) UpdateHashes ¶ added in v1.4.0
func (h *THasher) UpdateHashes(key TKey, numBitsBefore int, numBitsAfter int, hashes *THashVector)
only support single hash per sketch, todo
func (*THasher) UpdateHashesBytewise ¶ added in v1.4.0
func (h *THasher) UpdateHashesBytewise(key TKey, numBytesBefore int, numBytesAfter int, hashes *THashVector)
only support single hash per sketch, todo
type TableScanFromSingleChunk ¶
type TableScanFromSingleChunk struct {
BaseProcessor
Output *ChunkPort
Table *QueryTable
Builder *ChunkBuilder
Chunk Chunk
}
func NewTableScanFromSingleChunk ¶
func NewTableScanFromSingleChunk(rowDataType hybridqp.RowDataType, table *QueryTable, _ query.ProcessorOptions) *TableScanFromSingleChunk
func (*TableScanFromSingleChunk) Close ¶
func (scan *TableScanFromSingleChunk) Close()
func (*TableScanFromSingleChunk) Explain ¶
func (scan *TableScanFromSingleChunk) Explain() []ValuePair
func (*TableScanFromSingleChunk) GetInputNumber ¶
func (scan *TableScanFromSingleChunk) GetInputNumber(_ Port) int
func (*TableScanFromSingleChunk) GetInputs ¶
func (scan *TableScanFromSingleChunk) GetInputs() Ports
func (*TableScanFromSingleChunk) GetOutputNumber ¶
func (scan *TableScanFromSingleChunk) GetOutputNumber(_ Port) int
func (*TableScanFromSingleChunk) GetOutputs ¶
func (scan *TableScanFromSingleChunk) GetOutputs() Ports
func (*TableScanFromSingleChunk) Name ¶
func (scan *TableScanFromSingleChunk) Name() string
type TargetTable ¶ added in v1.0.0
type TargetTable struct {
// contains filtered or unexported fields
}
BatchRows is not thread safe. It can not be used in multi-threading model.
func NewTargetTable ¶ added in v1.0.0
func NewTargetTable(rowCap int, tupleCap int) *TargetTable
func (*TargetTable) Active ¶ added in v1.0.0
func (tt *TargetTable) Active() []influx.Row
func (*TargetTable) Allocate ¶ added in v1.0.0
func (tt *TargetTable) Allocate() (*influx.Row, *TargetTuple)
func (*TargetTable) CheckAndAllocate ¶ added in v1.0.0
func (tt *TargetTable) CheckAndAllocate() (*influx.Row, *TargetTuple, bool)
func (*TargetTable) Commit ¶ added in v1.0.0
func (tt *TargetTable) Commit()
func (*TargetTable) Reset ¶ added in v1.0.0
func (tt *TargetTable) Reset()
type TargetTablePool ¶ added in v1.0.0
type TargetTablePool struct {
// contains filtered or unexported fields
}
func NewTargetTablePool ¶ added in v1.0.0
func NewTargetTablePool(rowCap int, tupleCap int) *TargetTablePool
func (*TargetTablePool) Get ¶ added in v1.0.0
func (p *TargetTablePool) Get() *TargetTable
func (*TargetTablePool) Put ¶ added in v1.0.0
func (p *TargetTablePool) Put(table *TargetTable)
type TargetTransform ¶ added in v1.0.0
type TargetTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func NewTargetTransform ¶ added in v1.0.0
func NewTargetTransform(inRowDataType hybridqp.RowDataType, outRowDataType hybridqp.RowDataType, ops []hybridqp.ExprOptions, opt *query.ProcessorOptions, schema *QuerySchema, mst *influxql.Measurement) (*TargetTransform, error)
func (*TargetTransform) Close ¶ added in v1.0.0
func (trans *TargetTransform) Close()
func (*TargetTransform) CloseWriteChan ¶ added in v1.0.0
func (trans *TargetTransform) CloseWriteChan()
func (*TargetTransform) Explain ¶ added in v1.0.0
func (trans *TargetTransform) Explain() []ValuePair
func (*TargetTransform) GetInputNumber ¶ added in v1.0.0
func (trans *TargetTransform) GetInputNumber(_ Port) int
func (*TargetTransform) GetInputs ¶ added in v1.0.0
func (trans *TargetTransform) GetInputs() Ports
func (*TargetTransform) GetOutputNumber ¶ added in v1.0.0
func (trans *TargetTransform) GetOutputNumber(_ Port) int
func (*TargetTransform) GetOutputs ¶ added in v1.0.0
func (trans *TargetTransform) GetOutputs() Ports
func (*TargetTransform) Name ¶ added in v1.0.0
func (trans *TargetTransform) Name() string
type TargetTransformCreator ¶ added in v1.0.0
type TargetTransformCreator struct {
}
func (*TargetTransformCreator) Create ¶ added in v1.0.0
func (c *TargetTransformCreator) Create(plan LogicalPlan, opt *query.ProcessorOptions) (Processor, error)
type TargetTuple ¶ added in v1.0.0
type TargetTuple struct {
// contains filtered or unexported fields
}
func NewTargetTuple ¶ added in v1.0.0
func NewTargetTuple(cap int) *TargetTuple
func (*TargetTuple) Active ¶ added in v1.0.0
func (t *TargetTuple) Active() []influx.Field
func (*TargetTuple) Allocate ¶ added in v1.0.0
func (t *TargetTuple) Allocate() *influx.Field
func (*TargetTuple) CheckAndAllocate ¶ added in v1.0.0
func (t *TargetTuple) CheckAndAllocate() (*influx.Field, bool)
func (*TargetTuple) Commit ¶ added in v1.0.0
func (t *TargetTuple) Commit()
func (*TargetTuple) Len ¶ added in v1.0.0
func (t *TargetTuple) Len() int
func (*TargetTuple) Reset ¶ added in v1.0.0
func (t *TargetTuple) Reset()
type TimeColReduceFunc ¶ added in v1.3.0
type TimeFuncState ¶ added in v1.1.0
type TimeFuncState uint32
type TopNTransform ¶ added in v1.4.0
type TopNTransform struct {
BaseProcessor
// contains filtered or unexported fields
}
func (*TopNTransform) Close ¶ added in v1.4.0
func (trans *TopNTransform) Close()
func (*TopNTransform) Explain ¶ added in v1.4.0
func (trans *TopNTransform) Explain() []ValuePair
func (*TopNTransform) GetInputNumber ¶ added in v1.4.0
func (trans *TopNTransform) GetInputNumber(_ Port) int
func (*TopNTransform) GetInputs ¶ added in v1.4.0
func (trans *TopNTransform) GetInputs() Ports
func (*TopNTransform) GetOutputNumber ¶ added in v1.4.0
func (trans *TopNTransform) GetOutputNumber(_ Port) int
func (*TopNTransform) GetOutputs ¶ added in v1.4.0
func (trans *TopNTransform) GetOutputs() Ports
func (*TopNTransform) InitFuncs ¶ added in v1.4.0
func (trans *TopNTransform) InitFuncs(inRowDataType hybridqp.RowDataType, fn string, opt hybridqp.ExprOptions) error
func (*TopNTransform) Name ¶ added in v1.4.0
func (trans *TopNTransform) Name() string
type TopNTransformCreator ¶ added in v1.4.0
type TopNTransformCreator struct {
}
func (*TopNTransformCreator) Create ¶ added in v1.4.0
func (c *TopNTransformCreator) Create(plan LogicalPlan, opt query.ProcessorOptions) (Processor, error)
type TransformCreator ¶
type TransformCreator interface {
Create(LogicalPlan, *query.ProcessorOptions) (Processor, error)
}
type TransformCreatorFactory ¶
type TransformCreatorFactory struct {
// contains filtered or unexported fields
}
func GetTransformFactoryInstance ¶
func GetTransformFactoryInstance() *TransformCreatorFactory
func NewTransformCreatorFactory ¶
func NewTransformCreatorFactory() *TransformCreatorFactory
func (*TransformCreatorFactory) Add ¶
func (r *TransformCreatorFactory) Add(name string, creator TransformCreator)
func (*TransformCreatorFactory) Find ¶
func (r *TransformCreatorFactory) Find(name string) (TransformCreator, bool)
type TransformDag ¶
type TransformDag struct {
// contains filtered or unexported fields
}
func NewTransformDag ¶
func NewTransformDag() *TransformDag
func (*TransformDag) AddEdge ¶
func (dag *TransformDag) AddEdge(from *TransformVertex, to *TransformVertex) bool
func (*TransformDag) AddVertex ¶
func (dag *TransformDag) AddVertex(vertex *TransformVertex) bool
func (*TransformDag) Contains ¶
func (dag *TransformDag) Contains(vertex *TransformVertex) bool
func (*TransformDag) DepthFirstWalkVertex ¶
func (dag *TransformDag) DepthFirstWalkVertex(visitor TransformVertexVisitor, vertex *TransformVertex)
func (*TransformDag) SetVertexToInfo ¶ added in v1.0.0
func (dag *TransformDag) SetVertexToInfo(vertex *TransformVertex, info *TransformVertexInfo)
SetVertexToInfo de
func (*TransformDag) WalkVertex ¶
func (dag *TransformDag) WalkVertex(vertex *TransformVertex, fn func(to, from *TransformVertex))
type TransformEdge ¶
type TransformEdge struct {
// contains filtered or unexported fields
}
func NewTransformEdge ¶
func NewTransformEdge(from *TransformVertex, to *TransformVertex) *TransformEdge
type TransformVertex ¶
type TransformVertex struct {
// contains filtered or unexported fields
}
func NewTransformVertex ¶
func NewTransformVertex(node hybridqp.QueryNode, transform Processor) *TransformVertex
func (*TransformVertex) GetTransform ¶ added in v1.0.0
func (t *TransformVertex) GetTransform() Processor
type TransformVertexInfo ¶
type TransformVertexInfo struct {
// contains filtered or unexported fields
}
func NewTransformVertexInfo ¶
func NewTransformVertexInfo() *TransformVertexInfo
func (*TransformVertexInfo) AddBackwardEdge ¶
func (info *TransformVertexInfo) AddBackwardEdge(edge *TransformEdge)
func (*TransformVertexInfo) AddDirectEdge ¶
func (info *TransformVertexInfo) AddDirectEdge(edge *TransformEdge)
type TransformVertexVisitor ¶
type TransformVertexVisitor interface {
Visit(*TransformVertex) TransformVertexVisitor
}
type ValueCount ¶ added in v1.3.0
type ValueCount struct {
// contains filtered or unexported fields
}
type VertexWriter ¶
type VertexWriterImpl ¶
func NewVertexWriterImpl ¶
func NewVertexWriterImpl(dag *DAG, builder *strings.Builder) *VertexWriterImpl
func (*VertexWriterImpl) Explain ¶
func (w *VertexWriterImpl) Explain(vertex *Vertex)
func (*VertexWriterImpl) ExplainEdges ¶
func (w *VertexWriterImpl) ExplainEdges(edges Edges)
func (*VertexWriterImpl) Item ¶
func (w *VertexWriterImpl) Item(term string, value interface{})
func (*VertexWriterImpl) String ¶
func (w *VertexWriterImpl) String() string
type WideCoProcessorImpl ¶ added in v0.2.0
type WideCoProcessorImpl struct {
Routine *WideRoutineImpl
}
func NewWideCoProcessorImpl ¶ added in v0.2.0
func NewWideCoProcessorImpl(routine *WideRoutineImpl) *WideCoProcessorImpl
func (*WideCoProcessorImpl) WorkOnChunk ¶ added in v0.2.0
func (p *WideCoProcessorImpl) WorkOnChunk(in Chunk, out Chunk, params *IteratorParams)
type WideIterator ¶ added in v0.2.0
type WideIterator struct {
// contains filtered or unexported fields
}
func NewWideIterator ¶ added in v0.2.0
func NewWideIterator(fn WideReduce, params ...interface{}) *WideIterator
func (*WideIterator) Next ¶ added in v0.2.0
func (r *WideIterator) Next(ie *IteratorEndpoint, p *IteratorParams)
type WideReduce ¶ added in v0.2.0
type WideRoutineImpl ¶ added in v0.2.0
type WideRoutineImpl struct {
// contains filtered or unexported fields
}
func NewWideRoutineImpl ¶ added in v0.2.0
func NewWideRoutineImpl(iterator Iterator) *WideRoutineImpl
func (*WideRoutineImpl) WorkOnChunk ¶ added in v0.2.0
func (r *WideRoutineImpl) WorkOnChunk(in Chunk, out Chunk, params *IteratorParams)
type WindowMerge ¶ added in v1.3.0
type WindowMerge[T util.ExceptString] func(prevWindow, currWindow *SlidingWindow[T], fpm PointMerge[T])
Source Files
¶
- agg_factory.go
- agg_func.go
- agg_func_prom.go
- agg_iterator.gen.go
- agg_iterator.go
- agg_iterator_prom.go
- agg_operators.go
- agg_transform.go
- align_transform.go
- call_processor.go
- chunk.go
- chunk_arrow_transform.go
- chunk_codec.gen.go
- chunk_pool.go
- chunk_tags.go
- column.gen.go
- context.go
- coprocessor.go
- count_min_sketch.go
- dag.go
- ddcm.go
- ddcm_cycle_manager.go
- factory.go
- fill_processor.gen.go
- fill_transform.go
- filter_blank_transfrom.go
- filter_transform.go
- full_join_transform.go
- groupby_transform.go
- hash_agg_func.gen.go
- hash_agg_func_prom.go
- hash_agg_transform.go
- hash_merge_func.gen.go
- hash_merge_transform.go
- hasher.go
- heu_planner.go
- heu_rule.go
- holt_winters_transform.go
- httpsender_transform.go
- inc_agg_transform.go
- inc_hash_agg_funcs.go
- inc_hash_agg_transform.go
- index_fragment.go
- index_scan_transform.go
- init.go
- interval_transform.go
- label_functions.go
- limit_transform.go
- logic_plan.go
- logic_plan_base.go
- logic_plan_codec.go
- materialize_transform.go
- merge_transform.go
- ogsketch.go
- opt_rules.go
- orderby_transform.go
- pipeline_executor.go
- plan_type.go
- plan_type_shard.go
- processor.go
- prom_binop_transform.go
- prom_instant_vector_transform.go
- prom_range_vector_transform.go
- prom_time_functions.go
- rpc_client.go
- rpc_message.go
- rpc_transform.go
- schema.go
- select.go
- simple_processors.go
- sliding_window_processor.go
- sliding_window_transform.go
- sort_append_transform.go
- sort_merge_transform.go
- sort_transform.go
- sort_transform_prom.go
- sort_transform_result.go
- sparse_index_scan_transform.go
- split_group_transform.go
- string_functions.go
- subquery.go
- subquery_transform.go
- tablescan_transform.go
- target_transform.go
- topn_transform.go
- topn_transform_common.go
- udaf_functions.go
- udaf_iterator.go