 Documentation
      ¶
      Documentation
      ¶
    
    
  
    
  
    Index ¶
- func EstimatedJSONRowLen(fields []Field) int
- func MarshalFieldsToJSON(dst []byte, fields []Field) []byte
- func MarshalFieldsToLogfmt(dst []byte, fields []Field) []byte
- func PutJSONParser(p *JSONParser)
- func PutLogRows(lr *LogRows)
- func PutStreamTags(st *StreamTags)
- func PutSyslogParser(p *SyslogParser)
- func RenameField(fields []Field, oldNames []string, newName string)
- func TryParseTimestampRFC3339Nano(s string) (int64, bool)
- type BlockColumn
- type DatadbStats
- type Field
- type Filter
- type IndexdbStats
- type JSONParser
- type LogRows
- func (lr *LogRows) GetRowString(idx int) string
- func (lr *LogRows) Len() int
- func (lr *LogRows) Less(i, j int) bool
- func (lr *LogRows) MustAdd(tenantID TenantID, timestamp int64, fields, streamFields []Field)
- func (lr *LogRows) NeedFlush() bool
- func (lr *LogRows) Reset()
- func (lr *LogRows) ResetKeepSettings()
- func (lr *LogRows) Swap(i, j int)
 
- type PartitionStats
- type Query
- func (q *Query) AddCountByTimePipe(step, off int64, fields []string)
- func (q *Query) AddExtraFilters(extraFilters *Filter)
- func (q *Query) AddFacetsPipe(limit, maxValuesPerField, maxValueLen int, keepConstFields bool)
- func (q *Query) AddPipeLimit(n uint64)
- func (q *Query) AddTimeFilter(start, end int64)
- func (q *Query) CanLiveTail() bool
- func (q *Query) CanReturnLastNResults() bool
- func (q *Query) Clone(timestamp int64) *Query
- func (q *Query) CloneWithTimeFilter(timestamp, start, end int64) *Query
- func (q *Query) DropAllPipes()
- func (q *Query) GetFilterTimeRange() (int64, int64)
- func (q *Query) GetStatsByFields() ([]string, error)
- func (q *Query) GetStatsByFieldsAddGroupingByTime(step int64) ([]string, error)
- func (q *Query) GetTimestamp() int64
- func (q *Query) HasGlobalTimeFilter() bool
- func (q *Query) String() string
 
- type Storage
- func (s *Storage) GetFieldNames(ctx context.Context, tenantIDs []TenantID, q *Query) ([]ValueWithHits, error)
- func (s *Storage) GetFieldValues(ctx context.Context, tenantIDs []TenantID, q *Query, fieldName string, ...) ([]ValueWithHits, error)
- func (s *Storage) GetStreamFieldNames(ctx context.Context, tenantIDs []TenantID, q *Query) ([]ValueWithHits, error)
- func (s *Storage) GetStreamFieldValues(ctx context.Context, tenantIDs []TenantID, q *Query, fieldName string, ...) ([]ValueWithHits, error)
- func (s *Storage) GetStreamIDs(ctx context.Context, tenantIDs []TenantID, q *Query, limit uint64) ([]ValueWithHits, error)
- func (s *Storage) GetStreams(ctx context.Context, tenantIDs []TenantID, q *Query, limit uint64) ([]ValueWithHits, error)
- func (s *Storage) IsReadOnly() bool
- func (s *Storage) MustAddRows(lr *LogRows)
- func (s *Storage) MustClose()
- func (s *Storage) MustForceMerge(partitionNamePrefix string)
- func (s *Storage) RunQuery(ctx context.Context, tenantIDs []TenantID, q *Query, writeBlock WriteBlockFunc) error
- func (s *Storage) UpdateStats(ss *StorageStats)
 
