Documentation ¶
Overview ¶
Package influxql implements a parser for the InfluxDB query language.
InfluxQL is a DML and DDL language for the InfluxDB time series database. It provides the ability to query for aggregate statistics as well as create and configure the InfluxDB server.
Selecting data ¶
The SELECT query is used for retrieving data from one or more series. It allows for a list of columns followed by a list of series to select from.
SELECT value FROM cpu_load
You can also add a a conditional expression to limit the results of the query:
SELECT value FROM cpu_load WHERE host = 'influxdb.com'
Two or more series can be combined into a single query and executed together:
SELECT cpu0.value + cpu1.value FROM cpu_load AS cpu0 INNER JOIN cpu_load cpu1 ON cpu0.host = cpu1.host
Limits and ordering can be set on selection queries as well:
SELECT value FROM cpu_load LIMIT 100 ORDER DESC;
Removing data ¶
The DELETE query is available to remove time series data points from the database. This query will delete "cpu_load" values older than an hour:
DELETE FROM cpu_load WHERE time < now() - 1h
Continuous Queries ¶
Queries can be run indefinitely on the server in order to generate new series. This is done by running a "SELECT INTO" query. For example, this query computes the hourly mean for cpu_load and stores it into a "cpu_load" series in the "daily" shard space.
SELECT mean(value) AS value FROM cpu_load GROUP BY 1h INTO daily.cpu_load
If there is existing data on the source series then this query will be run for all historic data. To only execute the query on new incoming data you can append "NO BACKFILL" to the end of the query:
SELECT mean(value) AS value FROM cpu_load GROUP BY 1h INTO daily.cpu_load NO BACKFILL
Continuous queries will return an id that can be used to remove them in the future. To remove a continous query, use the DROP CONTINUOUS QUERY statement:
DROP CONTINUOUS QUERY 12
You can also list all continuous queries by running:
LIST CONTINUOUS QUERIES
Index ¶
- Constants
- Variables
- func AggregateBooleanPoints(a BooleanPointAggregator, points []BooleanPoint)
- func AggregateFloatPoints(a FloatPointAggregator, points []FloatPoint)
- func AggregateIntegerPoints(a IntegerPointAggregator, points []IntegerPoint)
- func AggregateStringPoints(a StringPointAggregator, points []StringPoint)
- func BinaryExprName(expr *BinaryExpr) string
- func BooleanCountReduce(prev *IntegerPoint, curr *BooleanPoint) (int64, int64, []interface{})
- func BooleanFirstReduce(prev, curr *BooleanPoint) (int64, bool, []interface{})
- func BooleanLastReduce(prev, curr *BooleanPoint) (int64, bool, []interface{})
- func ContainsVarRef(expr Expr) bool
- func ErrDatabaseNotFound(name string) error
- func ErrMeasurementNotFound(name string) error
- func Eval(expr Expr, m map[string]interface{}) interface{}
- func EvalBool(expr Expr, m map[string]interface{}) bool
- func ExprNames(expr Expr) []string
- func FloatCountReduce(prev *IntegerPoint, curr *FloatPoint) (int64, int64, []interface{})
- func FloatFirstReduce(prev, curr *FloatPoint) (int64, float64, []interface{})
- func FloatLastReduce(prev, curr *FloatPoint) (int64, float64, []interface{})
- func FloatMaxReduce(prev, curr *FloatPoint) (int64, float64, []interface{})
- func FloatMinReduce(prev, curr *FloatPoint) (int64, float64, []interface{})
- func FloatSumReduce(prev, curr *FloatPoint) (int64, float64, []interface{})
- func FormatDuration(d time.Duration) string
- func HasTimeExpr(expr Expr) bool
- func IdentNeedsQuotes(ident string) bool
- func IntegerCountReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
- func IntegerFirstReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
- func IntegerLastReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
- func IntegerMaxReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
- func IntegerMinReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
- func IntegerSumReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
- func IsRegexOp(t Token) bool
- func IsSystemName(name string) bool
- func MatchSource(sources Sources, name string) string
- func OnlyTimeExpr(expr Expr) bool
- func ParseDuration(s string) (time.Duration, error)
- func QuoteIdent(segments ...string) string
- func QuoteString(s string) string
- func ScanBareIdent(r io.RuneScanner) string
- func ScanDelimited(r io.RuneScanner, start, end rune, escapes map[rune]rune, escapesPassThru bool) ([]byte, error)
- func ScanString(r io.RuneScanner) (string, error)
- func StringCountReduce(prev *IntegerPoint, curr *StringPoint) (int64, int64, []interface{})
- func StringFirstReduce(prev, curr *StringPoint) (int64, string, []interface{})
- func StringLastReduce(prev, curr *StringPoint) (int64, string, []interface{})
- func TimeRange(expr Expr) (min, max time.Time)
- func TimeRangeAsEpochNano(expr Expr) (min, max int64)
- func Walk(v Visitor, node Node)
- func WalkFunc(node Node, fn func(Node))
- type AlterRetentionPolicyStatement
- type AuxIterator
- type BinaryExpr
- type BooleanBulkPointAggregator
- type BooleanFuncFloatReducer
- type BooleanFuncIntegerReducer
- type BooleanFuncReducer
- type BooleanFuncStringReducer
- type BooleanIterator
- type BooleanLiteral
- type BooleanPoint
- type BooleanPointAggregator
- type BooleanPointDecoder
- type BooleanPointEmitter
- type BooleanPointEncoder
- type BooleanReduceFloatFunc
- type BooleanReduceFloatSliceFunc
- type BooleanReduceFunc
- type BooleanReduceIntegerFunc
- type BooleanReduceIntegerSliceFunc
- type BooleanReduceSliceFunc
- type BooleanReduceStringFunc
- type BooleanReduceStringSliceFunc
- type BooleanSliceFuncFloatReducer
- type BooleanSliceFuncIntegerReducer
- type BooleanSliceFuncReducer
- type BooleanSliceFuncStringReducer
- type Call
- type CreateContinuousQueryStatement
- type CreateDatabaseStatement
- type CreateRetentionPolicyStatement
- type CreateSubscriptionStatement
- type CreateUserStatement
- type DataType
- type DeleteStatement
- type Dimension
- type Dimensions
- type Distinct
- type DropContinuousQueryStatement
- type DropDatabaseStatement
- type DropMeasurementStatement
- type DropRetentionPolicyStatement
- type DropSeriesStatement
- type DropServerStatement
- type DropSubscriptionStatement
- type DropUserStatement
- type DurationLiteral
- type Emitter
- type ExecutionPrivilege
- type ExecutionPrivileges
- type Expr
- type Field
- type Fields
- type FillOption
- type FloatBulkPointAggregator
- type FloatFuncBooleanReducer
- type FloatFuncIntegerReducer
- type FloatFuncReducer
- type FloatFuncStringReducer
- type FloatIterator
- type FloatMeanReducer
- type FloatPoint
- func FloatDistinctReduceSlice(a []FloatPoint) []FloatPoint
- func FloatMedianReduceSlice(a []FloatPoint) []FloatPoint
- func FloatSpreadReduceSlice(a []FloatPoint) []FloatPoint
- func FloatStddevReduceSlice(a []FloatPoint) []FloatPoint
- func IntegerMedianReduceSlice(a []IntegerPoint) []FloatPoint
- func IntegerStddevReduceSlice(a []IntegerPoint) []FloatPoint
- type FloatPointAggregator
- type FloatPointDecoder
- type FloatPointEmitter
- type FloatPointEncoder
- type FloatReduceBooleanFunc
- type FloatReduceBooleanSliceFunc
- type FloatReduceFunc
- type FloatReduceIntegerFunc
- type FloatReduceIntegerSliceFunc
- type FloatReduceSliceFunc
- func NewFloatBottomReduceSliceFunc(n int, tags []int, interval Interval) FloatReduceSliceFunc
- func NewFloatDerivativeReduceSliceFunc(interval Interval, isNonNegative bool) FloatReduceSliceFunc
- func NewFloatPercentileReduceSliceFunc(percentile float64) FloatReduceSliceFunc
- func NewFloatTopReduceSliceFunc(n int, tags []int, interval Interval) FloatReduceSliceFunc
- type FloatReduceStringFunc
- type FloatReduceStringSliceFunc
- type FloatSliceFuncBooleanReducer
- type FloatSliceFuncIntegerReducer
- type FloatSliceFuncReducer
- type FloatSliceFuncStringReducer
- type GrantAdminStatement
- type GrantStatement
- type HasDefaultDatabase
- type IntegerBulkPointAggregator
- type IntegerFuncBooleanReducer
- type IntegerFuncFloatReducer
- type IntegerFuncReducer
- type IntegerFuncStringReducer
- type IntegerIterator
- type IntegerMeanReducer
- type IntegerPoint
- type IntegerPointAggregator
- type IntegerPointDecoder
- type IntegerPointEmitter
- type IntegerPointEncoder
- type IntegerReduceBooleanFunc
- type IntegerReduceBooleanSliceFunc
- type IntegerReduceFloatFunc
- type IntegerReduceFloatSliceFunc
- type IntegerReduceFunc
- type IntegerReduceSliceFunc
- type IntegerReduceStringFunc
- type IntegerReduceStringSliceFunc
- type IntegerSliceFuncBooleanReducer
- type IntegerSliceFuncFloatReducer
- type IntegerSliceFuncReducer
- type IntegerSliceFuncStringReducer
- type Interval
- type Iterator
- func NewCallIterator(input Iterator, opt IteratorOptions) (Iterator, error)
- func NewDedupeIterator(input Iterator) Iterator
- func NewDistinctIterator(input Iterator, opt IteratorOptions) (Iterator, error)
- func NewFillIterator(input Iterator, expr Expr, opt IteratorOptions) Iterator
- func NewIntervalIterator(input Iterator, opt IteratorOptions) Iterator
- func NewLimitIterator(input Iterator, opt IteratorOptions) Iterator
- func NewMergeIterator(inputs []Iterator, opt IteratorOptions) Iterator
- func NewReaderIterator(r io.Reader) (Iterator, error)
- func NewSortedMergeIterator(inputs []Iterator, opt IteratorOptions) Iterator
- func Select(stmt *SelectStatement, ic IteratorCreator, sopt *SelectOptions) ([]Iterator, error)
- type IteratorCreator
- type IteratorCreators
- func (a IteratorCreators) Close() error
- func (a IteratorCreators) CreateIterator(opt IteratorOptions) (Iterator, error)
- func (a IteratorCreators) FieldDimensions(sources Sources) (fields, dimensions map[string]struct{}, err error)
- func (a IteratorCreators) SeriesKeys(opt IteratorOptions) (SeriesList, error)
- type IteratorEncoder
- type IteratorOptions
- func (opt IteratorOptions) DerivativeInterval() Interval
- func (opt *IteratorOptions) MarshalBinary() ([]byte, error)
- func (opt IteratorOptions) MergeSorted() bool
- func (opt IteratorOptions) SeekTime() int64
- func (opt *IteratorOptions) UnmarshalBinary(buf []byte) error
- func (opt IteratorOptions) Window(t int64) (start, end int64)
- type Iterators
- type Literal
- type Measurement
- type Measurements
- type Node
- type NowValuer
- type NumberLiteral
- type ParenExpr
- type ParseError
- type Parser
- type Point
- type PointDecoder
- type Points
- type Pos
- type Privilege
- type Processor
- type Query
- type QueryExecutor
- type RegexLiteral
- type Result
- type RevokeAdminStatement
- type RevokeStatement
- type Rewriter
- type Scanner
- type SelectOptions
- type SelectStatement
- func (s *SelectStatement) Clone() *SelectStatement
- func (s *SelectStatement) ColumnNames() []string
- func (s *SelectStatement) FunctionCalls() []*Call
- func (s *SelectStatement) FunctionCallsByPosition() [][]*Call
- func (s *SelectStatement) GroupByInterval() (time.Duration, error)
- func (s *SelectStatement) HasCountDistinct() bool
- func (s *SelectStatement) HasDerivative() bool
- func (s *SelectStatement) HasDimensionWildcard() bool
- func (s *SelectStatement) HasDistinct() bool
- func (s *SelectStatement) HasFieldWildcard() bool
- func (s *SelectStatement) HasSimpleCount() bool
- func (s *SelectStatement) HasTimeFieldSpecified() bool
- func (s *SelectStatement) HasWildcard() bool
- func (s *SelectStatement) IsSimpleDerivative() bool
- func (s *SelectStatement) NamesInDimension() []string
- func (s *SelectStatement) NamesInSelect() []string
- func (s *SelectStatement) NamesInWhere() []string
- func (s *SelectStatement) RequiredPrivileges() ExecutionPrivileges
- func (s *SelectStatement) RewriteDistinct()
- func (s *SelectStatement) RewriteTimeFields()
- func (s *SelectStatement) RewriteWildcards(ic IteratorCreator) (*SelectStatement, error)
- func (s *SelectStatement) SetTimeRange(start, end time.Time) error
- func (s *SelectStatement) String() string
- func (s *SelectStatement) Substatement(ref *VarRef) (*SelectStatement, error)
- func (s *SelectStatement) TimeAscending() bool
- type Series
- type SeriesList
- type SetPasswordUserStatement
- type ShowContinuousQueriesStatement
- type ShowDatabasesStatement
- type ShowDiagnosticsStatement
- type ShowFieldKeysStatement
- type ShowGrantsForUserStatement
- type ShowMeasurementsStatement
- type ShowRetentionPoliciesStatement
- type ShowSeriesStatement
- type ShowServersStatement
- type ShowShardGroupsStatement
- type ShowShardsStatement
- type ShowStatsStatement
- type ShowSubscriptionsStatement
- type ShowTagKeysStatement
- type ShowTagValuesStatement
- type ShowUsersStatement
- type SortField
- type SortFields
- type Source
- type Sources
- type Statement
- type Statements
- type StringBulkPointAggregator
- type StringFuncBooleanReducer
- type StringFuncFloatReducer
- type StringFuncIntegerReducer
- type StringFuncReducer
- type StringIterator
- type StringLiteral
- type StringPoint
- type StringPointAggregator
- type StringPointDecoder
- type StringPointEmitter
- type StringPointEncoder
- type StringReduceBooleanFunc
- type StringReduceBooleanSliceFunc
- type StringReduceFloatFunc
- type StringReduceFloatSliceFunc
- type StringReduceFunc
- type StringReduceIntegerFunc
- type StringReduceIntegerSliceFunc
- type StringReduceSliceFunc
- type StringSliceFuncBooleanReducer
- type StringSliceFuncFloatReducer
- type StringSliceFuncIntegerReducer
- type StringSliceFuncReducer
- type TagSet
- type Tags
- type Target
- type TimeLiteral
- type Token
- type Valuer
- type VarRef
- type Visitor
- type Wildcard
Constants ¶
const ( // Unknown primitive data type. Unknown DataType = 0 // Float means the data type is a float Float = 1 // Integer means the data type is a integer Integer = 2 // String means the data type is a string of text. String = 3 // Boolean means the data type is a boolean. Boolean = 4 // Time means the data type is a time. Time = 5 // Duration means the data type is a duration of time. Duration = 6 )
const ( // MinTime is used as the minimum time value when computing an unbounded range. MinTime = int64(0) // MaxTime is used as the maximum time value when computing an unbounded range. // This time is Jan 1, 2050 at midnight UTC. MaxTime = int64(2524608000000000000) )
const ( // DateFormat represents the format for date literals. DateFormat = "2006-01-02" // DateTimeFormat represents the format for date time literals. DateTimeFormat = "2006-01-02 15:04:05.999999" )
const ZeroTime = int64(-6795364578871345152)
ZeroTime is the Unix nanosecond timestamp for time.Time{}.
Variables ¶
var ( // ErrInvalidQuery is returned when executing an unknown query type. ErrInvalidQuery = errors.New("invalid query") // ErrNotExecuted is returned when a statement is not executed in a query. // This can occur when a previous statement in the same query has errored. ErrNotExecuted = errors.New("not executed") )
var ErrInvalidDuration = errors.New("invalid duration")
ErrInvalidDuration is returned when parsing a malformatted duration.
var ErrUnknownCall = errors.New("unknown call")
ErrUnknownCall is returned when operating on an unknown function call.
Functions ¶
func AggregateBooleanPoints ¶ added in v0.11.0
func AggregateBooleanPoints(a BooleanPointAggregator, points []BooleanPoint)
AggregateBooleanPoints feeds a slice of BooleanPoint into an aggregator. If the aggregator is a BooleanBulkPointAggregator, it will use the AggregateBulk method.
func AggregateFloatPoints ¶ added in v0.11.0
func AggregateFloatPoints(a FloatPointAggregator, points []FloatPoint)
AggregateFloatPoints feeds a slice of FloatPoint into an aggregator. If the aggregator is a FloatBulkPointAggregator, it will use the AggregateBulk method.
func AggregateIntegerPoints ¶ added in v0.11.0
func AggregateIntegerPoints(a IntegerPointAggregator, points []IntegerPoint)
AggregateIntegerPoints feeds a slice of IntegerPoint into an aggregator. If the aggregator is a IntegerBulkPointAggregator, it will use the AggregateBulk method.
func AggregateStringPoints ¶ added in v0.11.0
func AggregateStringPoints(a StringPointAggregator, points []StringPoint)
AggregateStringPoints feeds a slice of StringPoint into an aggregator. If the aggregator is a StringBulkPointAggregator, it will use the AggregateBulk method.
func BinaryExprName ¶ added in v0.11.0
func BinaryExprName(expr *BinaryExpr) string
func BooleanCountReduce ¶ added in v0.11.0
func BooleanCountReduce(prev *IntegerPoint, curr *BooleanPoint) (int64, int64, []interface{})
BooleanCountReduce returns the count of points.
func BooleanFirstReduce ¶ added in v0.11.0
func BooleanFirstReduce(prev, curr *BooleanPoint) (int64, bool, []interface{})
BooleanFirstReduce returns the first point sorted by time.
func BooleanLastReduce ¶ added in v0.11.0
func BooleanLastReduce(prev, curr *BooleanPoint) (int64, bool, []interface{})
BooleanLastReduce returns the first point sorted by time.
func ContainsVarRef ¶ added in v0.11.0
ContainsVarRef returns true if expr is a VarRef or contains one.
func ErrDatabaseNotFound ¶ added in v0.11.0
ErrDatabaseNotFound returns a database not found error for the given database name.
func ErrMeasurementNotFound ¶ added in v0.11.0
ErrMeasurementNotFound returns a measurement not found error for the given measurement name.
func EvalBool ¶ added in v0.9.5
EvalBool evaluates expr and returns true if result is a boolean true. Otherwise returns false.
func ExprNames ¶ added in v0.11.0
ExprNames returns a list of non-"time" field names from an expression.
func FloatCountReduce ¶ added in v0.11.0
func FloatCountReduce(prev *IntegerPoint, curr *FloatPoint) (int64, int64, []interface{})
FloatCountReduce returns the count of points.
func FloatFirstReduce ¶ added in v0.11.0
func FloatFirstReduce(prev, curr *FloatPoint) (int64, float64, []interface{})
FloatFirstReduce returns the first point sorted by time.
func FloatLastReduce ¶ added in v0.11.0
func FloatLastReduce(prev, curr *FloatPoint) (int64, float64, []interface{})
FloatLastReduce returns the last point sorted by time.
func FloatMaxReduce ¶ added in v0.11.0
func FloatMaxReduce(prev, curr *FloatPoint) (int64, float64, []interface{})
FloatMaxReduce returns the maximum value between prev & curr.
func FloatMinReduce ¶ added in v0.11.0
func FloatMinReduce(prev, curr *FloatPoint) (int64, float64, []interface{})
FloatMinReduce returns the minimum value between prev & curr.
func FloatSumReduce ¶ added in v0.11.0
func FloatSumReduce(prev, curr *FloatPoint) (int64, float64, []interface{})
FloatSumReduce returns the sum prev value & curr value.
func FormatDuration ¶
FormatDuration formats a duration to a string.
func HasTimeExpr ¶ added in v0.9.5
HasTimeExpr returns true if the expression has a time term.
func IdentNeedsQuotes ¶
IdentNeedsQuotes returns true if the ident string given would require quotes.
func IntegerCountReduce ¶ added in v0.11.0
func IntegerCountReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
IntegerCountReduce returns the count of points.
func IntegerFirstReduce ¶ added in v0.11.0
func IntegerFirstReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
IntegerFirstReduce returns the first point sorted by time.
func IntegerLastReduce ¶ added in v0.11.0
func IntegerLastReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
IntegerLastReduce returns the last point sorted by time.
func IntegerMaxReduce ¶ added in v0.11.0
func IntegerMaxReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
IntegerMaxReduce returns the maximum value between prev & curr.
func IntegerMinReduce ¶ added in v0.11.0
func IntegerMinReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
IntegerMinReduce returns the minimum value between prev & curr.
func IntegerSumReduce ¶ added in v0.11.0
func IntegerSumReduce(prev, curr *IntegerPoint) (int64, int64, []interface{})
IntegerSumReduce returns the sum prev value & curr value.
func IsSystemName ¶ added in v0.11.0
IsSystemName returns true if name is an internal system name.
func MatchSource ¶
MatchSource returns the source name that matches a field name. Returns a blank string if no sources match.
func OnlyTimeExpr ¶ added in v0.9.5
OnlyTimeExpr returns true if the expression only has time constraints.
func ParseDuration ¶
ParseDuration parses a time duration from a string.
func QuoteIdent ¶
QuoteIdent returns a quoted identifier from multiple bare identifiers.
func ScanBareIdent ¶
func ScanBareIdent(r io.RuneScanner) string
ScanBareIdent reads bare identifier from a rune reader.
func ScanDelimited ¶
func ScanDelimited(r io.RuneScanner, start, end rune, escapes map[rune]rune, escapesPassThru bool) ([]byte, error)
ScanDelimited reads a delimited set of runes
func ScanString ¶
func ScanString(r io.RuneScanner) (string, error)
ScanString reads a quoted string from a rune reader.
func StringCountReduce ¶ added in v0.11.0
func StringCountReduce(prev *IntegerPoint, curr *StringPoint) (int64, int64, []interface{})
StringCountReduce returns the count of points.
func StringFirstReduce ¶ added in v0.11.0
func StringFirstReduce(prev, curr *StringPoint) (int64, string, []interface{})
StringFirstReduce returns the first point sorted by time.
func StringLastReduce ¶ added in v0.11.0
func StringLastReduce(prev, curr *StringPoint) (int64, string, []interface{})
StringLastReduce returns the first point sorted by time.
func TimeRange ¶
TimeRange returns the minimum and maximum times specified by an expression. Returns zero times if there is no bound.
func TimeRangeAsEpochNano ¶ added in v0.9.2
TimeRangeAsEpochNano returns the minimum and maximum times, as epoch nano, specified by and expression. If there is no lower bound, the start of the epoch is returned for minimum. If there is no higher bound, now is returned for maximum.
Types ¶
type AlterRetentionPolicyStatement ¶
type AlterRetentionPolicyStatement struct { // Name of policy to alter. Name string // Name of the database this policy belongs to. Database string // Duration data written to this policy will be retained. Duration *time.Duration // Replication factor for data written to this policy. Replication *int // Should this policy be set as defalut for the database? Default bool }
AlterRetentionPolicyStatement represents a command to alter an existing retention policy.
func (*AlterRetentionPolicyStatement) RequiredPrivileges ¶
func (s *AlterRetentionPolicyStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute an AlterRetentionPolicyStatement.
func (*AlterRetentionPolicyStatement) String ¶
func (s *AlterRetentionPolicyStatement) String() string
String returns a string representation of the alter retention policy statement.
type AuxIterator ¶ added in v0.11.0
type AuxIterator interface { Iterator IteratorCreator // Auxilary iterator Iterator(name string) Iterator // Start starts writing to the created iterators. Start() // Backgrounds the iterator so that, when start is called, it will // continuously read from the iterator. Background() }
AuxIterator represents an iterator that can split off separate auxilary iterators.
func NewAuxIterator ¶ added in v0.11.0
func NewAuxIterator(input Iterator, seriesKeys SeriesList, opt IteratorOptions) AuxIterator
NewAuxIterator returns a new instance of AuxIterator.
type BinaryExpr ¶
BinaryExpr represents an operation between two expressions.
func (*BinaryExpr) String ¶
func (e *BinaryExpr) String() string
String returns a string representation of the binary expression.
type BooleanBulkPointAggregator ¶ added in v0.11.0
type BooleanBulkPointAggregator interface {
AggregateBooleanBulk(points []BooleanPoint)
}
BooleanBulkPointAggregator aggregates multiple points at a time.
type BooleanFuncFloatReducer ¶ added in v0.11.0
type BooleanFuncFloatReducer struct {
// contains filtered or unexported fields
}
func NewBooleanFuncFloatReducer ¶ added in v0.11.0
func NewBooleanFuncFloatReducer(fn BooleanReduceFloatFunc) *BooleanFuncFloatReducer
func (*BooleanFuncFloatReducer) AggregateBoolean ¶ added in v0.11.0
func (r *BooleanFuncFloatReducer) AggregateBoolean(p *BooleanPoint)
func (*BooleanFuncFloatReducer) Emit ¶ added in v0.11.0
func (r *BooleanFuncFloatReducer) Emit() []FloatPoint
type BooleanFuncIntegerReducer ¶ added in v0.11.0
type BooleanFuncIntegerReducer struct {
// contains filtered or unexported fields
}
func NewBooleanFuncIntegerReducer ¶ added in v0.11.0
func NewBooleanFuncIntegerReducer(fn BooleanReduceIntegerFunc) *BooleanFuncIntegerReducer
func (*BooleanFuncIntegerReducer) AggregateBoolean ¶ added in v0.11.0
func (r *BooleanFuncIntegerReducer) AggregateBoolean(p *BooleanPoint)
func (*BooleanFuncIntegerReducer) Emit ¶ added in v0.11.0
func (r *BooleanFuncIntegerReducer) Emit() []IntegerPoint
type BooleanFuncReducer ¶ added in v0.11.0
type BooleanFuncReducer struct {
// contains filtered or unexported fields
}
func NewBooleanFuncReducer ¶ added in v0.11.0
func NewBooleanFuncReducer(fn BooleanReduceFunc) *BooleanFuncReducer
func (*BooleanFuncReducer) AggregateBoolean ¶ added in v0.11.0
func (r *BooleanFuncReducer) AggregateBoolean(p *BooleanPoint)
func (*BooleanFuncReducer) Emit ¶ added in v0.11.0
func (r *BooleanFuncReducer) Emit() []BooleanPoint
type BooleanFuncStringReducer ¶ added in v0.11.0
type BooleanFuncStringReducer struct {
// contains filtered or unexported fields
}
func NewBooleanFuncStringReducer ¶ added in v0.11.0
func NewBooleanFuncStringReducer(fn BooleanReduceStringFunc) *BooleanFuncStringReducer
func (*BooleanFuncStringReducer) AggregateBoolean ¶ added in v0.11.0
func (r *BooleanFuncStringReducer) AggregateBoolean(p *BooleanPoint)
func (*BooleanFuncStringReducer) Emit ¶ added in v0.11.0
func (r *BooleanFuncStringReducer) Emit() []StringPoint
type BooleanIterator ¶ added in v0.11.0
type BooleanIterator interface { Iterator Next() *BooleanPoint }
BooleanIterator represents a stream of boolean points.
type BooleanLiteral ¶
type BooleanLiteral struct {
Val bool
}
BooleanLiteral represents a boolean literal.
func (*BooleanLiteral) String ¶
func (l *BooleanLiteral) String() string
String returns a string representation of the literal.
type BooleanPoint ¶ added in v0.11.0
type BooleanPoint struct { Name string Tags Tags Time int64 Nil bool Value bool Aux []interface{} // Total number of points that were combined into this point from an aggregate. // If this is zero, the point is not the result of an aggregate function. Aggregated uint32 }
BooleanPoint represents a point with a bool value. DO NOT ADD ADDITIONAL FIELDS TO THIS STRUCT. See TestPoint_Fields in influxql/point_test.go for more details.
func BooleanDistinctReduceSlice ¶ added in v0.11.0
func BooleanDistinctReduceSlice(a []BooleanPoint) []BooleanPoint
BooleanDistinctReduceSlice returns the distinct value within a window.
func (*BooleanPoint) Clone ¶ added in v0.11.0
func (v *BooleanPoint) Clone() *BooleanPoint
Clone returns a copy of v.
type BooleanPointAggregator ¶ added in v0.11.0
type BooleanPointAggregator interface {
AggregateBoolean(p *BooleanPoint)
}
BooleanPointAggregator aggregates points to produce a single point.
type BooleanPointDecoder ¶ added in v0.11.0
type BooleanPointDecoder struct {
// contains filtered or unexported fields
}
NewBooleanPointDecoder decodes BooleanPoint points from a reader.
func NewBooleanPointDecoder ¶ added in v0.11.0
func NewBooleanPointDecoder(r io.Reader) *BooleanPointDecoder
NewBooleanPointDecoder returns a new instance of BooleanPointDecoder that reads from r.
func (*BooleanPointDecoder) DecodeBooleanPoint ¶ added in v0.11.0
func (dec *BooleanPointDecoder) DecodeBooleanPoint(p *BooleanPoint) error
DecodeBooleanPoint reads from the underlying reader and unmarshals into p.
type BooleanPointEmitter ¶ added in v0.11.0
type BooleanPointEmitter interface {
Emit() []BooleanPoint
}
BooleanPointEmitter produces a single point from an aggregate.
type BooleanPointEncoder ¶ added in v0.11.0
type BooleanPointEncoder struct {
// contains filtered or unexported fields
}
NewBooleanPointEncoder encodes BooleanPoint points to a writer.
func NewBooleanPointEncoder ¶ added in v0.11.0
func NewBooleanPointEncoder(w io.Writer) *BooleanPointEncoder
NewBooleanPointEncoder returns a new instance of BooleanPointEncoder that writes to w.
func (*BooleanPointEncoder) EncodeBooleanPoint ¶ added in v0.11.0
func (enc *BooleanPointEncoder) EncodeBooleanPoint(p *BooleanPoint) error
EncodeBooleanPoint marshals and writes p to the underlying writer.
type BooleanReduceFloatFunc ¶ added in v0.11.0
type BooleanReduceFloatFunc func(prev *FloatPoint, curr *BooleanPoint) (t int64, v float64, aux []interface{})
BooleanReduceFloatFunc is the function called by a BooleanPoint reducer.
type BooleanReduceFloatSliceFunc ¶ added in v0.11.0
type BooleanReduceFloatSliceFunc func(a []BooleanPoint) []FloatPoint
BooleanReduceFloatSliceFunc is the function called by a BooleanPoint reducer.
type BooleanReduceFunc ¶ added in v0.11.0
type BooleanReduceFunc func(prev *BooleanPoint, curr *BooleanPoint) (t int64, v bool, aux []interface{})
BooleanReduceFunc is the function called by a BooleanPoint reducer.
type BooleanReduceIntegerFunc ¶ added in v0.11.0
type BooleanReduceIntegerFunc func(prev *IntegerPoint, curr *BooleanPoint) (t int64, v int64, aux []interface{})
BooleanReduceIntegerFunc is the function called by a BooleanPoint reducer.
type BooleanReduceIntegerSliceFunc ¶ added in v0.11.0
type BooleanReduceIntegerSliceFunc func(a []BooleanPoint) []IntegerPoint
BooleanReduceIntegerSliceFunc is the function called by a BooleanPoint reducer.
type BooleanReduceSliceFunc ¶ added in v0.11.0
type BooleanReduceSliceFunc func(a []BooleanPoint) []BooleanPoint
BooleanReduceSliceFunc is the function called by a BooleanPoint reducer.
type BooleanReduceStringFunc ¶ added in v0.11.0
type BooleanReduceStringFunc func(prev *StringPoint, curr *BooleanPoint) (t int64, v string, aux []interface{})
BooleanReduceStringFunc is the function called by a BooleanPoint reducer.
type BooleanReduceStringSliceFunc ¶ added in v0.11.0
type BooleanReduceStringSliceFunc func(a []BooleanPoint) []StringPoint
BooleanReduceStringSliceFunc is the function called by a BooleanPoint reducer.
type BooleanSliceFuncFloatReducer ¶ added in v0.11.0
type BooleanSliceFuncFloatReducer struct {
// contains filtered or unexported fields
}
func NewBooleanSliceFuncFloatReducer ¶ added in v0.11.0
func NewBooleanSliceFuncFloatReducer(fn BooleanReduceFloatSliceFunc) *BooleanSliceFuncFloatReducer
func (*BooleanSliceFuncFloatReducer) AggregateBoolean ¶ added in v0.11.0
func (r *BooleanSliceFuncFloatReducer) AggregateBoolean(p *BooleanPoint)
func (*BooleanSliceFuncFloatReducer) AggregateBooleanBulk ¶ added in v0.11.0
func (r *BooleanSliceFuncFloatReducer) AggregateBooleanBulk(points []BooleanPoint)
func (*BooleanSliceFuncFloatReducer) Emit ¶ added in v0.11.0
func (r *BooleanSliceFuncFloatReducer) Emit() []FloatPoint
type BooleanSliceFuncIntegerReducer ¶ added in v0.11.0
type BooleanSliceFuncIntegerReducer struct {
// contains filtered or unexported fields
}
func NewBooleanSliceFuncIntegerReducer ¶ added in v0.11.0
func NewBooleanSliceFuncIntegerReducer(fn BooleanReduceIntegerSliceFunc) *BooleanSliceFuncIntegerReducer
func (*BooleanSliceFuncIntegerReducer) AggregateBoolean ¶ added in v0.11.0
func (r *BooleanSliceFuncIntegerReducer) AggregateBoolean(p *BooleanPoint)
func (*BooleanSliceFuncIntegerReducer) AggregateBooleanBulk ¶ added in v0.11.0
func (r *BooleanSliceFuncIntegerReducer) AggregateBooleanBulk(points []BooleanPoint)
func (*BooleanSliceFuncIntegerReducer) Emit ¶ added in v0.11.0
func (r *BooleanSliceFuncIntegerReducer) Emit() []IntegerPoint
type BooleanSliceFuncReducer ¶ added in v0.11.0
type BooleanSliceFuncReducer struct {
// contains filtered or unexported fields
}
func NewBooleanSliceFuncReducer ¶ added in v0.11.0
func NewBooleanSliceFuncReducer(fn BooleanReduceSliceFunc) *BooleanSliceFuncReducer
func (*BooleanSliceFuncReducer) AggregateBoolean ¶ added in v0.11.0
func (r *BooleanSliceFuncReducer) AggregateBoolean(p *BooleanPoint)
func (*BooleanSliceFuncReducer) AggregateBooleanBulk ¶ added in v0.11.0
func (r *BooleanSliceFuncReducer) AggregateBooleanBulk(points []BooleanPoint)
func (*BooleanSliceFuncReducer) Emit ¶ added in v0.11.0
func (r *BooleanSliceFuncReducer) Emit() []BooleanPoint
type BooleanSliceFuncStringReducer ¶ added in v0.11.0
type BooleanSliceFuncStringReducer struct {
// contains filtered or unexported fields
}
func NewBooleanSliceFuncStringReducer ¶ added in v0.11.0
func NewBooleanSliceFuncStringReducer(fn BooleanReduceStringSliceFunc) *BooleanSliceFuncStringReducer
func (*BooleanSliceFuncStringReducer) AggregateBoolean ¶ added in v0.11.0
func (r *BooleanSliceFuncStringReducer) AggregateBoolean(p *BooleanPoint)
func (*BooleanSliceFuncStringReducer) AggregateBooleanBulk ¶ added in v0.11.0
func (r *BooleanSliceFuncStringReducer) AggregateBooleanBulk(points []BooleanPoint)
func (*BooleanSliceFuncStringReducer) Emit ¶ added in v0.11.0
func (r *BooleanSliceFuncStringReducer) Emit() []StringPoint
type Call ¶
Call represents a function call.
type CreateContinuousQueryStatement ¶
type CreateContinuousQueryStatement struct { // Name of the continuous query to be created. Name string // Name of the database to create the continuous query on. Database string // Source of data (SELECT statement). Source *SelectStatement // Interval to resample previous queries ResampleEvery time.Duration // Maximum duration to resample previous queries ResampleFor time.Duration }
CreateContinuousQueryStatement represents a command for creating a continuous query.
func (*CreateContinuousQueryStatement) DefaultDatabase ¶
func (s *CreateContinuousQueryStatement) DefaultDatabase() string
DefaultDatabase returns the default database from the statement.
func (*CreateContinuousQueryStatement) RequiredPrivileges ¶
func (s *CreateContinuousQueryStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a CreateContinuousQueryStatement.
func (*CreateContinuousQueryStatement) String ¶
func (s *CreateContinuousQueryStatement) String() string
String returns a string representation of the statement.
type CreateDatabaseStatement ¶
type CreateDatabaseStatement struct { // Name of the database to be created. Name string // IfNotExists indicates whether to return without error if the database // already exists. IfNotExists bool // RetentionPolicyCreate indicates whether the user explicitly wants to create a retention policy RetentionPolicyCreate bool // RetentionPolicyDuration indicates retention duration for the new database RetentionPolicyDuration time.Duration // RetentionPolicyReplication indicates retention replication for the new database RetentionPolicyReplication int // RetentionPolicyName indicates retention name for the new database RetentionPolicyName string }
CreateDatabaseStatement represents a command for creating a new database.
func (*CreateDatabaseStatement) RequiredPrivileges ¶
func (s *CreateDatabaseStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a CreateDatabaseStatement.
func (*CreateDatabaseStatement) String ¶
func (s *CreateDatabaseStatement) String() string
String returns a string representation of the create database statement.
type CreateRetentionPolicyStatement ¶
type CreateRetentionPolicyStatement struct { // Name of policy to create. Name string // Name of database this policy belongs to. Database string // Duration data written to this policy will be retained. Duration time.Duration // Replication factor for data written to this policy. Replication int // Should this policy be set as default for the database? Default bool }
CreateRetentionPolicyStatement represents a command to create a retention policy.
func (*CreateRetentionPolicyStatement) RequiredPrivileges ¶
func (s *CreateRetentionPolicyStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a CreateRetentionPolicyStatement.
func (*CreateRetentionPolicyStatement) String ¶
func (s *CreateRetentionPolicyStatement) String() string
String returns a string representation of the create retention policy.
type CreateSubscriptionStatement ¶ added in v0.9.5
type CreateSubscriptionStatement struct { Name string Database string RetentionPolicy string Destinations []string Mode string }
CreateSubscriptionStatement represents a command to add a subscription to the incoming data stream
func (*CreateSubscriptionStatement) RequiredPrivileges ¶ added in v0.9.5
func (s *CreateSubscriptionStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a CreateSubscriptionStatement
func (*CreateSubscriptionStatement) String ¶ added in v0.9.5
func (s *CreateSubscriptionStatement) String() string
String returns a string representation of the CreateSubscriptionStatement.
type CreateUserStatement ¶
type CreateUserStatement struct { // Name of the user to be created. Name string // User's password. Password string // User's admin privilege. Admin bool }
CreateUserStatement represents a command for creating a new user.
func (*CreateUserStatement) RequiredPrivileges ¶
func (s *CreateUserStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a CreateUserStatement.
func (*CreateUserStatement) String ¶
func (s *CreateUserStatement) String() string
String returns a string representation of the create user statement.
type DataType ¶
type DataType int
DataType represents the primitive data types available in InfluxQL.
func InspectDataType ¶
func InspectDataType(v interface{}) DataType
InspectDataType returns the data type of a given value.
func InspectDataTypes ¶ added in v0.11.0
func InspectDataTypes(a []interface{}) []DataType
type DeleteStatement ¶
type DeleteStatement struct { // Data source that values are removed from. Source Source // An expression evaluated on data point. Condition Expr }
DeleteStatement represents a command for removing data from the database.
func (*DeleteStatement) RequiredPrivileges ¶
func (s *DeleteStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a DeleteStatement.
func (*DeleteStatement) String ¶
func (s *DeleteStatement) String() string
String returns a string representation of the delete statement.
type Dimension ¶
type Dimension struct {
Expr Expr
}
Dimension represents an expression that a select statement is grouped by.
type Dimensions ¶
type Dimensions []*Dimension
Dimensions represents a list of dimensions.
func (Dimensions) Normalize ¶
func (a Dimensions) Normalize() (time.Duration, []string)
Normalize returns the interval and tag dimensions separately. Returns 0 if no time interval is specified.
func (Dimensions) String ¶
func (a Dimensions) String() string
String returns a string representation of the dimensions.
type Distinct ¶
type Distinct struct { // Identifier following DISTINCT Val string }
Distinct represents a DISTINCT expression.
type DropContinuousQueryStatement ¶
DropContinuousQueryStatement represents a command for removing a continuous query.
func (*DropContinuousQueryStatement) RequiredPrivileges ¶
func (s *DropContinuousQueryStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a DropContinuousQueryStatement
func (*DropContinuousQueryStatement) String ¶
func (s *DropContinuousQueryStatement) String() string
String returns a string representation of the statement.
type DropDatabaseStatement ¶
type DropDatabaseStatement struct { // Name of the database to be dropped. Name string // IfExists indicates whether to return without error if the database // does not exists. IfExists bool }
DropDatabaseStatement represents a command to drop a database.
func (*DropDatabaseStatement) RequiredPrivileges ¶
func (s *DropDatabaseStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a DropDatabaseStatement.
func (*DropDatabaseStatement) String ¶
func (s *DropDatabaseStatement) String() string
String returns a string representation of the drop database statement.
type DropMeasurementStatement ¶
type DropMeasurementStatement struct { // Name of the measurement to be dropped. Name string }
DropMeasurementStatement represents a command to drop a measurement.
func (*DropMeasurementStatement) RequiredPrivileges ¶
func (s *DropMeasurementStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a DropMeasurementStatement
func (*DropMeasurementStatement) String ¶
func (s *DropMeasurementStatement) String() string
String returns a string representation of the drop measurement statement.
type DropRetentionPolicyStatement ¶
type DropRetentionPolicyStatement struct { // Name of the policy to drop. Name string // Name of the database to drop the policy from. Database string }
DropRetentionPolicyStatement represents a command to drop a retention policy from a database.
func (*DropRetentionPolicyStatement) RequiredPrivileges ¶
func (s *DropRetentionPolicyStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a DropRetentionPolicyStatement.
func (*DropRetentionPolicyStatement) String ¶
func (s *DropRetentionPolicyStatement) String() string
String returns a string representation of the drop retention policy statement.
type DropSeriesStatement ¶
type DropSeriesStatement struct { // Data source that fields are extracted from (optional) Sources Sources // An expression evaluated on data point (optional) Condition Expr }
DropSeriesStatement represents a command for removing a series from the database.
func (DropSeriesStatement) RequiredPrivileges ¶
func (s DropSeriesStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a DropSeriesStatement.
func (*DropSeriesStatement) String ¶
func (s *DropSeriesStatement) String() string
String returns a string representation of the drop series statement.
type DropServerStatement ¶ added in v0.9.5
type DropServerStatement struct { // ID of the node to be dropped. NodeID uint64 // Meta indicates if the server being dropped is a meta or data node Meta bool }
DropServerStatement represents a command for removing a server from the cluster.
func (*DropServerStatement) RequiredPrivileges ¶ added in v0.9.5
func (s *DropServerStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a DropServerStatement.
func (*DropServerStatement) String ¶ added in v0.9.5
func (s *DropServerStatement) String() string
String returns a string representation of the drop series statement.
type DropSubscriptionStatement ¶ added in v0.9.5
DropSubscriptionStatement represents a command to drop a subscription to the incoming data stream.
func (*DropSubscriptionStatement) RequiredPrivileges ¶ added in v0.9.5
func (s *DropSubscriptionStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a DropSubscriptionStatement
func (*DropSubscriptionStatement) String ¶ added in v0.9.5
func (s *DropSubscriptionStatement) String() string
String returns a string representation of the DropSubscriptionStatement.
type DropUserStatement ¶
type DropUserStatement struct { // Name of the user to drop. Name string }
DropUserStatement represents a command for dropping a user.
func (*DropUserStatement) RequiredPrivileges ¶
func (s *DropUserStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a DropUserStatement.
func (*DropUserStatement) String ¶
func (s *DropUserStatement) String() string
String returns a string representation of the drop user statement.
type DurationLiteral ¶
DurationLiteral represents a duration literal.
func (*DurationLiteral) String ¶
func (l *DurationLiteral) String() string
String returns a string representation of the literal.
type Emitter ¶ added in v0.11.0
type Emitter struct { // The columns to attach to each row. Columns []string // Removes the "time" column from output. // Used for meta queries where time does not apply. OmitTime bool // contains filtered or unexported fields }
Emitter groups values together by name,
func NewEmitter ¶ added in v0.11.0
NewEmitter returns a new instance of Emitter that pulls from itrs.
type ExecutionPrivilege ¶
type ExecutionPrivilege struct { // Admin privilege required. Admin bool // Name of the database. Name string // Database privilege required. Privilege Privilege }
ExecutionPrivilege is a privilege required for a user to execute a statement on a database or resource.
type ExecutionPrivileges ¶
type ExecutionPrivileges []ExecutionPrivilege
ExecutionPrivileges is a list of privileges required to execute a statement.
type Expr ¶
type Expr interface { Node // contains filtered or unexported methods }
Expr represents an expression that can be evaluated to a value.
func MustParseExpr ¶ added in v0.11.0
MustParseExpr parses an expression string and returns its AST. Panic on error.
type Field ¶
Field represents an expression retrieved from a select statement.
type Fields ¶
type Fields []*Field
Fields represents a list of fields.
func (Fields) AliasNames ¶ added in v0.9.3
AliasNames returns a list of calculated field names in order of alias, function name, then field.
type FillOption ¶
type FillOption int
FillOption represents different options for aggregate windows.
const ( // NullFill means that empty aggregate windows will just have null values. NullFill FillOption = iota // NoFill means that empty aggregate windows will be purged from the result. NoFill // NumberFill means that empty aggregate windows will be filled with the given number NumberFill // PreviousFill means that empty aggregate windows will be filled with whatever the previous aggregate window had PreviousFill )
type FloatBulkPointAggregator ¶ added in v0.11.0
type FloatBulkPointAggregator interface {
AggregateFloatBulk(points []FloatPoint)
}
FloatBulkPointAggregator aggregates multiple points at a time.
type FloatFuncBooleanReducer ¶ added in v0.11.0
type FloatFuncBooleanReducer struct {
// contains filtered or unexported fields
}
func NewFloatFuncBooleanReducer ¶ added in v0.11.0
func NewFloatFuncBooleanReducer(fn FloatReduceBooleanFunc) *FloatFuncBooleanReducer
func (*FloatFuncBooleanReducer) AggregateFloat ¶ added in v0.11.0
func (r *FloatFuncBooleanReducer) AggregateFloat(p *FloatPoint)
func (*FloatFuncBooleanReducer) Emit ¶ added in v0.11.0
func (r *FloatFuncBooleanReducer) Emit() []BooleanPoint
type FloatFuncIntegerReducer ¶ added in v0.11.0
type FloatFuncIntegerReducer struct {
// contains filtered or unexported fields
}
func NewFloatFuncIntegerReducer ¶ added in v0.11.0
func NewFloatFuncIntegerReducer(fn FloatReduceIntegerFunc) *FloatFuncIntegerReducer
func (*FloatFuncIntegerReducer) AggregateFloat ¶ added in v0.11.0
func (r *FloatFuncIntegerReducer) AggregateFloat(p *FloatPoint)
func (*FloatFuncIntegerReducer) Emit ¶ added in v0.11.0
func (r *FloatFuncIntegerReducer) Emit() []IntegerPoint
type FloatFuncReducer ¶ added in v0.11.0
type FloatFuncReducer struct {
// contains filtered or unexported fields
}
func NewFloatFuncReducer ¶ added in v0.11.0
func NewFloatFuncReducer(fn FloatReduceFunc) *FloatFuncReducer
func (*FloatFuncReducer) AggregateFloat ¶ added in v0.11.0
func (r *FloatFuncReducer) AggregateFloat(p *FloatPoint)
func (*FloatFuncReducer) Emit ¶ added in v0.11.0
func (r *FloatFuncReducer) Emit() []FloatPoint
type FloatFuncStringReducer ¶ added in v0.11.0
type FloatFuncStringReducer struct {
// contains filtered or unexported fields
}
func NewFloatFuncStringReducer ¶ added in v0.11.0
func NewFloatFuncStringReducer(fn FloatReduceStringFunc) *FloatFuncStringReducer
func (*FloatFuncStringReducer) AggregateFloat ¶ added in v0.11.0
func (r *FloatFuncStringReducer) AggregateFloat(p *FloatPoint)
func (*FloatFuncStringReducer) Emit ¶ added in v0.11.0
func (r *FloatFuncStringReducer) Emit() []StringPoint
type FloatIterator ¶ added in v0.11.0
type FloatIterator interface { Iterator Next() *FloatPoint }
FloatIterator represents a stream of float points.
type FloatMeanReducer ¶ added in v0.11.0
type FloatMeanReducer struct {
// contains filtered or unexported fields
}
func NewFloatMeanReducer ¶ added in v0.11.0
func NewFloatMeanReducer() *FloatMeanReducer
func (*FloatMeanReducer) AggregateFloat ¶ added in v0.11.0
func (r *FloatMeanReducer) AggregateFloat(p *FloatPoint)
func (*FloatMeanReducer) Emit ¶ added in v0.11.0
func (r *FloatMeanReducer) Emit() []FloatPoint
type FloatPoint ¶ added in v0.11.0
type FloatPoint struct { Name string Tags Tags Time int64 Nil bool Value float64 Aux []interface{} // Total number of points that were combined into this point from an aggregate. // If this is zero, the point is not the result of an aggregate function. Aggregated uint32 }
FloatPoint represents a point with a float64 value. DO NOT ADD ADDITIONAL FIELDS TO THIS STRUCT. See TestPoint_Fields in influxql/point_test.go for more details.
func FloatDistinctReduceSlice ¶ added in v0.11.0
func FloatDistinctReduceSlice(a []FloatPoint) []FloatPoint
FloatDistinctReduceSlice returns the distinct value within a window.
func FloatMedianReduceSlice ¶ added in v0.11.0
func FloatMedianReduceSlice(a []FloatPoint) []FloatPoint
FloatMedianReduceSlice returns the median value within a window.
func FloatSpreadReduceSlice ¶ added in v0.11.0
func FloatSpreadReduceSlice(a []FloatPoint) []FloatPoint
FloatSpreadReduceSlice returns the spread value within a window.
func FloatStddevReduceSlice ¶ added in v0.11.0
func FloatStddevReduceSlice(a []FloatPoint) []FloatPoint
FloatStddevReduceSlice returns the stddev value within a window.
func IntegerMedianReduceSlice ¶ added in v0.11.0
func IntegerMedianReduceSlice(a []IntegerPoint) []FloatPoint
IntegerMedianReduceSlice returns the median value within a window.
func IntegerStddevReduceSlice ¶ added in v0.11.0
func IntegerStddevReduceSlice(a []IntegerPoint) []FloatPoint
IntegerStddevReduceSlice returns the stddev value within a window.
func (*FloatPoint) Clone ¶ added in v0.11.0
func (v *FloatPoint) Clone() *FloatPoint
Clone returns a copy of v.
type FloatPointAggregator ¶ added in v0.11.0
type FloatPointAggregator interface {
AggregateFloat(p *FloatPoint)
}
FloatPointAggregator aggregates points to produce a single point.
type FloatPointDecoder ¶ added in v0.11.0
type FloatPointDecoder struct {
// contains filtered or unexported fields
}
NewFloatPointDecoder decodes FloatPoint points from a reader.
func NewFloatPointDecoder ¶ added in v0.11.0
func NewFloatPointDecoder(r io.Reader) *FloatPointDecoder
NewFloatPointDecoder returns a new instance of FloatPointDecoder that reads from r.
func (*FloatPointDecoder) DecodeFloatPoint ¶ added in v0.11.0
func (dec *FloatPointDecoder) DecodeFloatPoint(p *FloatPoint) error
DecodeFloatPoint reads from the underlying reader and unmarshals into p.
type FloatPointEmitter ¶ added in v0.11.0
type FloatPointEmitter interface {
Emit() []FloatPoint
}
FloatPointEmitter produces a single point from an aggregate.
type FloatPointEncoder ¶ added in v0.11.0
type FloatPointEncoder struct {
// contains filtered or unexported fields
}
NewFloatPointEncoder encodes FloatPoint points to a writer.
func NewFloatPointEncoder ¶ added in v0.11.0
func NewFloatPointEncoder(w io.Writer) *FloatPointEncoder
NewFloatPointEncoder returns a new instance of FloatPointEncoder that writes to w.
func (*FloatPointEncoder) EncodeFloatPoint ¶ added in v0.11.0
func (enc *FloatPointEncoder) EncodeFloatPoint(p *FloatPoint) error
EncodeFloatPoint marshals and writes p to the underlying writer.
type FloatReduceBooleanFunc ¶ added in v0.11.0
type FloatReduceBooleanFunc func(prev *BooleanPoint, curr *FloatPoint) (t int64, v bool, aux []interface{})
FloatReduceBooleanFunc is the function called by a FloatPoint reducer.
type FloatReduceBooleanSliceFunc ¶ added in v0.11.0
type FloatReduceBooleanSliceFunc func(a []FloatPoint) []BooleanPoint
FloatReduceBooleanSliceFunc is the function called by a FloatPoint reducer.
type FloatReduceFunc ¶ added in v0.11.0
type FloatReduceFunc func(prev *FloatPoint, curr *FloatPoint) (t int64, v float64, aux []interface{})
FloatReduceFunc is the function called by a FloatPoint reducer.
type FloatReduceIntegerFunc ¶ added in v0.11.0
type FloatReduceIntegerFunc func(prev *IntegerPoint, curr *FloatPoint) (t int64, v int64, aux []interface{})
FloatReduceIntegerFunc is the function called by a FloatPoint reducer.
type FloatReduceIntegerSliceFunc ¶ added in v0.11.0
type FloatReduceIntegerSliceFunc func(a []FloatPoint) []IntegerPoint
FloatReduceIntegerSliceFunc is the function called by a FloatPoint reducer.
type FloatReduceSliceFunc ¶ added in v0.11.0
type FloatReduceSliceFunc func(a []FloatPoint) []FloatPoint
FloatReduceSliceFunc is the function called by a FloatPoint reducer.
func NewFloatBottomReduceSliceFunc ¶ added in v0.11.0
func NewFloatBottomReduceSliceFunc(n int, tags []int, interval Interval) FloatReduceSliceFunc
NewFloatBottomReduceSliceFunc returns the bottom values within a window.
func NewFloatDerivativeReduceSliceFunc ¶ added in v0.11.0
func NewFloatDerivativeReduceSliceFunc(interval Interval, isNonNegative bool) FloatReduceSliceFunc
NewFloatDerivativeReduceSliceFunc returns the derivative value within a window.
func NewFloatPercentileReduceSliceFunc ¶ added in v0.11.0
func NewFloatPercentileReduceSliceFunc(percentile float64) FloatReduceSliceFunc
NewFloatPercentileReduceSliceFunc returns the percentile value within a window.
func NewFloatTopReduceSliceFunc ¶ added in v0.11.0
func NewFloatTopReduceSliceFunc(n int, tags []int, interval Interval) FloatReduceSliceFunc
NewFloatTopReduceSliceFunc returns the top values within a window.
type FloatReduceStringFunc ¶ added in v0.11.0
type FloatReduceStringFunc func(prev *StringPoint, curr *FloatPoint) (t int64, v string, aux []interface{})
FloatReduceStringFunc is the function called by a FloatPoint reducer.
type FloatReduceStringSliceFunc ¶ added in v0.11.0
type FloatReduceStringSliceFunc func(a []FloatPoint) []StringPoint
FloatReduceStringSliceFunc is the function called by a FloatPoint reducer.
type FloatSliceFuncBooleanReducer ¶ added in v0.11.0
type FloatSliceFuncBooleanReducer struct {
// contains filtered or unexported fields
}
func NewFloatSliceFuncBooleanReducer ¶ added in v0.11.0
func NewFloatSliceFuncBooleanReducer(fn FloatReduceBooleanSliceFunc) *FloatSliceFuncBooleanReducer
func (*FloatSliceFuncBooleanReducer) AggregateFloat ¶ added in v0.11.0
func (r *FloatSliceFuncBooleanReducer) AggregateFloat(p *FloatPoint)
func (*FloatSliceFuncBooleanReducer) AggregateFloatBulk ¶ added in v0.11.0
func (r *FloatSliceFuncBooleanReducer) AggregateFloatBulk(points []FloatPoint)
func (*FloatSliceFuncBooleanReducer) Emit ¶ added in v0.11.0
func (r *FloatSliceFuncBooleanReducer) Emit() []BooleanPoint
type FloatSliceFuncIntegerReducer ¶ added in v0.11.0
type FloatSliceFuncIntegerReducer struct {
// contains filtered or unexported fields
}
func NewFloatSliceFuncIntegerReducer ¶ added in v0.11.0
func NewFloatSliceFuncIntegerReducer(fn FloatReduceIntegerSliceFunc) *FloatSliceFuncIntegerReducer
func (*FloatSliceFuncIntegerReducer) AggregateFloat ¶ added in v0.11.0
func (r *FloatSliceFuncIntegerReducer) AggregateFloat(p *FloatPoint)
func (*FloatSliceFuncIntegerReducer) AggregateFloatBulk ¶ added in v0.11.0
func (r *FloatSliceFuncIntegerReducer) AggregateFloatBulk(points []FloatPoint)
func (*FloatSliceFuncIntegerReducer) Emit ¶ added in v0.11.0
func (r *FloatSliceFuncIntegerReducer) Emit() []IntegerPoint
type FloatSliceFuncReducer ¶ added in v0.11.0
type FloatSliceFuncReducer struct {
// contains filtered or unexported fields
}
func NewFloatSliceFuncReducer ¶ added in v0.11.0
func NewFloatSliceFuncReducer(fn FloatReduceSliceFunc) *FloatSliceFuncReducer
func (*FloatSliceFuncReducer) AggregateFloat ¶ added in v0.11.0
func (r *FloatSliceFuncReducer) AggregateFloat(p *FloatPoint)
func (*FloatSliceFuncReducer) AggregateFloatBulk ¶ added in v0.11.0
func (r *FloatSliceFuncReducer) AggregateFloatBulk(points []FloatPoint)
func (*FloatSliceFuncReducer) Emit ¶ added in v0.11.0
func (r *FloatSliceFuncReducer) Emit() []FloatPoint
type FloatSliceFuncStringReducer ¶ added in v0.11.0
type FloatSliceFuncStringReducer struct {
// contains filtered or unexported fields
}
func NewFloatSliceFuncStringReducer ¶ added in v0.11.0
func NewFloatSliceFuncStringReducer(fn FloatReduceStringSliceFunc) *FloatSliceFuncStringReducer
func (*FloatSliceFuncStringReducer) AggregateFloat ¶ added in v0.11.0
func (r *FloatSliceFuncStringReducer) AggregateFloat(p *FloatPoint)
func (*FloatSliceFuncStringReducer) AggregateFloatBulk ¶ added in v0.11.0
func (r *FloatSliceFuncStringReducer) AggregateFloatBulk(points []FloatPoint)
func (*FloatSliceFuncStringReducer) Emit ¶ added in v0.11.0
func (r *FloatSliceFuncStringReducer) Emit() []StringPoint
type GrantAdminStatement ¶ added in v0.9.2
type GrantAdminStatement struct { // Who to grant the privilege to. User string }
GrantAdminStatement represents a command for granting admin privilege.
func (*GrantAdminStatement) RequiredPrivileges ¶ added in v0.9.2
func (s *GrantAdminStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a GrantAdminStatement.
func (*GrantAdminStatement) String ¶ added in v0.9.2
func (s *GrantAdminStatement) String() string
String returns a string representation of the grant admin statement.
type GrantStatement ¶
type GrantStatement struct { // The privilege to be granted. Privilege Privilege // Database to grant the privilege to. On string // Who to grant the privilege to. User string }
GrantStatement represents a command for granting a privilege.
func (*GrantStatement) RequiredPrivileges ¶
func (s *GrantStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a GrantStatement.
func (*GrantStatement) String ¶
func (s *GrantStatement) String() string
String returns a string representation of the grant statement.
type HasDefaultDatabase ¶
type HasDefaultDatabase interface { Node DefaultDatabase() string // contains filtered or unexported methods }
HasDefaultDatabase provides an interface to get the default database from a Statement.
type IntegerBulkPointAggregator ¶ added in v0.11.0
type IntegerBulkPointAggregator interface {
AggregateIntegerBulk(points []IntegerPoint)
}
IntegerBulkPointAggregator aggregates multiple points at a time.
type IntegerFuncBooleanReducer ¶ added in v0.11.0
type IntegerFuncBooleanReducer struct {
// contains filtered or unexported fields
}
func NewIntegerFuncBooleanReducer ¶ added in v0.11.0
func NewIntegerFuncBooleanReducer(fn IntegerReduceBooleanFunc) *IntegerFuncBooleanReducer
func (*IntegerFuncBooleanReducer) AggregateInteger ¶ added in v0.11.0
func (r *IntegerFuncBooleanReducer) AggregateInteger(p *IntegerPoint)
func (*IntegerFuncBooleanReducer) Emit ¶ added in v0.11.0
func (r *IntegerFuncBooleanReducer) Emit() []BooleanPoint
type IntegerFuncFloatReducer ¶ added in v0.11.0
type IntegerFuncFloatReducer struct {
// contains filtered or unexported fields
}
func NewIntegerFuncFloatReducer ¶ added in v0.11.0
func NewIntegerFuncFloatReducer(fn IntegerReduceFloatFunc) *IntegerFuncFloatReducer
func (*IntegerFuncFloatReducer) AggregateInteger ¶ added in v0.11.0
func (r *IntegerFuncFloatReducer) AggregateInteger(p *IntegerPoint)
func (*IntegerFuncFloatReducer) Emit ¶ added in v0.11.0
func (r *IntegerFuncFloatReducer) Emit() []FloatPoint
type IntegerFuncReducer ¶ added in v0.11.0
type IntegerFuncReducer struct {
// contains filtered or unexported fields
}
func NewIntegerFuncReducer ¶ added in v0.11.0
func NewIntegerFuncReducer(fn IntegerReduceFunc) *IntegerFuncReducer
func (*IntegerFuncReducer) AggregateInteger ¶ added in v0.11.0
func (r *IntegerFuncReducer) AggregateInteger(p *IntegerPoint)
func (*IntegerFuncReducer) Emit ¶ added in v0.11.0
func (r *IntegerFuncReducer) Emit() []IntegerPoint
type IntegerFuncStringReducer ¶ added in v0.11.0
type IntegerFuncStringReducer struct {
// contains filtered or unexported fields
}
func NewIntegerFuncStringReducer ¶ added in v0.11.0
func NewIntegerFuncStringReducer(fn IntegerReduceStringFunc) *IntegerFuncStringReducer
func (*IntegerFuncStringReducer) AggregateInteger ¶ added in v0.11.0
func (r *IntegerFuncStringReducer) AggregateInteger(p *IntegerPoint)
func (*IntegerFuncStringReducer) Emit ¶ added in v0.11.0
func (r *IntegerFuncStringReducer) Emit() []StringPoint
type IntegerIterator ¶ added in v0.11.0
type IntegerIterator interface { Iterator Next() *IntegerPoint }
IntegerIterator represents a stream of integer points.
type IntegerMeanReducer ¶ added in v0.11.0
type IntegerMeanReducer struct {
// contains filtered or unexported fields
}
func NewIntegerMeanReducer ¶ added in v0.11.0
func NewIntegerMeanReducer() *IntegerMeanReducer
func (*IntegerMeanReducer) AggregateInteger ¶ added in v0.11.0
func (r *IntegerMeanReducer) AggregateInteger(p *IntegerPoint)
func (*IntegerMeanReducer) Emit ¶ added in v0.11.0
func (r *IntegerMeanReducer) Emit() []FloatPoint
type IntegerPoint ¶ added in v0.11.0
type IntegerPoint struct { Name string Tags Tags Time int64 Nil bool Value int64 Aux []interface{} // Total number of points that were combined into this point from an aggregate. // If this is zero, the point is not the result of an aggregate function. Aggregated uint32 }
IntegerPoint represents a point with a int64 value. DO NOT ADD ADDITIONAL FIELDS TO THIS STRUCT. See TestPoint_Fields in influxql/point_test.go for more details.
func IntegerDistinctReduceSlice ¶ added in v0.11.0
func IntegerDistinctReduceSlice(a []IntegerPoint) []IntegerPoint
IntegerDistinctReduceSlice returns the distinct value within a window.
func IntegerSpreadReduceSlice ¶ added in v0.11.0
func IntegerSpreadReduceSlice(a []IntegerPoint) []IntegerPoint
IntegerSpreadReduceSlice returns the spread value within a window.
func (*IntegerPoint) Clone ¶ added in v0.11.0
func (v *IntegerPoint) Clone() *IntegerPoint
Clone returns a copy of v.
type IntegerPointAggregator ¶ added in v0.11.0
type IntegerPointAggregator interface {
AggregateInteger(p *IntegerPoint)
}
IntegerPointAggregator aggregates points to produce a single point.
type IntegerPointDecoder ¶ added in v0.11.0
type IntegerPointDecoder struct {
// contains filtered or unexported fields
}
NewIntegerPointDecoder decodes IntegerPoint points from a reader.
func NewIntegerPointDecoder ¶ added in v0.11.0
func NewIntegerPointDecoder(r io.Reader) *IntegerPointDecoder
NewIntegerPointDecoder returns a new instance of IntegerPointDecoder that reads from r.
func (*IntegerPointDecoder) DecodeIntegerPoint ¶ added in v0.11.0
func (dec *IntegerPointDecoder) DecodeIntegerPoint(p *IntegerPoint) error
DecodeIntegerPoint reads from the underlying reader and unmarshals into p.
type IntegerPointEmitter ¶ added in v0.11.0
type IntegerPointEmitter interface {
Emit() []IntegerPoint
}
IntegerPointEmitter produces a single point from an aggregate.
type IntegerPointEncoder ¶ added in v0.11.0
type IntegerPointEncoder struct {
// contains filtered or unexported fields
}
NewIntegerPointEncoder encodes IntegerPoint points to a writer.
func NewIntegerPointEncoder ¶ added in v0.11.0
func NewIntegerPointEncoder(w io.Writer) *IntegerPointEncoder
NewIntegerPointEncoder returns a new instance of IntegerPointEncoder that writes to w.
func (*IntegerPointEncoder) EncodeIntegerPoint ¶ added in v0.11.0
func (enc *IntegerPointEncoder) EncodeIntegerPoint(p *IntegerPoint) error
EncodeIntegerPoint marshals and writes p to the underlying writer.
type IntegerReduceBooleanFunc ¶ added in v0.11.0
type IntegerReduceBooleanFunc func(prev *BooleanPoint, curr *IntegerPoint) (t int64, v bool, aux []interface{})
IntegerReduceBooleanFunc is the function called by a IntegerPoint reducer.
type IntegerReduceBooleanSliceFunc ¶ added in v0.11.0
type IntegerReduceBooleanSliceFunc func(a []IntegerPoint) []BooleanPoint
IntegerReduceBooleanSliceFunc is the function called by a IntegerPoint reducer.
type IntegerReduceFloatFunc ¶ added in v0.11.0
type IntegerReduceFloatFunc func(prev *FloatPoint, curr *IntegerPoint) (t int64, v float64, aux []interface{})
IntegerReduceFloatFunc is the function called by a IntegerPoint reducer.
type IntegerReduceFloatSliceFunc ¶ added in v0.11.0
type IntegerReduceFloatSliceFunc func(a []IntegerPoint) []FloatPoint
IntegerReduceFloatSliceFunc is the function called by a IntegerPoint reducer.
func NewIntegerDerivativeReduceSliceFunc ¶ added in v0.11.0
func NewIntegerDerivativeReduceSliceFunc(interval Interval, isNonNegative bool) IntegerReduceFloatSliceFunc
NewIntegerDerivativeReduceSliceFunc returns the derivative value within a window.
type IntegerReduceFunc ¶ added in v0.11.0
type IntegerReduceFunc func(prev *IntegerPoint, curr *IntegerPoint) (t int64, v int64, aux []interface{})
IntegerReduceFunc is the function called by a IntegerPoint reducer.
type IntegerReduceSliceFunc ¶ added in v0.11.0
type IntegerReduceSliceFunc func(a []IntegerPoint) []IntegerPoint
IntegerReduceSliceFunc is the function called by a IntegerPoint reducer.
func NewIntegerBottomReduceSliceFunc ¶ added in v0.11.0
func NewIntegerBottomReduceSliceFunc(n int, tags []int, interval Interval) IntegerReduceSliceFunc
NewIntegerBottomReduceSliceFunc returns the bottom values within a window.
func NewIntegerPercentileReduceSliceFunc ¶ added in v0.11.0
func NewIntegerPercentileReduceSliceFunc(percentile float64) IntegerReduceSliceFunc
NewIntegerPercentileReduceSliceFunc returns the percentile value within a window.
func NewIntegerTopReduceSliceFunc ¶ added in v0.11.0
func NewIntegerTopReduceSliceFunc(n int, tags []int, interval Interval) IntegerReduceSliceFunc
NewIntegerTopReduceSliceFunc returns the top values within a window.
type IntegerReduceStringFunc ¶ added in v0.11.0
type IntegerReduceStringFunc func(prev *StringPoint, curr *IntegerPoint) (t int64, v string, aux []interface{})
IntegerReduceStringFunc is the function called by a IntegerPoint reducer.
type IntegerReduceStringSliceFunc ¶ added in v0.11.0
type IntegerReduceStringSliceFunc func(a []IntegerPoint) []StringPoint
IntegerReduceStringSliceFunc is the function called by a IntegerPoint reducer.
type IntegerSliceFuncBooleanReducer ¶ added in v0.11.0
type IntegerSliceFuncBooleanReducer struct {
// contains filtered or unexported fields
}
func NewIntegerSliceFuncBooleanReducer ¶ added in v0.11.0
func NewIntegerSliceFuncBooleanReducer(fn IntegerReduceBooleanSliceFunc) *IntegerSliceFuncBooleanReducer
func (*IntegerSliceFuncBooleanReducer) AggregateInteger ¶ added in v0.11.0
func (r *IntegerSliceFuncBooleanReducer) AggregateInteger(p *IntegerPoint)
func (*IntegerSliceFuncBooleanReducer) AggregateIntegerBulk ¶ added in v0.11.0
func (r *IntegerSliceFuncBooleanReducer) AggregateIntegerBulk(points []IntegerPoint)
func (*IntegerSliceFuncBooleanReducer) Emit ¶ added in v0.11.0
func (r *IntegerSliceFuncBooleanReducer) Emit() []BooleanPoint
type IntegerSliceFuncFloatReducer ¶ added in v0.11.0
type IntegerSliceFuncFloatReducer struct {
// contains filtered or unexported fields
}
func NewIntegerSliceFuncFloatReducer ¶ added in v0.11.0
func NewIntegerSliceFuncFloatReducer(fn IntegerReduceFloatSliceFunc) *IntegerSliceFuncFloatReducer
func (*IntegerSliceFuncFloatReducer) AggregateInteger ¶ added in v0.11.0
func (r *IntegerSliceFuncFloatReducer) AggregateInteger(p *IntegerPoint)
func (*IntegerSliceFuncFloatReducer) AggregateIntegerBulk ¶ added in v0.11.0
func (r *IntegerSliceFuncFloatReducer) AggregateIntegerBulk(points []IntegerPoint)
func (*IntegerSliceFuncFloatReducer) Emit ¶ added in v0.11.0
func (r *IntegerSliceFuncFloatReducer) Emit() []FloatPoint
type IntegerSliceFuncReducer ¶ added in v0.11.0
type IntegerSliceFuncReducer struct {
// contains filtered or unexported fields
}
func NewIntegerSliceFuncReducer ¶ added in v0.11.0
func NewIntegerSliceFuncReducer(fn IntegerReduceSliceFunc) *IntegerSliceFuncReducer
func (*IntegerSliceFuncReducer) AggregateInteger ¶ added in v0.11.0
func (r *IntegerSliceFuncReducer) AggregateInteger(p *IntegerPoint)
func (*IntegerSliceFuncReducer) AggregateIntegerBulk ¶ added in v0.11.0
func (r *IntegerSliceFuncReducer) AggregateIntegerBulk(points []IntegerPoint)
func (*IntegerSliceFuncReducer) Emit ¶ added in v0.11.0
func (r *IntegerSliceFuncReducer) Emit() []IntegerPoint
type IntegerSliceFuncStringReducer ¶ added in v0.11.0
type IntegerSliceFuncStringReducer struct {
// contains filtered or unexported fields
}
func NewIntegerSliceFuncStringReducer ¶ added in v0.11.0
func NewIntegerSliceFuncStringReducer(fn IntegerReduceStringSliceFunc) *IntegerSliceFuncStringReducer
func (*IntegerSliceFuncStringReducer) AggregateInteger ¶ added in v0.11.0
func (r *IntegerSliceFuncStringReducer) AggregateInteger(p *IntegerPoint)
func (*IntegerSliceFuncStringReducer) AggregateIntegerBulk ¶ added in v0.11.0
func (r *IntegerSliceFuncStringReducer) AggregateIntegerBulk(points []IntegerPoint)
func (*IntegerSliceFuncStringReducer) Emit ¶ added in v0.11.0
func (r *IntegerSliceFuncStringReducer) Emit() []StringPoint
type Iterator ¶
type Iterator interface {
Close() error
}
Iterator represents a generic interface for all Iterators. Most iterator operations are done on the typed sub-interfaces.
func NewCallIterator ¶ added in v0.11.0
func NewCallIterator(input Iterator, opt IteratorOptions) (Iterator, error)
NewCallIterator returns a new iterator for a Call.
func NewDedupeIterator ¶ added in v0.11.0
NewDedupeIterator returns an iterator that only outputs unique points. This iterator maintains a serialized copy of each row so it is inefficient to use on large datasets. It is intended for small datasets such as meta queries.
func NewDistinctIterator ¶ added in v0.11.0
func NewDistinctIterator(input Iterator, opt IteratorOptions) (Iterator, error)
NewDistinctIterator returns an iterator for operating on a distinct() call.
func NewFillIterator ¶ added in v0.11.0
func NewFillIterator(input Iterator, expr Expr, opt IteratorOptions) Iterator
NewFillIterator returns an iterator that fills in missing points in an aggregate.
func NewIntervalIterator ¶ added in v0.11.0
func NewIntervalIterator(input Iterator, opt IteratorOptions) Iterator
NewIntervalIterator returns an iterator that sets the time on each point to the interval.
func NewLimitIterator ¶ added in v0.11.0
func NewLimitIterator(input Iterator, opt IteratorOptions) Iterator
NewLimitIterator returns an iterator that limits the number of points per grouping.
func NewMergeIterator ¶ added in v0.11.0
func NewMergeIterator(inputs []Iterator, opt IteratorOptions) Iterator
NewMergeIterator returns an iterator to merge itrs into one. Inputs must either be merge iterators or only contain a single name/tag in sorted order. The iterator will output all points by window, name/tag, then time. This iterator is useful when you need all of the points for an interval.
func NewReaderIterator ¶ added in v0.11.0
NewReaderIterator returns an iterator that streams from a reader.
func NewSortedMergeIterator ¶ added in v0.11.0
func NewSortedMergeIterator(inputs []Iterator, opt IteratorOptions) Iterator
NewSortedMergeIterator returns an iterator to merge itrs into one. Inputs must either be sorted merge iterators or only contain a single name/tag in sorted order. The iterator will output all points by name/tag, then time. This iterator is useful when you need all points for a name/tag to be in order.
func Select ¶ added in v0.11.0
func Select(stmt *SelectStatement, ic IteratorCreator, sopt *SelectOptions) ([]Iterator, error)
Select executes stmt against ic and returns a list of iterators to stream from.
Statements should have all rewriting performed before calling select(). This includes wildcard and source expansion.
type IteratorCreator ¶ added in v0.11.0
type IteratorCreator interface { // Creates a simple iterator for use in an InfluxQL query. CreateIterator(opt IteratorOptions) (Iterator, error) // Returns the unique fields and dimensions across a list of sources. FieldDimensions(sources Sources) (fields, dimensions map[string]struct{}, err error) // Returns the series keys that will be returned by this iterator. SeriesKeys(opt IteratorOptions) (SeriesList, error) }
IteratorCreator represents an interface for objects that can create Iterators.
type IteratorCreators ¶ added in v0.11.0
type IteratorCreators []IteratorCreator
IteratorCreators represents a list of iterator creators.
func (IteratorCreators) Close ¶ added in v0.11.0
func (a IteratorCreators) Close() error
Close closes all iterator creators that implement io.Closer.
func (IteratorCreators) CreateIterator ¶ added in v0.11.0
func (a IteratorCreators) CreateIterator(opt IteratorOptions) (Iterator, error)
CreateIterator returns a single combined iterator from multiple iterator creators.
func (IteratorCreators) FieldDimensions ¶ added in v0.11.0
func (a IteratorCreators) FieldDimensions(sources Sources) (fields, dimensions map[string]struct{}, err error)
FieldDimensions returns unique fields and dimensions from multiple iterator creators.
func (IteratorCreators) SeriesKeys ¶ added in v0.11.0
func (a IteratorCreators) SeriesKeys(opt IteratorOptions) (SeriesList, error)
SeriesKeys returns a list of series in all iterator creators in a. If a series exists in multiple creators in a, all instances will be combined into a single Series by calling Combine on it.
type IteratorEncoder ¶ added in v0.11.0
type IteratorEncoder struct {
// contains filtered or unexported fields
}
IteratorEncoder is an encoder for encoding an iterator's points to w.
func NewIteratorEncoder ¶ added in v0.11.0
func NewIteratorEncoder(w io.Writer) *IteratorEncoder
NewIteratorEncoder encodes an iterator's points to w.
func (*IteratorEncoder) EncodeIterator ¶ added in v0.11.0
func (enc *IteratorEncoder) EncodeIterator(itr Iterator) error
Encode encodes and writes all of itr's points to the underlying writer.
type IteratorOptions ¶ added in v0.11.0
type IteratorOptions struct { // Expression to iterate for. // This can be VarRef or a Call. Expr Expr // Auxilary tags or values to also retrieve for the point. Aux []string // Data sources from which to retrieve data. Sources []Source // Group by interval and tags. Interval Interval Dimensions []string // Fill options. Fill FillOption FillValue interface{} // Condition to filter by. Condition Expr // Time range for the iterator. StartTime int64 EndTime int64 // Sorted in time ascending order if true. Ascending bool // Limits the number of points per series. Limit, Offset int // Limits the number of series. SLimit, SOffset int // Removes duplicate rows from raw queries. Dedupe bool }
IteratorOptions is an object passed to CreateIterator to specify creation options.
func (IteratorOptions) DerivativeInterval ¶ added in v0.11.0
func (opt IteratorOptions) DerivativeInterval() Interval
DerivativeInterval returns the time interval for the derivative function.
func (*IteratorOptions) MarshalBinary ¶ added in v0.11.0
func (opt *IteratorOptions) MarshalBinary() ([]byte, error)
MarshalBinary encodes opt into a binary format.
func (IteratorOptions) MergeSorted ¶ added in v0.11.0
func (opt IteratorOptions) MergeSorted() bool
MergeSorted returns true if the options require a sorted merge. This is only needed when the expression is a variable reference or there is no expr.
func (IteratorOptions) SeekTime ¶ added in v0.11.0
func (opt IteratorOptions) SeekTime() int64
SeekTime returns the time the iterator should start from. For ascending iterators this is the start time, for descending iterators it's the end time.
func (*IteratorOptions) UnmarshalBinary ¶ added in v0.11.0
func (opt *IteratorOptions) UnmarshalBinary(buf []byte) error
UnmarshalBinary decodes from a binary format in to opt.
func (IteratorOptions) Window ¶ added in v0.11.0
func (opt IteratorOptions) Window(t int64) (start, end int64)
Window returns the time window [start,end) that t falls within.
type Iterators ¶ added in v0.11.0
type Iterators []Iterator
Iterators represents a list of iterators.
type Literal ¶ added in v0.11.0
type Literal interface { Expr // contains filtered or unexported methods }
Literal represents a static literal.
type Measurement ¶
type Measurement struct { Database string RetentionPolicy string Name string Regex *RegexLiteral IsTarget bool }
Measurement represents a single measurement used as a datasource.
func (*Measurement) String ¶
func (m *Measurement) String() string
String returns a string representation of the measurement.
type Measurements ¶
type Measurements []*Measurement
Measurements represents a list of measurements.
func (Measurements) String ¶
func (a Measurements) String() string
String returns a string representation of the measurements.
type Node ¶
type Node interface { String() string // contains filtered or unexported methods }
Node represents a node in the InfluxDB abstract syntax tree.
type NumberLiteral ¶
type NumberLiteral struct {
Val float64
}
NumberLiteral represents a numeric literal.
func (*NumberLiteral) String ¶
func (l *NumberLiteral) String() string
String returns a string representation of the literal.
type ParenExpr ¶
type ParenExpr struct {
Expr Expr
}
ParenExpr represents a parenthesized expression.
type ParseError ¶
ParseError represents an error that occurred during parsing.
func (*ParseError) Error ¶
func (e *ParseError) Error() string
Error returns the string representation of the error.
type Parser ¶
type Parser struct {
// contains filtered or unexported fields
}
Parser represents an InfluxQL parser.
func (*Parser) ParseQuery ¶
ParseQuery parses an InfluxQL string and returns a Query AST object.
func (*Parser) ParseStatement ¶
ParseStatement parses an InfluxQL string and returns a Statement AST object.
type Point ¶ added in v0.11.0
type Point interface {
// contains filtered or unexported methods
}
Point represents a value in a series that occurred at a given time.
type PointDecoder ¶ added in v0.11.0
type PointDecoder struct {
// contains filtered or unexported fields
}
NewPointDecoder decodes generic points from a reader.
func NewPointDecoder ¶ added in v0.11.0
func NewPointDecoder(r io.Reader) *PointDecoder
NewPointDecoder returns a new instance of PointDecoder that reads from r.
func (*PointDecoder) DecodePoint ¶ added in v0.11.0
func (dec *PointDecoder) DecodePoint(p *Point) error
DecodePoint reads from the underlying reader and unmarshals into p.
type Pos ¶
Pos specifies the line and character position of a token. The Char and Line are both zero-based indexes.
type Privilege ¶
type Privilege int
Privilege is a type of action a user can be granted the right to use.
const ( // NoPrivileges means no privileges required / granted / revoked. NoPrivileges Privilege = iota // ReadPrivilege means read privilege required / granted / revoked. ReadPrivilege // WritePrivilege means write privilege required / granted / revoked. WritePrivilege // AllPrivileges means all privileges required / granted / revoked. AllPrivileges )
func NewPrivilege ¶
NewPrivilege returns an initialized *Privilege.
type Processor ¶ added in v0.9.2
type Processor func(values []interface{}) interface{}
Processor is a prcessor type returned by GetProcessor
type Query ¶
type Query struct {
Statements Statements
}
Query represents a collection of ordered statements.
func ParseQuery ¶
ParseQuery parses a query string and returns its AST representation.
type QueryExecutor ¶ added in v0.11.0
type QueryExecutor interface {
ExecuteQuery(query *Query, database string, chunkSize int, closing chan struct{}) <-chan *Result
}
QueryExecutor executes every statement in an Query.
type RegexLiteral ¶
RegexLiteral represents a regular expression.
func CloneRegexLiteral ¶
func CloneRegexLiteral(r *RegexLiteral) *RegexLiteral
CloneRegexLiteral returns a clone of the RegexLiteral.
func (*RegexLiteral) String ¶
func (r *RegexLiteral) String() string
String returns a string representation of the literal.
type Result ¶
type Result struct { // StatementID is just the statement's position in the query. It's used // to combine statement results if they're being buffered in memory. StatementID int `json:"-"` Series models.Rows Err error }
Result represents a resultset returned from a single statement. Rows represents a list of rows that can be sorted consistently by name/tag.
func (*Result) MarshalJSON ¶
MarshalJSON encodes the result into JSON.
func (*Result) UnmarshalJSON ¶
UnmarshalJSON decodes the data into the Result struct
type RevokeAdminStatement ¶ added in v0.9.2
type RevokeAdminStatement struct { // Who to revoke admin privilege from. User string }
RevokeAdminStatement represents a command to revoke admin privilege from a user.
func (*RevokeAdminStatement) RequiredPrivileges ¶ added in v0.9.2
func (s *RevokeAdminStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a RevokeAdminStatement.
func (*RevokeAdminStatement) String ¶ added in v0.9.2
func (s *RevokeAdminStatement) String() string
String returns a string representation of the revoke admin statement.
type RevokeStatement ¶
type RevokeStatement struct { // The privilege to be revoked. Privilege Privilege // Database to revoke the privilege from. On string // Who to revoke privilege from. User string }
RevokeStatement represents a command to revoke a privilege from a user.
func (*RevokeStatement) RequiredPrivileges ¶
func (s *RevokeStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a RevokeStatement.
func (*RevokeStatement) String ¶
func (s *RevokeStatement) String() string
String returns a string representation of the revoke statement.
type Rewriter ¶
Rewriter can be called by Rewrite to replace nodes in the AST hierarchy. The Rewrite() function is called once per node.
type Scanner ¶
type Scanner struct {
// contains filtered or unexported fields
}
Scanner represents a lexical scanner for InfluxQL.
func NewScanner ¶
NewScanner returns a new instance of Scanner.
type SelectOptions ¶ added in v0.11.0
type SelectOptions struct { // The lower bound for a select call. MinTime time.Time // The upper bound for a select call. MaxTime time.Time }
SelectOptions are options that customize the select call.
type SelectStatement ¶
type SelectStatement struct { // Expressions returned from the selection. Fields Fields // Target (destination) for the result of the select. Target *Target // Expressions used for grouping the selection. Dimensions Dimensions // Data sources that fields are extracted from. Sources Sources // An expression evaluated on data point. Condition Expr // Fields to sort results by SortFields SortFields // Maximum number of rows to be returned. Unlimited if zero. Limit int // Returns rows starting at an offset from the first row. Offset int // Maxiumum number of series to be returned. Unlimited if zero. SLimit int // Returns series starting at an offset from the first one. SOffset int // if it's a query for raw data values (i.e. not an aggregate) IsRawQuery bool // What fill option the select statement uses, if any Fill FillOption // The value to fill empty aggregate buckets with, if any FillValue interface{} // Removes the "time" column from the output. OmitTime bool // Removes duplicate rows from raw queries. Dedupe bool // contains filtered or unexported fields }
SelectStatement represents a command for extracting data from the database.
func (*SelectStatement) Clone ¶
func (s *SelectStatement) Clone() *SelectStatement
Clone returns a deep copy of the statement.
func (*SelectStatement) ColumnNames ¶ added in v0.9.4
func (s *SelectStatement) ColumnNames() []string
ColumnNames will walk all fields and functions and return the appropriate field names for the select statement while maintaining order of the field names
func (*SelectStatement) FunctionCalls ¶
func (s *SelectStatement) FunctionCalls() []*Call
FunctionCalls returns the Call objects from the query
func (*SelectStatement) FunctionCallsByPosition ¶ added in v0.9.5
func (s *SelectStatement) FunctionCallsByPosition() [][]*Call
FunctionCallsByPosition returns the Call objects from the query in the order they appear in the select statement
func (*SelectStatement) GroupByInterval ¶
func (s *SelectStatement) GroupByInterval() (time.Duration, error)
GroupByInterval extracts the time interval, if specified.
func (*SelectStatement) HasCountDistinct ¶
func (s *SelectStatement) HasCountDistinct() bool
HasCountDistinct checks if a select statement contains COUNT and DISTINCT
func (*SelectStatement) HasDerivative ¶
func (s *SelectStatement) HasDerivative() bool
HasDerivative returns true if one of the function calls in the statement is a derivative aggregate
func (*SelectStatement) HasDimensionWildcard ¶ added in v0.9.3
func (s *SelectStatement) HasDimensionWildcard() bool
HasDimensionWildcard returns whether or not the select statement has at least 1 wildcard in the dimensions aka `GROUP BY`
func (*SelectStatement) HasDistinct ¶
func (s *SelectStatement) HasDistinct() bool
HasDistinct checks if a select statement contains DISTINCT
func (*SelectStatement) HasFieldWildcard ¶ added in v0.9.3
func (s *SelectStatement) HasFieldWildcard() bool
HasFieldWildcard returns whether or not the select statement has at least 1 wildcard in the fields
func (*SelectStatement) HasSimpleCount ¶ added in v0.9.6
func (s *SelectStatement) HasSimpleCount() bool
HasSimpleCount return true if one of the function calls is a count function with a variable ref as the first arg
func (*SelectStatement) HasTimeFieldSpecified ¶ added in v0.9.4
func (s *SelectStatement) HasTimeFieldSpecified() bool
HasTimeFieldSpecified will walk all fields and determine if the user explicitly asked for time This is needed to determine re-write behaviors for functions like TOP and BOTTOM
func (*SelectStatement) HasWildcard ¶
func (s *SelectStatement) HasWildcard() bool
HasWildcard returns whether or not the select statement has at least 1 wildcard
func (*SelectStatement) IsSimpleDerivative ¶
func (s *SelectStatement) IsSimpleDerivative() bool
IsSimpleDerivative return true if one of the function call is a derivative function with a variable ref as the first arg
func (*SelectStatement) NamesInDimension ¶ added in v0.9.3
func (s *SelectStatement) NamesInDimension() []string
NamesInDimension returns the field and tag names (idents) in the group by
func (*SelectStatement) NamesInSelect ¶
func (s *SelectStatement) NamesInSelect() []string
NamesInSelect returns the field and tag names (idents) in the select clause
func (*SelectStatement) NamesInWhere ¶
func (s *SelectStatement) NamesInWhere() []string
NamesInWhere returns the field and tag names (idents) referenced in the where clause
func (*SelectStatement) RequiredPrivileges ¶
func (s *SelectStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute the SelectStatement.
func (*SelectStatement) RewriteDistinct ¶
func (s *SelectStatement) RewriteDistinct()
RewriteDistinct rewrites the expression to be a call for map/reduce to work correctly This method assumes all validation has passed
func (*SelectStatement) RewriteTimeFields ¶ added in v0.11.0
func (s *SelectStatement) RewriteTimeFields()
RewriteTimeFields removes any "time" field references.
func (*SelectStatement) RewriteWildcards ¶
func (s *SelectStatement) RewriteWildcards(ic IteratorCreator) (*SelectStatement, error)
RewriteWildcards returns the re-written form of the select statement. Any wildcard query fields are replaced with the supplied fields, and any wildcard GROUP BY fields are replaced with the supplied dimensions.
func (*SelectStatement) SetTimeRange ¶
func (s *SelectStatement) SetTimeRange(start, end time.Time) error
SetTimeRange sets the start and end time of the select statement to [start, end). i.e. start inclusive, end exclusive. This is used commonly for continuous queries so the start and end are in buckets.
func (*SelectStatement) String ¶
func (s *SelectStatement) String() string
String returns a string representation of the select statement.
func (*SelectStatement) Substatement ¶
func (s *SelectStatement) Substatement(ref *VarRef) (*SelectStatement, error)
Substatement returns a single-series statement for a given variable reference.
func (*SelectStatement) TimeAscending ¶ added in v0.9.5
func (s *SelectStatement) TimeAscending() bool
TimeAscending returns true if the time field is sorted in chronological order.
type Series ¶ added in v0.11.0
Series represents a series that will be returned by the iterator.
type SeriesList ¶ added in v0.11.0
type SeriesList []Series
SeriesList is a list of series that will be returned by an iterator.
func (SeriesList) Len ¶ added in v0.11.0
func (a SeriesList) Len() int
func (SeriesList) Less ¶ added in v0.11.0
func (a SeriesList) Less(i, j int) bool
func (SeriesList) MarshalBinary ¶ added in v0.11.0
func (a SeriesList) MarshalBinary() ([]byte, error)
MarshalBinary encodes list into a binary format.
func (SeriesList) Swap ¶ added in v0.11.0
func (a SeriesList) Swap(i, j int)
func (*SeriesList) UnmarshalBinary ¶ added in v0.11.0
func (a *SeriesList) UnmarshalBinary(buf []byte) error
UnmarshalBinary decodes from a binary format.
type SetPasswordUserStatement ¶
type SetPasswordUserStatement struct { // Plain Password Password string // Who to grant the privilege to. Name string }
SetPasswordUserStatement represents a command for changing user password.
func (*SetPasswordUserStatement) RequiredPrivileges ¶
func (s *SetPasswordUserStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a SetPasswordUserStatement.
func (*SetPasswordUserStatement) String ¶
func (s *SetPasswordUserStatement) String() string
String returns a string representation of the set password statement.
type ShowContinuousQueriesStatement ¶
type ShowContinuousQueriesStatement struct{}
ShowContinuousQueriesStatement represents a command for listing continuous queries.
func (*ShowContinuousQueriesStatement) RequiredPrivileges ¶
func (s *ShowContinuousQueriesStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a ShowContinuousQueriesStatement.
func (*ShowContinuousQueriesStatement) String ¶
func (s *ShowContinuousQueriesStatement) String() string
String returns a string representation of the list continuous queries statement.
type ShowDatabasesStatement ¶
type ShowDatabasesStatement struct{}
ShowDatabasesStatement represents a command for listing all databases in the cluster.
func (*ShowDatabasesStatement) RequiredPrivileges ¶
func (s *ShowDatabasesStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a ShowDatabasesStatement
func (*ShowDatabasesStatement) String ¶
func (s *ShowDatabasesStatement) String() string
String returns a string representation of the list databases command.
type ShowDiagnosticsStatement ¶
type ShowDiagnosticsStatement struct { // Module Module string }
ShowDiagnosticsStatement represents a command for show node diagnostics.
func (*ShowDiagnosticsStatement) RequiredPrivileges ¶
func (s *ShowDiagnosticsStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a ShowDiagnosticsStatement
func (*ShowDiagnosticsStatement) String ¶
func (s *ShowDiagnosticsStatement) String() string
String returns a string representation of the ShowDiagnosticsStatement.
type ShowFieldKeysStatement ¶
type ShowFieldKeysStatement struct { // Data sources that fields are extracted from. Sources Sources // Fields to sort results by SortFields SortFields // Maximum number of rows to be returned. // Unlimited if zero. Limit int // Returns rows starting at an offset from the first row. Offset int }
ShowFieldKeysStatement represents a command for listing field keys.
func (*ShowFieldKeysStatement) RequiredPrivileges ¶
func (s *ShowFieldKeysStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a ShowFieldKeysStatement
func (*ShowFieldKeysStatement) String ¶
func (s *ShowFieldKeysStatement) String() string
String returns a string representation of the statement.
type ShowGrantsForUserStatement ¶ added in v0.9.1
type ShowGrantsForUserStatement struct { // Name of the user to display privileges. Name string }
ShowGrantsForUserStatement represents a command for listing user privileges.
func (*ShowGrantsForUserStatement) RequiredPrivileges ¶ added in v0.9.1
func (s *ShowGrantsForUserStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a ShowGrantsForUserStatement
func (*ShowGrantsForUserStatement) String ¶ added in v0.9.1
func (s *ShowGrantsForUserStatement) String() string
String returns a string representation of the show grants for user.
type ShowMeasurementsStatement ¶
type ShowMeasurementsStatement struct { // Measurement name or regex. Source Source // An expression evaluated on data point. Condition Expr // Fields to sort results by SortFields SortFields // Maximum number of rows to be returned. // Unlimited if zero. Limit int // Returns rows starting at an offset from the first row. Offset int }
ShowMeasurementsStatement represents a command for listing measurements.
func (*ShowMeasurementsStatement) RequiredPrivileges ¶
func (s *ShowMeasurementsStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a ShowMeasurementsStatement
func (*ShowMeasurementsStatement) String ¶
func (s *ShowMeasurementsStatement) String() string
String returns a string representation of the statement.
type ShowRetentionPoliciesStatement ¶
type ShowRetentionPoliciesStatement struct { // Name of the database to list policies for. Database string }
ShowRetentionPoliciesStatement represents a command for listing retention policies.
func (*ShowRetentionPoliciesStatement) RequiredPrivileges ¶
func (s *ShowRetentionPoliciesStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a ShowRetentionPoliciesStatement
func (*ShowRetentionPoliciesStatement) String ¶
func (s *ShowRetentionPoliciesStatement) String() string
String returns a string representation of a ShowRetentionPoliciesStatement.
type ShowSeriesStatement ¶
type ShowSeriesStatement struct { // Measurement(s) the series are listed for. Sources Sources // An expression evaluated on a series name or tag. Condition Expr // Fields to sort results by SortFields SortFields // Maximum number of rows to be returned. // Unlimited if zero. Limit int // Returns rows starting at an offset from the first row. Offset int }
ShowSeriesStatement represents a command for listing series in the database.
func (*ShowSeriesStatement) RequiredPrivileges ¶
func (s *ShowSeriesStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a ShowSeriesStatement.
func (*ShowSeriesStatement) String ¶
func (s *ShowSeriesStatement) String() string
String returns a string representation of the list series statement.
type ShowServersStatement ¶
type ShowServersStatement struct{}
ShowServersStatement represents a command for listing all servers.
func (*ShowServersStatement) RequiredPrivileges ¶
func (s *ShowServersStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a ShowServersStatement
func (*ShowServersStatement) String ¶
func (s *ShowServersStatement) String() string
String returns a string representation of the show servers command.
type ShowShardGroupsStatement ¶ added in v0.9.6
type ShowShardGroupsStatement struct{}
ShowShardGroupsStatement represents a command for displaying shard groups in the cluster.
func (*ShowShardGroupsStatement) RequiredPrivileges ¶ added in v0.9.6
func (s *ShowShardGroupsStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privileges required to execute the statement.
func (*ShowShardGroupsStatement) String ¶ added in v0.9.6
func (s *ShowShardGroupsStatement) String() string
String returns a string representation of the SHOW SHARD GROUPS command.
type ShowShardsStatement ¶ added in v0.9.4
type ShowShardsStatement struct{}
ShowShardsStatement represents a command for displaying shards in the cluster.
func (*ShowShardsStatement) RequiredPrivileges ¶ added in v0.9.4
func (s *ShowShardsStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privileges required to execute the statement.
func (*ShowShardsStatement) String ¶ added in v0.9.4
func (s *ShowShardsStatement) String() string
String returns a string representation.
type ShowStatsStatement ¶
type ShowStatsStatement struct { // Module Module string }
ShowStatsStatement displays statistics for a given module.
func (*ShowStatsStatement) RequiredPrivileges ¶
func (s *ShowStatsStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a ShowStatsStatement
func (*ShowStatsStatement) String ¶
func (s *ShowStatsStatement) String() string
String returns a string representation of a ShowStatsStatement.
type ShowSubscriptionsStatement ¶ added in v0.9.5
type ShowSubscriptionsStatement struct { }
ShowSubscriptionsStatement represents a command to show a list of subscriptions.
func (*ShowSubscriptionsStatement) RequiredPrivileges ¶ added in v0.9.5
func (s *ShowSubscriptionsStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege required to execute a ShowSubscriptionStatement
func (*ShowSubscriptionsStatement) String ¶ added in v0.9.5
func (s *ShowSubscriptionsStatement) String() string
String returns a string representation of the ShowSubscriptionStatement.
type ShowTagKeysStatement ¶
type ShowTagKeysStatement struct { // Data sources that fields are extracted from. Sources Sources // An expression evaluated on data point. Condition Expr // Fields to sort results by SortFields SortFields // Maximum number of tag keys per measurement. Unlimited if zero. Limit int // Returns tag keys starting at an offset from the first row. Offset int // Maxiumum number of series to be returned. Unlimited if zero. SLimit int // Returns series starting at an offset from the first one. SOffset int }
ShowTagKeysStatement represents a command for listing tag keys.
func (*ShowTagKeysStatement) RequiredPrivileges ¶
func (s *ShowTagKeysStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a ShowTagKeysStatement
func (*ShowTagKeysStatement) String ¶
func (s *ShowTagKeysStatement) String() string
String returns a string representation of the statement.
type ShowTagValuesStatement ¶
type ShowTagValuesStatement struct { // Data source that fields are extracted from. Sources Sources // Tag key(s) to pull values from. TagKeys []string // An expression evaluated on data point. Condition Expr // Fields to sort results by SortFields SortFields // Maximum number of rows to be returned. // Unlimited if zero. Limit int // Returns rows starting at an offset from the first row. Offset int }
ShowTagValuesStatement represents a command for listing tag values.
func (*ShowTagValuesStatement) RequiredPrivileges ¶
func (s *ShowTagValuesStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a ShowTagValuesStatement
func (*ShowTagValuesStatement) String ¶
func (s *ShowTagValuesStatement) String() string
String returns a string representation of the statement.
type ShowUsersStatement ¶
type ShowUsersStatement struct{}
ShowUsersStatement represents a command for listing users.
func (*ShowUsersStatement) RequiredPrivileges ¶
func (s *ShowUsersStatement) RequiredPrivileges() ExecutionPrivileges
RequiredPrivileges returns the privilege(s) required to execute a ShowUsersStatement
func (*ShowUsersStatement) String ¶
func (s *ShowUsersStatement) String() string
String returns a string representation of the ShowUsersStatement.
type SortFields ¶
type SortFields []*SortField
SortFields represents an ordered list of ORDER BY fields
func (SortFields) String ¶
func (a SortFields) String() string
String returns a string representation of sort fields
type Source ¶
type Source interface { Node // contains filtered or unexported methods }
Source represents a source of data for a statement.
type Sources ¶
type Sources []Source
Sources represents a list of sources.
func (Sources) HasSystemSource ¶ added in v0.11.0
HasSystemSource returns true if any of the sources are internal, system sources.
func (Sources) MarshalBinary ¶ added in v0.11.0
MarshalBinary encodes a list of sources to a binary format.
func (*Sources) UnmarshalBinary ¶ added in v0.11.0
UnmarshalBinary decodes binary data into a list of sources.
type Statement ¶
type Statement interface { Node RequiredPrivileges() ExecutionPrivileges // contains filtered or unexported methods }
Statement represents a single command in InfluxQL.
func MustParseStatement ¶
MustParseStatement parses a statement string and returns its AST. Panic on error.
func ParseStatement ¶
ParseStatement parses a statement string and returns its AST representation.
func RewriteStatement ¶ added in v0.11.0
RewriteStatement rewrites stmt into a new statement, if applicable.
type Statements ¶
type Statements []Statement
Statements represents a list of statements.
func (Statements) String ¶
func (a Statements) String() string
String returns a string representation of the statements.
type StringBulkPointAggregator ¶ added in v0.11.0
type StringBulkPointAggregator interface {
AggregateStringBulk(points []StringPoint)
}
StringBulkPointAggregator aggregates multiple points at a time.
type StringFuncBooleanReducer ¶ added in v0.11.0
type StringFuncBooleanReducer struct {
// contains filtered or unexported fields
}
func NewStringFuncBooleanReducer ¶ added in v0.11.0
func NewStringFuncBooleanReducer(fn StringReduceBooleanFunc) *StringFuncBooleanReducer
func (*StringFuncBooleanReducer) AggregateString ¶ added in v0.11.0
func (r *StringFuncBooleanReducer) AggregateString(p *StringPoint)
func (*StringFuncBooleanReducer) Emit ¶ added in v0.11.0
func (r *StringFuncBooleanReducer) Emit() []BooleanPoint
type StringFuncFloatReducer ¶ added in v0.11.0
type StringFuncFloatReducer struct {
// contains filtered or unexported fields
}
func NewStringFuncFloatReducer ¶ added in v0.11.0
func NewStringFuncFloatReducer(fn StringReduceFloatFunc) *StringFuncFloatReducer
func (*StringFuncFloatReducer) AggregateString ¶ added in v0.11.0
func (r *StringFuncFloatReducer) AggregateString(p *StringPoint)
func (*StringFuncFloatReducer) Emit ¶ added in v0.11.0
func (r *StringFuncFloatReducer) Emit() []FloatPoint
type StringFuncIntegerReducer ¶ added in v0.11.0
type StringFuncIntegerReducer struct {
// contains filtered or unexported fields
}
func NewStringFuncIntegerReducer ¶ added in v0.11.0
func NewStringFuncIntegerReducer(fn StringReduceIntegerFunc) *StringFuncIntegerReducer
func (*StringFuncIntegerReducer) AggregateString ¶ added in v0.11.0
func (r *StringFuncIntegerReducer) AggregateString(p *StringPoint)
func (*StringFuncIntegerReducer) Emit ¶ added in v0.11.0
func (r *StringFuncIntegerReducer) Emit() []IntegerPoint
type StringFuncReducer ¶ added in v0.11.0
type StringFuncReducer struct {
// contains filtered or unexported fields
}
func NewStringFuncReducer ¶ added in v0.11.0
func NewStringFuncReducer(fn StringReduceFunc) *StringFuncReducer
func (*StringFuncReducer) AggregateString ¶ added in v0.11.0
func (r *StringFuncReducer) AggregateString(p *StringPoint)
func (*StringFuncReducer) Emit ¶ added in v0.11.0
func (r *StringFuncReducer) Emit() []StringPoint
type StringIterator ¶ added in v0.11.0
type StringIterator interface { Iterator Next() *StringPoint }
StringIterator represents a stream of string points.
type StringLiteral ¶
type StringLiteral struct {
Val string
}
StringLiteral represents a string literal.
func (*StringLiteral) String ¶
func (l *StringLiteral) String() string
String returns a string representation of the literal.
type StringPoint ¶ added in v0.11.0
type StringPoint struct { Name string Tags Tags Time int64 Nil bool Value string Aux []interface{} // Total number of points that were combined into this point from an aggregate. // If this is zero, the point is not the result of an aggregate function. Aggregated uint32 }
StringPoint represents a point with a string value. DO NOT ADD ADDITIONAL FIELDS TO THIS STRUCT. See TestPoint_Fields in influxql/point_test.go for more details.
func StringDistinctReduceSlice ¶ added in v0.11.0
func StringDistinctReduceSlice(a []StringPoint) []StringPoint
StringDistinctReduceSlice returns the distinct value within a window.
func StringStddevReduceSlice ¶ added in v0.11.0
func StringStddevReduceSlice(a []StringPoint) []StringPoint
StringStddevReduceSlice always returns "".
func (*StringPoint) Clone ¶ added in v0.11.0
func (v *StringPoint) Clone() *StringPoint
Clone returns a copy of v.
type StringPointAggregator ¶ added in v0.11.0
type StringPointAggregator interface {
AggregateString(p *StringPoint)
}
StringPointAggregator aggregates points to produce a single point.
type StringPointDecoder ¶ added in v0.11.0
type StringPointDecoder struct {
// contains filtered or unexported fields
}
NewStringPointDecoder decodes StringPoint points from a reader.
func NewStringPointDecoder ¶ added in v0.11.0
func NewStringPointDecoder(r io.Reader) *StringPointDecoder
NewStringPointDecoder returns a new instance of StringPointDecoder that reads from r.
func (*StringPointDecoder) DecodeStringPoint ¶ added in v0.11.0
func (dec *StringPointDecoder) DecodeStringPoint(p *StringPoint) error
DecodeStringPoint reads from the underlying reader and unmarshals into p.
type StringPointEmitter ¶ added in v0.11.0
type StringPointEmitter interface {
Emit() []StringPoint
}
StringPointEmitter produces a single point from an aggregate.
type StringPointEncoder ¶ added in v0.11.0
type StringPointEncoder struct {
// contains filtered or unexported fields
}
NewStringPointEncoder encodes StringPoint points to a writer.
func NewStringPointEncoder ¶ added in v0.11.0
func NewStringPointEncoder(w io.Writer) *StringPointEncoder
NewStringPointEncoder returns a new instance of StringPointEncoder that writes to w.
func (*StringPointEncoder) EncodeStringPoint ¶ added in v0.11.0
func (enc *StringPointEncoder) EncodeStringPoint(p *StringPoint) error
EncodeStringPoint marshals and writes p to the underlying writer.
type StringReduceBooleanFunc ¶ added in v0.11.0
type StringReduceBooleanFunc func(prev *BooleanPoint, curr *StringPoint) (t int64, v bool, aux []interface{})
StringReduceBooleanFunc is the function called by a StringPoint reducer.
type StringReduceBooleanSliceFunc ¶ added in v0.11.0
type StringReduceBooleanSliceFunc func(a []StringPoint) []BooleanPoint
StringReduceBooleanSliceFunc is the function called by a StringPoint reducer.
type StringReduceFloatFunc ¶ added in v0.11.0
type StringReduceFloatFunc func(prev *FloatPoint, curr *StringPoint) (t int64, v float64, aux []interface{})
StringReduceFloatFunc is the function called by a StringPoint reducer.
type StringReduceFloatSliceFunc ¶ added in v0.11.0
type StringReduceFloatSliceFunc func(a []StringPoint) []FloatPoint
StringReduceFloatSliceFunc is the function called by a StringPoint reducer.
type StringReduceFunc ¶ added in v0.11.0
type StringReduceFunc func(prev *StringPoint, curr *StringPoint) (t int64, v string, aux []interface{})
StringReduceFunc is the function called by a StringPoint reducer.
type StringReduceIntegerFunc ¶ added in v0.11.0
type StringReduceIntegerFunc func(prev *IntegerPoint, curr *StringPoint) (t int64, v int64, aux []interface{})
StringReduceIntegerFunc is the function called by a StringPoint reducer.
type StringReduceIntegerSliceFunc ¶ added in v0.11.0
type StringReduceIntegerSliceFunc func(a []StringPoint) []IntegerPoint
StringReduceIntegerSliceFunc is the function called by a StringPoint reducer.
type StringReduceSliceFunc ¶ added in v0.11.0
type StringReduceSliceFunc func(a []StringPoint) []StringPoint
StringReduceSliceFunc is the function called by a StringPoint reducer.
type StringSliceFuncBooleanReducer ¶ added in v0.11.0
type StringSliceFuncBooleanReducer struct {
// contains filtered or unexported fields
}
func NewStringSliceFuncBooleanReducer ¶ added in v0.11.0
func NewStringSliceFuncBooleanReducer(fn StringReduceBooleanSliceFunc) *StringSliceFuncBooleanReducer
func (*StringSliceFuncBooleanReducer) AggregateString ¶ added in v0.11.0
func (r *StringSliceFuncBooleanReducer) AggregateString(p *StringPoint)
func (*StringSliceFuncBooleanReducer) AggregateStringBulk ¶ added in v0.11.0
func (r *StringSliceFuncBooleanReducer) AggregateStringBulk(points []StringPoint)
func (*StringSliceFuncBooleanReducer) Emit ¶ added in v0.11.0
func (r *StringSliceFuncBooleanReducer) Emit() []BooleanPoint
type StringSliceFuncFloatReducer ¶ added in v0.11.0
type StringSliceFuncFloatReducer struct {
// contains filtered or unexported fields
}
func NewStringSliceFuncFloatReducer ¶ added in v0.11.0
func NewStringSliceFuncFloatReducer(fn StringReduceFloatSliceFunc) *StringSliceFuncFloatReducer
func (*StringSliceFuncFloatReducer) AggregateString ¶ added in v0.11.0
func (r *StringSliceFuncFloatReducer) AggregateString(p *StringPoint)
func (*StringSliceFuncFloatReducer) AggregateStringBulk ¶ added in v0.11.0
func (r *StringSliceFuncFloatReducer) AggregateStringBulk(points []StringPoint)
func (*StringSliceFuncFloatReducer) Emit ¶ added in v0.11.0
func (r *StringSliceFuncFloatReducer) Emit() []FloatPoint
type StringSliceFuncIntegerReducer ¶ added in v0.11.0
type StringSliceFuncIntegerReducer struct {
// contains filtered or unexported fields
}
func NewStringSliceFuncIntegerReducer ¶ added in v0.11.0
func NewStringSliceFuncIntegerReducer(fn StringReduceIntegerSliceFunc) *StringSliceFuncIntegerReducer
func (*StringSliceFuncIntegerReducer) AggregateString ¶ added in v0.11.0
func (r *StringSliceFuncIntegerReducer) AggregateString(p *StringPoint)
func (*StringSliceFuncIntegerReducer) AggregateStringBulk ¶ added in v0.11.0
func (r *StringSliceFuncIntegerReducer) AggregateStringBulk(points []StringPoint)
func (*StringSliceFuncIntegerReducer) Emit ¶ added in v0.11.0
func (r *StringSliceFuncIntegerReducer) Emit() []IntegerPoint
type StringSliceFuncReducer ¶ added in v0.11.0
type StringSliceFuncReducer struct {
// contains filtered or unexported fields
}
func NewStringSliceFuncReducer ¶ added in v0.11.0
func NewStringSliceFuncReducer(fn StringReduceSliceFunc) *StringSliceFuncReducer
func (*StringSliceFuncReducer) AggregateString ¶ added in v0.11.0
func (r *StringSliceFuncReducer) AggregateString(p *StringPoint)
func (*StringSliceFuncReducer) AggregateStringBulk ¶ added in v0.11.0
func (r *StringSliceFuncReducer) AggregateStringBulk(points []StringPoint)
func (*StringSliceFuncReducer) Emit ¶ added in v0.11.0
func (r *StringSliceFuncReducer) Emit() []StringPoint
type TagSet ¶
TagSet is a fundamental concept within the query system. It represents a composite series, composed of multiple individual series that share a set of tag attributes.
func LimitTagSets ¶ added in v0.11.0
LimitTagSets returns a tag set list with SLIMIT and SOFFSET applied.
type Tags ¶ added in v0.11.0
type Tags struct {
// contains filtered or unexported fields
}
Tags represent a map of keys and values. It memoizes its key so it can be used efficiently during query execution.
type Target ¶
type Target struct { // Measurement to write into. Measurement *Measurement }
Target represents a target (destination) policy, measurement, and DB.
type TimeLiteral ¶
TimeLiteral represents a point-in-time literal.
func (*TimeLiteral) String ¶
func (l *TimeLiteral) String() string
String returns a string representation of the literal.
type Token ¶
type Token int
Token is a lexical token of the InfluxQL language.
const ( // ILLEGAL Token, EOF, WS are Special InfluxQL tokens. ILLEGAL Token = iota EOF WS // IDENT and the following are InfluxQL literal tokens. IDENT // main NUMBER // 12345.67 DURATIONVAL // 13h STRING // "abc" BADSTRING // "abc BADESCAPE // \q TRUE // true FALSE // false REGEX // Regular expressions BADREGEX // `.* // ADD and the following are InfluxQL Operators ADD // + SUB // - MUL // * DIV // / AND // AND OR // OR EQ // = NEQ // != EQREGEX // =~ NEQREGEX // !~ LT // < LTE // <= GT // > GTE // >= LPAREN // ( RPAREN // ) COMMA // , COLON // : SEMICOLON // ; DOT // . // ALL and the following are InfluxQL Keywords ALL ALTER ANY AS ASC BEGIN BY CREATE CONTINUOUS DATA DATABASE DATABASES DEFAULT DELETE DESC DESTINATIONS DIAGNOSTICS DISTINCT DROP DURATION END EVERY EXISTS EXPLAIN FIELD FOR FORCE FROM GRANT GRANTS GROUP GROUPS IF IN INF INNER INSERT INTO KEY KEYS LIMIT META MEASUREMENT MEASUREMENTS NAME NOT OFFSET ON ORDER PASSWORD POLICY POLICIES PRIVILEGES QUERIES QUERY READ REPLICATION RESAMPLE RETENTION REVOKE SELECT SERIES SERVER SERVERS SET SHOW SHARD SHARDS SLIMIT SOFFSET STATS SUBSCRIPTION SUBSCRIPTIONS TAG TO USER USERS VALUES WHERE WITH WRITE )
These are a comprehensive list of InfluxQL language tokens.
func (Token) Precedence ¶
Precedence returns the operator precedence of the binary operator token.
type Valuer ¶
Valuer is the interface that wraps the Value() method.
Value returns the value and existence flag for a given key.