- type StorageConfig
- type StorageStats
- type StreamFilter
- type StreamTags
- func (st *StreamTags) Add(name, value string)
- func (st *StreamTags) Len() int
- func (st *StreamTags) Less(i, j int) bool
- func (st *StreamTags) MarshalCanonical(dst []byte) []byte
- func (st *StreamTags) Reset()
- func (st *StreamTags) String() string
- func (st *StreamTags) Swap(i, j int)
- func (st *StreamTags) UnmarshalCanonical(src []byte) ([]byte, error)
 
- type SyslogParser
- type TenantID
- type TimeFormatter
- type ValueWithHits
- type WriteBlockFunc
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
func EstimatedJSONRowLen ¶ added in v1.97.14
EstimatedJSONRowLen returns an approximate length of the log entry with the given fields if represented as JSON.
func MarshalFieldsToJSON ¶ added in v1.97.7
MarshalFieldsToJSON appends JSON-marshaled fields to dst and returns the result.
func MarshalFieldsToLogfmt ¶ added in v1.97.7
MarshalFieldsToLogfmt appends logfmt-marshaled fields to dst and returns the result.
func PutJSONParser ¶ added in v1.97.7
func PutJSONParser(p *JSONParser)
PutJSONParser returns the parser to the pool.
The parser cannot be used after returning to the pool.
func PutSyslogParser ¶ added in v1.97.7
func PutSyslogParser(p *SyslogParser)
PutSyslogParser returns back syslog parser to the pool.
p cannot be used after returning to the pool.
func RenameField ¶ added in v1.97.7
RenameField renames the first non-empty field with the name from oldNames list to newName in Fields
func TryParseTimestampRFC3339Nano ¶ added in v1.97.7
TryParseTimestampRFC3339Nano parses s as RFC3339 with optional nanoseconds part and timezone offset and returns unix timestamp in nanoseconds.
If s doesn't contain timezone offset, then the local timezone is used.
The returned timestamp can be negative if s is smaller than 1970 year.
Types ¶
type BlockColumn ¶
type BlockColumn struct {
	// Name is the column name
	Name string
	// Values is column values
	Values []string
}
    BlockColumn is a single column of a block of data
type DatadbStats ¶
type DatadbStats struct {
	// InmemoryMergesTotal is the number of inmemory merges performed in the given datadb.
	InmemoryMergesTotal uint64
	// InmemoryActiveMerges is the number of currently active inmemory merges performed by the given datadb.
	InmemoryActiveMerges uint64
	// SmallPartMergesTotal is the number of small file merges performed in the given datadb.
	SmallPartMergesTotal uint64
	// SmallPartActiveMerges is the number of currently active small file merges performed by the given datadb.
	SmallPartActiveMerges uint64
	// BigPartMergesTotal is the number of big file merges performed in the given datadb.
	BigPartMergesTotal uint64
	// BigPartActiveMerges is the number of currently active big file merges performed by the given datadb.
	BigPartActiveMerges uint64
	// InmemoryRowsCount is the number of rows, which weren't flushed to disk yet.
	InmemoryRowsCount uint64
	// SmallPartRowsCount is the number of rows stored on disk in small parts.
	SmallPartRowsCount uint64
	// BigPartRowsCount is the number of rows stored on disk in big parts.
	BigPartRowsCount uint64
	// InmemoryParts is the number of in-memory parts, which weren't flushed to disk yet.
	InmemoryParts uint64
	// SmallParts is the number of file-based small parts stored on disk.
	SmallParts uint64
	// BigParts is the number of file-based big parts stored on disk.
	BigParts uint64
	// InmemoryBlocks is the number of in-memory blocks, which weren't flushed to disk yet.
	InmemoryBlocks uint64
	// SmallPartBlocks is the number of file-based small blocks stored on disk.
	SmallPartBlocks uint64
	// BigPartBlocks is the number of file-based big blocks stored on disk.
	BigPartBlocks uint64
	// CompressedInmemorySize is the size of compressed data stored in memory.
	CompressedInmemorySize uint64
	// CompressedSmallPartSize is the size of compressed small parts data stored on disk.
	CompressedSmallPartSize uint64
	// CompressedBigPartSize is the size of compressed big data stored on disk.
	CompressedBigPartSize uint64
	// UncompressedInmemorySize is the size of uncompressed data stored in memory.
	UncompressedInmemorySize uint64
	// UncompressedSmallPartSize is the size of uncompressed small data stored on disk.
	UncompressedSmallPartSize uint64
	// UncompressedBigPartSize is the size of uncompressed big data stored on disk.
	UncompressedBigPartSize uint64
}
    DatadbStats contains various stats for datadb.
func (*DatadbStats) RowsCount ¶
func (s *DatadbStats) RowsCount() uint64
RowsCount returns the number of rows stored in datadb.
type Field ¶
type Field struct {
	// Name is the name of the field
	Name string
	// Value is the value of the field
	Value string
}
    Field is a single field for the log entry.
func SkipLeadingFieldsWithoutValues ¶ added in v1.97.10
SkipLeadingFieldsWithoutValues skips leading fields without values.
type Filter ¶ added in v1.97.15
type Filter struct {
	// contains filtered or unexported fields
}
    Filter represents LogsQL filter
See https://docs.victoriametrics.com/victorialogs/logsql/#filters
func ParseFilter ¶ added in v1.97.15
ParseFilter parses LogsQL filter
See https://docs.victoriametrics.com/victorialogs/logsql/#filters
type IndexdbStats ¶
type IndexdbStats struct {
	// StreamsCreatedTotal is the number of log streams created since the indexdb initialization.
	StreamsCreatedTotal uint64
	// IndexdbSizeBytes is the size of data in indexdb.
	IndexdbSizeBytes uint64
	// IndexdbItemsCount is the number of items in indexdb.
	IndexdbItemsCount uint64
	// IndexdbBlocksCount is the number of blocks in indexdb.
	IndexdbBlocksCount uint64
	// IndexdbPartsCount is the number of parts in indexdb.
	IndexdbPartsCount uint64
}
    IndexdbStats contains indexdb stats
type JSONParser ¶ added in v1.97.7
type JSONParser struct {
	// Fields contains the parsed JSON line after Parse() call
	//
	// The Fields are valid until the next call to ParseLogMessage()
	// or until the parser is returned to the pool with PutParser() call.
	Fields []Field
	// contains filtered or unexported fields
}
    JSONParser parses a single JSON log message into Fields.
See https://docs.victoriametrics.com/victorialogs/keyconcepts/#data-model
Use GetParser() for obtaining the parser.
func GetJSONParser ¶ added in v1.97.7
func GetJSONParser() *JSONParser
GetJSONParser returns JSONParser ready to parse JSON lines.
Return the parser to the pool when it is no longer needed by calling PutJSONParser().
func (*JSONParser) ParseLogMessage ¶ added in v1.97.7
func (p *JSONParser) ParseLogMessage(msg []byte) error
ParseLogMessage parses the given JSON log message msg into p.Fields.
The p.Fields remains valid until the next call to ParseLogMessage() or PutJSONParser().
type LogRows ¶
type LogRows struct {
	// contains filtered or unexported fields
}
    LogRows holds a set of rows needed for Storage.MustAddRows
LogRows must be obtained via GetLogRows()
func GetLogRows ¶
func GetLogRows(streamFields, ignoreFields []string, extraFields []Field, defaultMsgValue string) *LogRows
GetLogRows returns LogRows from the pool for the given streamFields.
streamFields is a set of field names, which must be associated with the stream. ignoreFields is a set of field names, which must be ignored during data ingestion. extraFields is a set of fields, which must be added to all the logs passed to MustAdd(). defaultMsgValue is the default value to store in non-existing or empty _msg.
Return back it to the pool with PutLogRows() when it is no longer needed.
func (*LogRows) GetRowString ¶
GetRowString returns string representation of the row with the given idx.
func (*LogRows) Less ¶
Less returns true if (streamID, timestamp) for row i is smaller than the (streamID, timestamp) for row j
func (*LogRows) MustAdd ¶
MustAdd adds a log entry with the given args to lr.
If streamFields is non-nil, the the given streamFields are used as log stream fields instead of the pre-configured stream fields from GetLogRows().
It is OK to modify the args after returning from the function, since lr copies all the args to internal data.
Log entries are dropped with the warning message in the following cases: - if there are too many log fields - if there are too long log field names - if the total length of log entries is too long
func (*LogRows) NeedFlush ¶
NeedFlush returns true if lr contains too much data, so it must be flushed to the storage.
func (*LogRows) Reset ¶
func (lr *LogRows) Reset()
Reset resets lr with all its settings.
Call ResetKeepSettings() for resetting lr without resetting its settings.
func (*LogRows) ResetKeepSettings ¶
func (lr *LogRows) ResetKeepSettings()
ResetKeepSettings resets rows stored in lr, while keeping its settings passed to GetLogRows().
type PartitionStats ¶
type PartitionStats struct {
	DatadbStats
	IndexdbStats
}
    PartitionStats contains stats for the partition.
type Query ¶
type Query struct {
	// contains filtered or unexported fields
}
    Query represents LogsQL query.
func ParseQueryAtTimestamp ¶ added in v1.97.8
ParseQueryAtTimestamp parses s in the context of the given timestamp.
E.g. _time:duration filters are adjusted according to the provided timestamp as _time:[timestamp-duration, duration].
func ParseStatsQuery ¶ added in v1.97.10
ParseStatsQuery parses LogsQL query s at the given timestamp with the needed stats query checks.
func (*Query) AddCountByTimePipe ¶ added in v1.97.7
AddCountByTimePipe adds '| stats by (_time:step offset off, field1, ..., fieldN) count() hits' to the end of q.
func (*Query) AddExtraFilters ¶ added in v1.97.11
AddExtraFilters adds extraFilters to q
func (*Query) AddFacetsPipe ¶ added in v1.97.14
AddFacetsPipe adds ' facets <limit> max_values_per_field <maxValuesPerField> max_value_len <maxValueLen> <keepConstFields>` to the end of q.
func (*Query) AddPipeLimit ¶ added in v1.97.7
AddPipeLimit adds `| limit n` pipe to q.
See https://docs.victoriametrics.com/victorialogs/logsql/#limit-pipe
func (*Query) AddTimeFilter ¶ added in v1.97.7
AddTimeFilter adds global filter _time:[start ... end] to q.
func (*Query) CanLiveTail ¶ added in v1.97.7
CanLiveTail returns true if q can be used in live tailing
func (*Query) CanReturnLastNResults ¶ added in v1.97.7
CanReturnLastNResults returns true if time range filter at q can be adjusted for returning the last N results.
func (*Query) CloneWithTimeFilter ¶ added in v1.97.12
CloneWithTimeFilter clones q at the given timestamp and adds _time:[start, end] filter to the cloned q.
func (*Query) DropAllPipes ¶ added in v1.97.7
func (q *Query) DropAllPipes()
DropAllPipes drops all the pipes from q.
func (*Query) GetFilterTimeRange ¶ added in v1.97.7
GetFilterTimeRange returns filter time range for the given q.
func (*Query) GetStatsByFields ¶ added in v1.97.8
GetStatsByFields returns `by (...)` fields from the last `stats` pipe at q.
func (*Query) GetStatsByFieldsAddGroupingByTime ¶ added in v1.97.8
GetStatsByFieldsAddGroupingByTime returns `by (...)` fields from the last `stats` pipe at q.
if step > 0, then _time:step is added to the last `stats by (...)` pipe at q.
func (*Query) GetTimestamp ¶ added in v1.97.8
GetTimestamp returns timestamp context for the given q, which was passed to ParseQueryAtTimestamp().
func (*Query) HasGlobalTimeFilter ¶ added in v1.97.12
HasGlobalTimeFilter returns true when query contains a global time filter.
type Storage ¶
type Storage struct {
	// contains filtered or unexported fields
}
    Storage is the storage for log entries.
func MustOpenStorage ¶
func MustOpenStorage(path string, cfg *StorageConfig) *Storage
MustOpenStorage opens Storage at the given path.
MustClose must be called on the returned Storage when it is no longer needed.
func (*Storage) GetFieldNames ¶ added in v1.97.7
func (s *Storage) GetFieldNames(ctx context.Context, tenantIDs []TenantID, q *Query) ([]ValueWithHits, error)
GetFieldNames returns field names from q results for the given tenantIDs.
func (*Storage) GetFieldValues ¶ added in v1.97.7
func (s *Storage) GetFieldValues(ctx context.Context, tenantIDs []TenantID, q *Query, fieldName string, limit uint64) ([]ValueWithHits, error)
GetFieldValues returns unique values with the number of hits for the given fieldName returned by q for the given tenantIDs.
If limit > 0, then up to limit unique values are returned.
func (*Storage) GetStreamFieldNames ¶ added in v1.97.7
func (s *Storage) GetStreamFieldNames(ctx context.Context, tenantIDs []TenantID, q *Query) ([]ValueWithHits, error)
GetStreamFieldNames returns stream field names from q results for the given tenantIDs.
func (*Storage) GetStreamFieldValues ¶ added in v1.97.7
func (s *Storage) GetStreamFieldValues(ctx context.Context, tenantIDs []TenantID, q *Query, fieldName string, limit uint64) ([]ValueWithHits, error)
GetStreamFieldValues returns stream field values for the given fieldName from q results for the given tenantIDs.
If limit > 9, then up to limit unique values are returned.
func (*Storage) GetStreamIDs ¶ added in v1.97.7
func (s *Storage) GetStreamIDs(ctx context.Context, tenantIDs []TenantID, q *Query, limit uint64) ([]ValueWithHits, error)
GetStreamIDs returns stream_id field values from q results for the given tenantIDs.
If limit > 0, then up to limit unique streams are returned.
func (*Storage) GetStreams ¶ added in v1.97.7
func (s *Storage) GetStreams(ctx context.Context, tenantIDs []TenantID, q *Query, limit uint64) ([]ValueWithHits, error)
GetStreams returns streams from q results for the given tenantIDs.
If limit > 0, then up to limit unique streams are returned.
func (*Storage) IsReadOnly ¶ added in v1.94.0
IsReadOnly returns true if s is in read-only mode.
func (*Storage) MustAddRows ¶
MustAddRows adds lr to s.
It is recommended checking whether the s is in read-only mode by calling IsReadOnly() before calling MustAddRows.
func (*Storage) MustClose ¶
func (s *Storage) MustClose()
MustClose closes s.
It is expected that nobody uses the storage at the close time.
func (*Storage) MustForceMerge ¶ added in v1.97.10
MustForceMerge force-merges parts in s partitions with names starting from the given partitionNamePrefix.
Partitions are merged sequentially in order to reduce load on the system.
func (*Storage) RunQuery ¶
func (s *Storage) RunQuery(ctx context.Context, tenantIDs []TenantID, q *Query, writeBlock WriteBlockFunc) error
RunQuery runs the given q and calls writeBlock for results.
func (*Storage) UpdateStats ¶
func (s *Storage) UpdateStats(ss *StorageStats)
UpdateStats updates ss for the given s.
type StorageConfig ¶
type StorageConfig struct {
	// Retention is the retention for the ingested data.
	//
	// Older data is automatically deleted.
	Retention time.Duration
	// MaxDiskSpaceUsageBytes is an optional maximum disk space logs can use.
	//
	// The oldest per-day partitions are automatically dropped if the total disk space usage exceeds this limit.
	MaxDiskSpaceUsageBytes int64
	// FlushInterval is the interval for flushing the in-memory data to disk at the Storage.
	FlushInterval time.Duration
	// FutureRetention is the allowed retention from the current time to future for the ingested data.
	//
	// Log entries with timestamps bigger than now+FutureRetention are ignored.
	FutureRetention time.Duration
	// MinFreeDiskSpaceBytes is the minimum free disk space at storage path after which the storage stops accepting new data
	// and enters read-only mode.
	MinFreeDiskSpaceBytes int64
	// LogNewStreams indicates whether to log newly created log streams.
	//
	// This can be useful for debugging of high cardinality issues.
	// https://docs.victoriametrics.com/victorialogs/keyconcepts/#high-cardinality
	LogNewStreams bool
	// LogIngestedRows indicates whether to log the ingested log entries.
	//
	// This can be useful for debugging of data ingestion.
	LogIngestedRows bool
}
    StorageConfig is the config for the Storage.
type StorageStats ¶
type StorageStats struct {
	// RowsDroppedTooBigTimestamp is the number of rows dropped during data ingestion because their timestamp is smaller than the minimum allowed
	RowsDroppedTooBigTimestamp uint64
	// RowsDroppedTooSmallTimestamp is the number of rows dropped during data ingestion because their timestamp is bigger than the maximum allowed
	RowsDroppedTooSmallTimestamp uint64
	// PartitionsCount is the number of partitions in the storage
	PartitionsCount uint64
	// IsReadOnly indicates whether the storage is read-only.
	IsReadOnly bool
	// PartitionStats contains partition stats.
	PartitionStats
}
    StorageStats represents stats for the storage. It may be obtained by calling Storage.UpdateStats().
type StreamFilter ¶
type StreamFilter struct {
	// contains filtered or unexported fields
}
    StreamFilter is a filter for streams, e.g. `_stream:{...}`
func (*StreamFilter) String ¶
func (sf *StreamFilter) String() string
type StreamTags ¶
type StreamTags struct {
	// contains filtered or unexported fields
}
    StreamTags contains stream tags.
func (*StreamTags) Add ¶
func (st *StreamTags) Add(name, value string)
Add adds (name:value) tag to st.
func (*StreamTags) Less ¶
func (st *StreamTags) Less(i, j int) bool
Less returns true if tag i is smaller than the tag j.
func (*StreamTags) MarshalCanonical ¶
func (st *StreamTags) MarshalCanonical(dst []byte) []byte
MarshalCanonical marshal st in a canonical way
func (*StreamTags) String ¶
func (st *StreamTags) String() string
String returns string representation of st.
func (*StreamTags) UnmarshalCanonical ¶
func (st *StreamTags) UnmarshalCanonical(src []byte) ([]byte, error)
UnmarshalCanonical unmarshals st from src marshaled with MarshalCanonical.
type SyslogParser ¶ added in v1.97.7
type SyslogParser struct {
	// Fields contains parsed fields after Parse call.
	Fields []Field
	// contains filtered or unexported fields
}
    SyslogParser is parser for syslog messages.
It understands the following syslog formats:
- https://datatracker.ietf.org/doc/html/rfc5424 - https://datatracker.ietf.org/doc/html/rfc3164
It extracts the following list of syslog message fields into Fields - https://docs.victoriametrics.com/victorialogs/logsql/#unpack_syslog-pipe
func GetSyslogParser ¶ added in v1.97.7
func GetSyslogParser(currentYear int, timezone *time.Location) *SyslogParser
GetSyslogParser returns syslog parser from the pool.
currentYear must contain the current year. It is used for properly setting timestamp field for rfc3164 format, which doesn't contain year.
the timezone is used for rfc3164 format for setting the desired timezone.
Return back the parser to the pool by calling PutSyslogParser when it is no longer needed.
func (*SyslogParser) Parse ¶ added in v1.97.7
func (p *SyslogParser) Parse(s string)
Parse parses syslog message from s into p.Fields.
p.Fields is valid until s is modified or p state is changed.
type TenantID ¶
type TenantID struct {
	// AccountID is the id of the account for the log stream.
	AccountID uint32
	// ProjectID is the id of the project for the log stream.
	ProjectID uint32
}
    TenantID is an id of a tenant for log streams.
Each log stream is associated with a single TenantID.
func GetTenantIDFromRequest ¶
GetTenantIDFromRequest returns tenantID from r.
func ParseTenantID ¶ added in v1.97.7
ParseTenantID returns tenantID from s.
s is expected in the form of accountID:projectID. If s is empty, then zero tenantID is returned.
type TimeFormatter ¶
type TimeFormatter int64
TimeFormatter implements fmt.Stringer for timestamp in nanoseconds
func (*TimeFormatter) String ¶
func (tf *TimeFormatter) String() string
String returns human-readable representation for tf.
type ValueWithHits ¶ added in v1.97.7
ValueWithHits contains value and hits.
type WriteBlockFunc ¶ added in v1.97.7
type WriteBlockFunc func(workerID uint, timestamps []int64, columns []BlockColumn)
WriteBlockFunc must write a block with the given timestamps and columns.
WriteBlockFunc cannot hold references to timestamps and columns after returning.
       Source Files
      ¶
      Source Files
      ¶
    
- arena.go
- bitmap.go
- block.go
- block_data.go
- block_header.go
- block_result.go
- block_search.go
- block_stream_merger.go
- block_stream_reader.go
- block_stream_writer.go
- bloomfilter.go
- cache.go
- chunked_allocator.go
- column_names.go
- consts.go
- datadb.go
- encoding.go
- fields_set.go
- filenames.go
- filter.go
- filter_and.go
- filter_any_case_phrase.go
- filter_any_case_prefix.go
- filter_day_range.go
- filter_exact.go
- filter_exact_prefix.go
- filter_in.go
- filter_ipv4_range.go
- filter_len_range.go
- filter_noop.go
- filter_not.go
- filter_or.go
- filter_phrase.go
- filter_prefix.go
- filter_range.go
- filter_regexp.go
- filter_sequence.go
- filter_stream.go
- filter_stream_id.go
- filter_string_range.go
- filter_time.go
- filter_value_type.go
- filter_week_range.go
- hash128.go
- hash_tokenizer.go
- hits_map.go
- if_filter.go
- index_block_header.go
- indexdb.go
- inmemory_part.go
- json_parser.go
- log_rows.go
- logfmt_parser.go
- parser.go
- part.go
- part_header.go
- partition.go
- pattern.go
- pipe.go
- pipe_block_stats.go
- pipe_blocks_count.go
- pipe_collapse_nums.go
- pipe_copy.go
- pipe_delete.go
- pipe_drop_empty_fields.go
- pipe_extract.go
- pipe_extract_regexp.go
- pipe_facets.go
- pipe_field_names.go
- pipe_field_values.go
- pipe_fields.go
- pipe_filter.go
- pipe_first.go
- pipe_format.go
- pipe_hash.go
- pipe_join.go
- pipe_last.go
- pipe_len.go
- pipe_limit.go
- pipe_math.go
- pipe_offset.go
- pipe_pack.go
- pipe_pack_json.go
- pipe_pack_logfmt.go
- pipe_rename.go
- pipe_replace.go
- pipe_replace_regexp.go
- pipe_sort.go
- pipe_sort_topk.go
- pipe_stats.go
- pipe_stream_context.go
- pipe_top.go
- pipe_union.go
- pipe_uniq.go
- pipe_unpack.go
- pipe_unpack_json.go
- pipe_unpack_logfmt.go
- pipe_unpack_syslog.go
- pipe_unroll.go
- pipe_update.go
- rows.go
- stats_avg.go
- stats_count.go
- stats_count_empty.go
- stats_count_uniq.go
- stats_count_uniq_hash.go
- stats_histogram.go
- stats_max.go
- stats_median.go
- stats_min.go
- stats_quantile.go
- stats_rate.go
- stats_rate_sum.go
- stats_row_any.go
- stats_row_max.go
- stats_row_min.go
- stats_sum.go
- stats_sum_len.go
- stats_uniq_values.go
- stats_values.go
- storage.go
- storage_search.go
- stream_filter.go
- stream_id.go
- stream_tags.go
- stringbucket.go
- syslog_parser.go
- tenant_id.go
- tokenizer.go
- u128.go
- values_encoder.go