metadata

package
v0.100.0 Latest Latest
Warning

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

Go to latest
Published: May 6, 2024 License: Apache-2.0 Imports: 9 Imported by: 0

Documentation

Index

Constants

View Source
const (
	MetricsStability = component.StabilityLevelBeta
)

Variables

View Source
var MapAttributeCacheName = map[string]AttributeCacheName{
	"fielddata": AttributeCacheNameFielddata,
	"query":     AttributeCacheNameQuery,
}

MapAttributeCacheName is a helper map of string to AttributeCacheName attribute value.

MapAttributeClusterPublishedDifferenceState is a helper map of string to AttributeClusterPublishedDifferenceState attribute value.

MapAttributeClusterStateQueueState is a helper map of string to AttributeClusterStateQueueState attribute value.

MapAttributeClusterStateUpdateType is a helper map of string to AttributeClusterStateUpdateType attribute value.

View Source
var MapAttributeDirection = map[string]AttributeDirection{
	"received": AttributeDirectionReceived,
	"sent":     AttributeDirectionSent,
}

MapAttributeDirection is a helper map of string to AttributeDirection attribute value.

View Source
var MapAttributeDocumentState = map[string]AttributeDocumentState{
	"active":  AttributeDocumentStateActive,
	"deleted": AttributeDocumentStateDeleted,
}

MapAttributeDocumentState is a helper map of string to AttributeDocumentState attribute value.

View Source
var MapAttributeGetResult = map[string]AttributeGetResult{
	"hit":  AttributeGetResultHit,
	"miss": AttributeGetResultMiss,
}

MapAttributeGetResult is a helper map of string to AttributeGetResult attribute value.

MapAttributeHealthStatus is a helper map of string to AttributeHealthStatus attribute value.

MapAttributeIndexAggregationType is a helper map of string to AttributeIndexAggregationType attribute value.

MapAttributeIndexingPressureStage is a helper map of string to AttributeIndexingPressureStage attribute value.

View Source
var MapAttributeMemoryState = map[string]AttributeMemoryState{
	"free": AttributeMemoryStateFree,
	"used": AttributeMemoryStateUsed,
}

MapAttributeMemoryState is a helper map of string to AttributeMemoryState attribute value.

MapAttributeOperation is a helper map of string to AttributeOperation attribute value.

MapAttributeQueryCacheCountType is a helper map of string to AttributeQueryCacheCountType attribute value.

MapAttributeSegmentsMemoryObjectType is a helper map of string to AttributeSegmentsMemoryObjectType attribute value.

View Source
var MapAttributeShardState = map[string]AttributeShardState{
	"active":             AttributeShardStateActive,
	"active_primary":     AttributeShardStateActivePrimary,
	"relocating":         AttributeShardStateRelocating,
	"initializing":       AttributeShardStateInitializing,
	"unassigned":         AttributeShardStateUnassigned,
	"unassigned_delayed": AttributeShardStateUnassignedDelayed,
}

MapAttributeShardState is a helper map of string to AttributeShardState attribute value.

View Source
var MapAttributeTaskState = map[string]AttributeTaskState{
	"rejected":  AttributeTaskStateRejected,
	"completed": AttributeTaskStateCompleted,
}

MapAttributeTaskState is a helper map of string to AttributeTaskState attribute value.

View Source
var MapAttributeThreadState = map[string]AttributeThreadState{
	"active": AttributeThreadStateActive,
	"idle":   AttributeThreadStateIdle,
}

MapAttributeThreadState is a helper map of string to AttributeThreadState attribute value.

View Source
var (
	Type = component.MustNewType("elasticsearch")
)

Functions

func Meter added in v0.92.0

func Meter(settings component.TelemetrySettings) metric.Meter

func Tracer added in v0.92.0

func Tracer(settings component.TelemetrySettings) trace.Tracer

func WithStartTime added in v0.43.0

func WithStartTime(startTime pcommon.Timestamp) metricBuilderOption

WithStartTime sets startTime on the metrics builder.

Types

type AttributeCacheName added in v0.43.0

type AttributeCacheName int

AttributeCacheName specifies the a value cache_name attribute.

const (
	AttributeCacheNameFielddata AttributeCacheName
	AttributeCacheNameQuery
)

func (AttributeCacheName) String added in v0.51.0

func (av AttributeCacheName) String() string

String returns the string representation of the AttributeCacheName.

type AttributeClusterPublishedDifferenceState added in v0.59.0

type AttributeClusterPublishedDifferenceState int

AttributeClusterPublishedDifferenceState specifies the a value cluster_published_difference_state attribute.

const (
	AttributeClusterPublishedDifferenceStateIncompatible AttributeClusterPublishedDifferenceState
	AttributeClusterPublishedDifferenceStateCompatible
)

func (AttributeClusterPublishedDifferenceState) String added in v0.59.0

String returns the string representation of the AttributeClusterPublishedDifferenceState.

type AttributeClusterStateQueueState added in v0.59.0

type AttributeClusterStateQueueState int

AttributeClusterStateQueueState specifies the a value cluster_state_queue_state attribute.

const (
	AttributeClusterStateQueueStatePending AttributeClusterStateQueueState
	AttributeClusterStateQueueStateCommitted
)

func (AttributeClusterStateQueueState) String added in v0.59.0

String returns the string representation of the AttributeClusterStateQueueState.

type AttributeClusterStateUpdateType added in v0.59.0

type AttributeClusterStateUpdateType int

AttributeClusterStateUpdateType specifies the a value cluster_state_update_type attribute.

const (
	AttributeClusterStateUpdateTypeComputation AttributeClusterStateUpdateType
	AttributeClusterStateUpdateTypeContextConstruction
	AttributeClusterStateUpdateTypeCommit
	AttributeClusterStateUpdateTypeCompletion
	AttributeClusterStateUpdateTypeMasterApply
	AttributeClusterStateUpdateTypeNotification
)

func (AttributeClusterStateUpdateType) String added in v0.59.0

String returns the string representation of the AttributeClusterStateUpdateType.

type AttributeDirection added in v0.43.0

type AttributeDirection int

AttributeDirection specifies the a value direction attribute.

const (
	AttributeDirectionReceived AttributeDirection
	AttributeDirectionSent
)

func (AttributeDirection) String added in v0.51.0

func (av AttributeDirection) String() string

String returns the string representation of the AttributeDirection.

type AttributeDocumentState added in v0.43.0

type AttributeDocumentState int

AttributeDocumentState specifies the a value document_state attribute.

const (
	AttributeDocumentStateActive AttributeDocumentState
	AttributeDocumentStateDeleted
)

func (AttributeDocumentState) String added in v0.51.0

func (av AttributeDocumentState) String() string

String returns the string representation of the AttributeDocumentState.

type AttributeGetResult added in v0.64.0

type AttributeGetResult int

AttributeGetResult specifies the a value get_result attribute.

const (
	AttributeGetResultHit AttributeGetResult
	AttributeGetResultMiss
)

func (AttributeGetResult) String added in v0.64.0

func (av AttributeGetResult) String() string

String returns the string representation of the AttributeGetResult.

type AttributeHealthStatus added in v0.43.0

type AttributeHealthStatus int

AttributeHealthStatus specifies the a value health_status attribute.

const (
	AttributeHealthStatusGreen AttributeHealthStatus
	AttributeHealthStatusYellow
	AttributeHealthStatusRed
)

func (AttributeHealthStatus) String added in v0.51.0

func (av AttributeHealthStatus) String() string

String returns the string representation of the AttributeHealthStatus.

type AttributeIndexAggregationType added in v0.62.0

type AttributeIndexAggregationType int

AttributeIndexAggregationType specifies the a value index_aggregation_type attribute.

const (
	AttributeIndexAggregationTypePrimaryShards AttributeIndexAggregationType
	AttributeIndexAggregationTypeTotal
)

func (AttributeIndexAggregationType) String added in v0.62.0

String returns the string representation of the AttributeIndexAggregationType.

type AttributeIndexingPressureStage added in v0.59.0

type AttributeIndexingPressureStage int

AttributeIndexingPressureStage specifies the a value indexing_pressure_stage attribute.

const (
	AttributeIndexingPressureStageCoordinating AttributeIndexingPressureStage
	AttributeIndexingPressureStagePrimary
	AttributeIndexingPressureStageReplica
)

func (AttributeIndexingPressureStage) String added in v0.59.0

String returns the string representation of the AttributeIndexingPressureStage.

type AttributeMemoryState added in v0.56.0

type AttributeMemoryState int

AttributeMemoryState specifies the a value memory_state attribute.

const (
	AttributeMemoryStateFree AttributeMemoryState
	AttributeMemoryStateUsed
)

func (AttributeMemoryState) String added in v0.56.0

func (av AttributeMemoryState) String() string

String returns the string representation of the AttributeMemoryState.

type AttributeOperation added in v0.43.0

type AttributeOperation int

AttributeOperation specifies the a value operation attribute.

const (
	AttributeOperationIndex AttributeOperation
	AttributeOperationDelete
	AttributeOperationGet
	AttributeOperationQuery
	AttributeOperationFetch
	AttributeOperationScroll
	AttributeOperationSuggest
	AttributeOperationMerge
	AttributeOperationRefresh
	AttributeOperationFlush
	AttributeOperationWarmer
)

func (AttributeOperation) String added in v0.51.0

func (av AttributeOperation) String() string

String returns the string representation of the AttributeOperation.

type AttributeQueryCacheCountType added in v0.60.0

type AttributeQueryCacheCountType int

AttributeQueryCacheCountType specifies the a value query_cache_count_type attribute.

const (
	AttributeQueryCacheCountTypeHit AttributeQueryCacheCountType
	AttributeQueryCacheCountTypeMiss
)

func (AttributeQueryCacheCountType) String added in v0.60.0

String returns the string representation of the AttributeQueryCacheCountType.

type AttributeSegmentsMemoryObjectType added in v0.64.0

type AttributeSegmentsMemoryObjectType int

AttributeSegmentsMemoryObjectType specifies the a value segments_memory_object_type attribute.

const (
	AttributeSegmentsMemoryObjectTypeTerm AttributeSegmentsMemoryObjectType
	AttributeSegmentsMemoryObjectTypeDocValue
	AttributeSegmentsMemoryObjectTypeIndexWriter
	AttributeSegmentsMemoryObjectTypeFixedBitSet
)

func (AttributeSegmentsMemoryObjectType) String added in v0.64.0

String returns the string representation of the AttributeSegmentsMemoryObjectType.

type AttributeShardState added in v0.43.0

type AttributeShardState int

AttributeShardState specifies the a value shard_state attribute.

const (
	AttributeShardStateActive AttributeShardState
	AttributeShardStateActivePrimary
	AttributeShardStateRelocating
	AttributeShardStateInitializing
	AttributeShardStateUnassigned
	AttributeShardStateUnassignedDelayed
)

func (AttributeShardState) String added in v0.51.0

func (av AttributeShardState) String() string

String returns the string representation of the AttributeShardState.

type AttributeTaskState added in v0.43.0

type AttributeTaskState int

AttributeTaskState specifies the a value task_state attribute.

const (
	AttributeTaskStateRejected AttributeTaskState
	AttributeTaskStateCompleted
)

func (AttributeTaskState) String added in v0.51.0

func (av AttributeTaskState) String() string

String returns the string representation of the AttributeTaskState.

type AttributeThreadState added in v0.43.0

type AttributeThreadState int

AttributeThreadState specifies the a value thread_state attribute.

const (
	AttributeThreadStateActive AttributeThreadState
	AttributeThreadStateIdle
)

func (AttributeThreadState) String added in v0.51.0

func (av AttributeThreadState) String() string

String returns the string representation of the AttributeThreadState.

type MetricConfig added in v0.77.0

type MetricConfig struct {
	Enabled bool `mapstructure:"enabled"`
	// contains filtered or unexported fields
}

MetricConfig provides common config for a particular metric.

func (*MetricConfig) Unmarshal added in v0.77.0

func (ms *MetricConfig) Unmarshal(parser *confmap.Conf) error

type MetricsBuilder added in v0.43.0

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

MetricsBuilder provides an interface for scrapers to report metrics while taking care of all the transformations required to produce metric representation defined in metadata and user config.

func NewMetricsBuilder added in v0.43.0

func NewMetricsBuilder(mbc MetricsBuilderConfig, settings receiver.CreateSettings, options ...metricBuilderOption) *MetricsBuilder

func (*MetricsBuilder) Emit added in v0.43.0

Emit returns all the metrics accumulated by the metrics builder and updates the internal state to be ready for recording another set of metrics. This function will be responsible for applying all the transformations required to produce metric representation defined in metadata and user config, e.g. delta or cumulative.

func (*MetricsBuilder) EmitForResource added in v0.48.0

func (mb *MetricsBuilder) EmitForResource(rmo ...ResourceMetricsOption)

EmitForResource saves all the generated metrics under a new resource and updates the internal state to be ready for recording another set of data points as part of another resource. This function can be helpful when one scraper needs to emit metrics from several resources. Otherwise calling this function is not required, just `Emit` function can be called instead. Resource attributes should be provided as ResourceMetricsOption arguments.

func (*MetricsBuilder) NewResourceBuilder added in v0.83.0

func (mb *MetricsBuilder) NewResourceBuilder() *ResourceBuilder

NewResourceBuilder returns a new resource builder that should be used to build a resource associated with for the emitted metrics.

func (*MetricsBuilder) RecordElasticsearchBreakerMemoryEstimatedDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchBreakerMemoryEstimatedDataPoint(ts pcommon.Timestamp, val int64, circuitBreakerNameAttributeValue string)

RecordElasticsearchBreakerMemoryEstimatedDataPoint adds a data point to elasticsearch.breaker.memory.estimated metric.

func (*MetricsBuilder) RecordElasticsearchBreakerMemoryLimitDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchBreakerMemoryLimitDataPoint(ts pcommon.Timestamp, val int64, circuitBreakerNameAttributeValue string)

RecordElasticsearchBreakerMemoryLimitDataPoint adds a data point to elasticsearch.breaker.memory.limit metric.

func (*MetricsBuilder) RecordElasticsearchBreakerTrippedDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchBreakerTrippedDataPoint(ts pcommon.Timestamp, val int64, circuitBreakerNameAttributeValue string)

RecordElasticsearchBreakerTrippedDataPoint adds a data point to elasticsearch.breaker.tripped metric.

func (*MetricsBuilder) RecordElasticsearchClusterDataNodesDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchClusterDataNodesDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchClusterDataNodesDataPoint adds a data point to elasticsearch.cluster.data_nodes metric.

func (*MetricsBuilder) RecordElasticsearchClusterHealthDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchClusterHealthDataPoint(ts pcommon.Timestamp, val int64, healthStatusAttributeValue AttributeHealthStatus)

RecordElasticsearchClusterHealthDataPoint adds a data point to elasticsearch.cluster.health metric.

func (*MetricsBuilder) RecordElasticsearchClusterInFlightFetchDataPoint added in v0.60.0

func (mb *MetricsBuilder) RecordElasticsearchClusterInFlightFetchDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchClusterInFlightFetchDataPoint adds a data point to elasticsearch.cluster.in_flight_fetch metric.

func (*MetricsBuilder) RecordElasticsearchClusterIndicesCacheEvictionsDataPoint added in v0.67.0

func (mb *MetricsBuilder) RecordElasticsearchClusterIndicesCacheEvictionsDataPoint(ts pcommon.Timestamp, val int64, cacheNameAttributeValue AttributeCacheName)

RecordElasticsearchClusterIndicesCacheEvictionsDataPoint adds a data point to elasticsearch.cluster.indices.cache.evictions metric.

func (*MetricsBuilder) RecordElasticsearchClusterNodesDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchClusterNodesDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchClusterNodesDataPoint adds a data point to elasticsearch.cluster.nodes metric.

func (*MetricsBuilder) RecordElasticsearchClusterPendingTasksDataPoint added in v0.60.0

func (mb *MetricsBuilder) RecordElasticsearchClusterPendingTasksDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchClusterPendingTasksDataPoint adds a data point to elasticsearch.cluster.pending_tasks metric.

func (*MetricsBuilder) RecordElasticsearchClusterPublishedStatesDifferencesDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchClusterPublishedStatesDifferencesDataPoint(ts pcommon.Timestamp, val int64, clusterPublishedDifferenceStateAttributeValue AttributeClusterPublishedDifferenceState)

RecordElasticsearchClusterPublishedStatesDifferencesDataPoint adds a data point to elasticsearch.cluster.published_states.differences metric.

func (*MetricsBuilder) RecordElasticsearchClusterPublishedStatesFullDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchClusterPublishedStatesFullDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchClusterPublishedStatesFullDataPoint adds a data point to elasticsearch.cluster.published_states.full metric.

func (*MetricsBuilder) RecordElasticsearchClusterShardsDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchClusterShardsDataPoint(ts pcommon.Timestamp, val int64, shardStateAttributeValue AttributeShardState)

RecordElasticsearchClusterShardsDataPoint adds a data point to elasticsearch.cluster.shards metric.

func (*MetricsBuilder) RecordElasticsearchClusterStateQueueDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchClusterStateQueueDataPoint(ts pcommon.Timestamp, val int64, clusterStateQueueStateAttributeValue AttributeClusterStateQueueState)

RecordElasticsearchClusterStateQueueDataPoint adds a data point to elasticsearch.cluster.state_queue metric.

func (*MetricsBuilder) RecordElasticsearchClusterStateUpdateCountDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchClusterStateUpdateCountDataPoint(ts pcommon.Timestamp, val int64, clusterStateUpdateStateAttributeValue string)

RecordElasticsearchClusterStateUpdateCountDataPoint adds a data point to elasticsearch.cluster.state_update.count metric.

func (*MetricsBuilder) RecordElasticsearchClusterStateUpdateTimeDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchClusterStateUpdateTimeDataPoint(ts pcommon.Timestamp, val int64, clusterStateUpdateStateAttributeValue string, clusterStateUpdateTypeAttributeValue AttributeClusterStateUpdateType)

RecordElasticsearchClusterStateUpdateTimeDataPoint adds a data point to elasticsearch.cluster.state_update.time metric.

func (*MetricsBuilder) RecordElasticsearchIndexCacheEvictionsDataPoint added in v0.65.0

func (mb *MetricsBuilder) RecordElasticsearchIndexCacheEvictionsDataPoint(ts pcommon.Timestamp, val int64, cacheNameAttributeValue AttributeCacheName, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexCacheEvictionsDataPoint adds a data point to elasticsearch.index.cache.evictions metric.

func (*MetricsBuilder) RecordElasticsearchIndexCacheMemoryUsageDataPoint added in v0.65.0

func (mb *MetricsBuilder) RecordElasticsearchIndexCacheMemoryUsageDataPoint(ts pcommon.Timestamp, val int64, cacheNameAttributeValue AttributeCacheName, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexCacheMemoryUsageDataPoint adds a data point to elasticsearch.index.cache.memory.usage metric.

func (*MetricsBuilder) RecordElasticsearchIndexCacheSizeDataPoint added in v0.65.0

func (mb *MetricsBuilder) RecordElasticsearchIndexCacheSizeDataPoint(ts pcommon.Timestamp, val int64, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexCacheSizeDataPoint adds a data point to elasticsearch.index.cache.size metric.

func (*MetricsBuilder) RecordElasticsearchIndexDocumentsDataPoint added in v0.65.0

func (mb *MetricsBuilder) RecordElasticsearchIndexDocumentsDataPoint(ts pcommon.Timestamp, val int64, documentStateAttributeValue AttributeDocumentState, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexDocumentsDataPoint adds a data point to elasticsearch.index.documents metric.

func (*MetricsBuilder) RecordElasticsearchIndexOperationsCompletedDataPoint added in v0.62.0

func (mb *MetricsBuilder) RecordElasticsearchIndexOperationsCompletedDataPoint(ts pcommon.Timestamp, val int64, operationAttributeValue AttributeOperation, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexOperationsCompletedDataPoint adds a data point to elasticsearch.index.operations.completed metric.

func (*MetricsBuilder) RecordElasticsearchIndexOperationsMergeDocsCountDataPoint added in v0.64.0

func (mb *MetricsBuilder) RecordElasticsearchIndexOperationsMergeDocsCountDataPoint(ts pcommon.Timestamp, val int64, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexOperationsMergeDocsCountDataPoint adds a data point to elasticsearch.index.operations.merge.docs_count metric.

func (*MetricsBuilder) RecordElasticsearchIndexOperationsMergeSizeDataPoint added in v0.64.0

func (mb *MetricsBuilder) RecordElasticsearchIndexOperationsMergeSizeDataPoint(ts pcommon.Timestamp, val int64, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexOperationsMergeSizeDataPoint adds a data point to elasticsearch.index.operations.merge.size metric.

func (*MetricsBuilder) RecordElasticsearchIndexOperationsTimeDataPoint added in v0.62.0

func (mb *MetricsBuilder) RecordElasticsearchIndexOperationsTimeDataPoint(ts pcommon.Timestamp, val int64, operationAttributeValue AttributeOperation, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexOperationsTimeDataPoint adds a data point to elasticsearch.index.operations.time metric.

func (*MetricsBuilder) RecordElasticsearchIndexSegmentsCountDataPoint added in v0.64.0

func (mb *MetricsBuilder) RecordElasticsearchIndexSegmentsCountDataPoint(ts pcommon.Timestamp, val int64, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexSegmentsCountDataPoint adds a data point to elasticsearch.index.segments.count metric.

func (*MetricsBuilder) RecordElasticsearchIndexSegmentsMemoryDataPoint added in v0.64.0

func (mb *MetricsBuilder) RecordElasticsearchIndexSegmentsMemoryDataPoint(ts pcommon.Timestamp, val int64, indexAggregationTypeAttributeValue AttributeIndexAggregationType, segmentsMemoryObjectTypeAttributeValue AttributeSegmentsMemoryObjectType)

RecordElasticsearchIndexSegmentsMemoryDataPoint adds a data point to elasticsearch.index.segments.memory metric.

func (*MetricsBuilder) RecordElasticsearchIndexSegmentsSizeDataPoint added in v0.64.0

func (mb *MetricsBuilder) RecordElasticsearchIndexSegmentsSizeDataPoint(ts pcommon.Timestamp, val int64, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexSegmentsSizeDataPoint adds a data point to elasticsearch.index.segments.size metric.

func (*MetricsBuilder) RecordElasticsearchIndexShardsSizeDataPoint added in v0.63.0

func (mb *MetricsBuilder) RecordElasticsearchIndexShardsSizeDataPoint(ts pcommon.Timestamp, val int64, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexShardsSizeDataPoint adds a data point to elasticsearch.index.shards.size metric.

func (*MetricsBuilder) RecordElasticsearchIndexTranslogOperationsDataPoint added in v0.64.0

func (mb *MetricsBuilder) RecordElasticsearchIndexTranslogOperationsDataPoint(ts pcommon.Timestamp, val int64, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexTranslogOperationsDataPoint adds a data point to elasticsearch.index.translog.operations metric.

func (*MetricsBuilder) RecordElasticsearchIndexTranslogSizeDataPoint added in v0.64.0

func (mb *MetricsBuilder) RecordElasticsearchIndexTranslogSizeDataPoint(ts pcommon.Timestamp, val int64, indexAggregationTypeAttributeValue AttributeIndexAggregationType)

RecordElasticsearchIndexTranslogSizeDataPoint adds a data point to elasticsearch.index.translog.size metric.

func (*MetricsBuilder) RecordElasticsearchIndexingPressureMemoryLimitDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchIndexingPressureMemoryLimitDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchIndexingPressureMemoryLimitDataPoint adds a data point to elasticsearch.indexing_pressure.memory.limit metric.

func (*MetricsBuilder) RecordElasticsearchIndexingPressureMemoryTotalPrimaryRejectionsDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchIndexingPressureMemoryTotalPrimaryRejectionsDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchIndexingPressureMemoryTotalPrimaryRejectionsDataPoint adds a data point to elasticsearch.indexing_pressure.memory.total.primary_rejections metric.

func (*MetricsBuilder) RecordElasticsearchIndexingPressureMemoryTotalReplicaRejectionsDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchIndexingPressureMemoryTotalReplicaRejectionsDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchIndexingPressureMemoryTotalReplicaRejectionsDataPoint adds a data point to elasticsearch.indexing_pressure.memory.total.replica_rejections metric.

func (*MetricsBuilder) RecordElasticsearchMemoryIndexingPressureDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchMemoryIndexingPressureDataPoint(ts pcommon.Timestamp, val int64, indexingPressureStageAttributeValue AttributeIndexingPressureStage)

RecordElasticsearchMemoryIndexingPressureDataPoint adds a data point to elasticsearch.memory.indexing_pressure metric.

func (*MetricsBuilder) RecordElasticsearchNodeCacheCountDataPoint added in v0.60.0

func (mb *MetricsBuilder) RecordElasticsearchNodeCacheCountDataPoint(ts pcommon.Timestamp, val int64, queryCacheCountTypeAttributeValue AttributeQueryCacheCountType)

RecordElasticsearchNodeCacheCountDataPoint adds a data point to elasticsearch.node.cache.count metric.

func (*MetricsBuilder) RecordElasticsearchNodeCacheEvictionsDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeCacheEvictionsDataPoint(ts pcommon.Timestamp, val int64, cacheNameAttributeValue AttributeCacheName)

RecordElasticsearchNodeCacheEvictionsDataPoint adds a data point to elasticsearch.node.cache.evictions metric.

func (*MetricsBuilder) RecordElasticsearchNodeCacheMemoryUsageDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeCacheMemoryUsageDataPoint(ts pcommon.Timestamp, val int64, cacheNameAttributeValue AttributeCacheName)

RecordElasticsearchNodeCacheMemoryUsageDataPoint adds a data point to elasticsearch.node.cache.memory.usage metric.

func (*MetricsBuilder) RecordElasticsearchNodeCacheSizeDataPoint added in v0.68.0

func (mb *MetricsBuilder) RecordElasticsearchNodeCacheSizeDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeCacheSizeDataPoint adds a data point to elasticsearch.node.cache.size metric.

func (*MetricsBuilder) RecordElasticsearchNodeClusterConnectionsDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeClusterConnectionsDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeClusterConnectionsDataPoint adds a data point to elasticsearch.node.cluster.connections metric.

func (*MetricsBuilder) RecordElasticsearchNodeClusterIoDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeClusterIoDataPoint(ts pcommon.Timestamp, val int64, directionAttributeValue AttributeDirection)

RecordElasticsearchNodeClusterIoDataPoint adds a data point to elasticsearch.node.cluster.io metric.

func (*MetricsBuilder) RecordElasticsearchNodeDiskIoReadDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchNodeDiskIoReadDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeDiskIoReadDataPoint adds a data point to elasticsearch.node.disk.io.read metric.

func (*MetricsBuilder) RecordElasticsearchNodeDiskIoWriteDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchNodeDiskIoWriteDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeDiskIoWriteDataPoint adds a data point to elasticsearch.node.disk.io.write metric.

func (*MetricsBuilder) RecordElasticsearchNodeDocumentsDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeDocumentsDataPoint(ts pcommon.Timestamp, val int64, documentStateAttributeValue AttributeDocumentState)

RecordElasticsearchNodeDocumentsDataPoint adds a data point to elasticsearch.node.documents metric.

func (*MetricsBuilder) RecordElasticsearchNodeFsDiskAvailableDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeFsDiskAvailableDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeFsDiskAvailableDataPoint adds a data point to elasticsearch.node.fs.disk.available metric.

func (*MetricsBuilder) RecordElasticsearchNodeFsDiskFreeDataPoint added in v0.60.0

func (mb *MetricsBuilder) RecordElasticsearchNodeFsDiskFreeDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeFsDiskFreeDataPoint adds a data point to elasticsearch.node.fs.disk.free metric.

func (*MetricsBuilder) RecordElasticsearchNodeFsDiskTotalDataPoint added in v0.60.0

func (mb *MetricsBuilder) RecordElasticsearchNodeFsDiskTotalDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeFsDiskTotalDataPoint adds a data point to elasticsearch.node.fs.disk.total metric.

func (*MetricsBuilder) RecordElasticsearchNodeHTTPConnectionsDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeHTTPConnectionsDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeHTTPConnectionsDataPoint adds a data point to elasticsearch.node.http.connections metric.

func (*MetricsBuilder) RecordElasticsearchNodeIngestDocumentsCurrentDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchNodeIngestDocumentsCurrentDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeIngestDocumentsCurrentDataPoint adds a data point to elasticsearch.node.ingest.documents.current metric.

func (*MetricsBuilder) RecordElasticsearchNodeIngestDocumentsDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchNodeIngestDocumentsDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeIngestDocumentsDataPoint adds a data point to elasticsearch.node.ingest.documents metric.

func (*MetricsBuilder) RecordElasticsearchNodeIngestOperationsFailedDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchNodeIngestOperationsFailedDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeIngestOperationsFailedDataPoint adds a data point to elasticsearch.node.ingest.operations.failed metric.

func (*MetricsBuilder) RecordElasticsearchNodeOpenFilesDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeOpenFilesDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeOpenFilesDataPoint adds a data point to elasticsearch.node.open_files metric.

func (*MetricsBuilder) RecordElasticsearchNodeOperationsCompletedDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeOperationsCompletedDataPoint(ts pcommon.Timestamp, val int64, operationAttributeValue AttributeOperation)

RecordElasticsearchNodeOperationsCompletedDataPoint adds a data point to elasticsearch.node.operations.completed metric.

func (*MetricsBuilder) RecordElasticsearchNodeOperationsCurrentDataPoint added in v0.68.0

func (mb *MetricsBuilder) RecordElasticsearchNodeOperationsCurrentDataPoint(ts pcommon.Timestamp, val int64, operationAttributeValue AttributeOperation)

RecordElasticsearchNodeOperationsCurrentDataPoint adds a data point to elasticsearch.node.operations.current metric.

func (*MetricsBuilder) RecordElasticsearchNodeOperationsGetCompletedDataPoint added in v0.64.0

func (mb *MetricsBuilder) RecordElasticsearchNodeOperationsGetCompletedDataPoint(ts pcommon.Timestamp, val int64, getResultAttributeValue AttributeGetResult)

RecordElasticsearchNodeOperationsGetCompletedDataPoint adds a data point to elasticsearch.node.operations.get.completed metric.

func (*MetricsBuilder) RecordElasticsearchNodeOperationsGetTimeDataPoint added in v0.64.0

func (mb *MetricsBuilder) RecordElasticsearchNodeOperationsGetTimeDataPoint(ts pcommon.Timestamp, val int64, getResultAttributeValue AttributeGetResult)

RecordElasticsearchNodeOperationsGetTimeDataPoint adds a data point to elasticsearch.node.operations.get.time metric.

func (*MetricsBuilder) RecordElasticsearchNodeOperationsTimeDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeOperationsTimeDataPoint(ts pcommon.Timestamp, val int64, operationAttributeValue AttributeOperation)

RecordElasticsearchNodeOperationsTimeDataPoint adds a data point to elasticsearch.node.operations.time metric.

func (*MetricsBuilder) RecordElasticsearchNodePipelineIngestDocumentsCurrentDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchNodePipelineIngestDocumentsCurrentDataPoint(ts pcommon.Timestamp, val int64, ingestPipelineNameAttributeValue string)

RecordElasticsearchNodePipelineIngestDocumentsCurrentDataPoint adds a data point to elasticsearch.node.pipeline.ingest.documents.current metric.

func (*MetricsBuilder) RecordElasticsearchNodePipelineIngestDocumentsPreprocessedDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchNodePipelineIngestDocumentsPreprocessedDataPoint(ts pcommon.Timestamp, val int64, ingestPipelineNameAttributeValue string)

RecordElasticsearchNodePipelineIngestDocumentsPreprocessedDataPoint adds a data point to elasticsearch.node.pipeline.ingest.documents.preprocessed metric.

func (*MetricsBuilder) RecordElasticsearchNodePipelineIngestOperationsFailedDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchNodePipelineIngestOperationsFailedDataPoint(ts pcommon.Timestamp, val int64, ingestPipelineNameAttributeValue string)

RecordElasticsearchNodePipelineIngestOperationsFailedDataPoint adds a data point to elasticsearch.node.pipeline.ingest.operations.failed metric.

func (*MetricsBuilder) RecordElasticsearchNodeScriptCacheEvictionsDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchNodeScriptCacheEvictionsDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeScriptCacheEvictionsDataPoint adds a data point to elasticsearch.node.script.cache_evictions metric.

func (*MetricsBuilder) RecordElasticsearchNodeScriptCompilationLimitTriggeredDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchNodeScriptCompilationLimitTriggeredDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeScriptCompilationLimitTriggeredDataPoint adds a data point to elasticsearch.node.script.compilation_limit_triggered metric.

func (*MetricsBuilder) RecordElasticsearchNodeScriptCompilationsDataPoint added in v0.59.0

func (mb *MetricsBuilder) RecordElasticsearchNodeScriptCompilationsDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeScriptCompilationsDataPoint adds a data point to elasticsearch.node.script.compilations metric.

func (*MetricsBuilder) RecordElasticsearchNodeSegmentsMemoryDataPoint added in v0.65.0

func (mb *MetricsBuilder) RecordElasticsearchNodeSegmentsMemoryDataPoint(ts pcommon.Timestamp, val int64, segmentsMemoryObjectTypeAttributeValue AttributeSegmentsMemoryObjectType)

RecordElasticsearchNodeSegmentsMemoryDataPoint adds a data point to elasticsearch.node.segments.memory metric.

func (*MetricsBuilder) RecordElasticsearchNodeShardsDataSetSizeDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchNodeShardsDataSetSizeDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeShardsDataSetSizeDataPoint adds a data point to elasticsearch.node.shards.data_set.size metric.

func (*MetricsBuilder) RecordElasticsearchNodeShardsReservedSizeDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchNodeShardsReservedSizeDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeShardsReservedSizeDataPoint adds a data point to elasticsearch.node.shards.reserved.size metric.

func (*MetricsBuilder) RecordElasticsearchNodeShardsSizeDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeShardsSizeDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeShardsSizeDataPoint adds a data point to elasticsearch.node.shards.size metric.

func (*MetricsBuilder) RecordElasticsearchNodeThreadPoolTasksFinishedDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeThreadPoolTasksFinishedDataPoint(ts pcommon.Timestamp, val int64, threadPoolNameAttributeValue string, taskStateAttributeValue AttributeTaskState)

RecordElasticsearchNodeThreadPoolTasksFinishedDataPoint adds a data point to elasticsearch.node.thread_pool.tasks.finished metric.

func (*MetricsBuilder) RecordElasticsearchNodeThreadPoolTasksQueuedDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeThreadPoolTasksQueuedDataPoint(ts pcommon.Timestamp, val int64, threadPoolNameAttributeValue string)

RecordElasticsearchNodeThreadPoolTasksQueuedDataPoint adds a data point to elasticsearch.node.thread_pool.tasks.queued metric.

func (*MetricsBuilder) RecordElasticsearchNodeThreadPoolThreadsDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordElasticsearchNodeThreadPoolThreadsDataPoint(ts pcommon.Timestamp, val int64, threadPoolNameAttributeValue string, threadStateAttributeValue AttributeThreadState)

RecordElasticsearchNodeThreadPoolThreadsDataPoint adds a data point to elasticsearch.node.thread_pool.threads metric.

func (*MetricsBuilder) RecordElasticsearchNodeTranslogOperationsDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchNodeTranslogOperationsDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeTranslogOperationsDataPoint adds a data point to elasticsearch.node.translog.operations metric.

func (*MetricsBuilder) RecordElasticsearchNodeTranslogSizeDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchNodeTranslogSizeDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeTranslogSizeDataPoint adds a data point to elasticsearch.node.translog.size metric.

func (*MetricsBuilder) RecordElasticsearchNodeTranslogUncommittedSizeDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchNodeTranslogUncommittedSizeDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchNodeTranslogUncommittedSizeDataPoint adds a data point to elasticsearch.node.translog.uncommitted.size metric.

func (*MetricsBuilder) RecordElasticsearchOsCPULoadAvg15mDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchOsCPULoadAvg15mDataPoint(ts pcommon.Timestamp, val float64)

RecordElasticsearchOsCPULoadAvg15mDataPoint adds a data point to elasticsearch.os.cpu.load_avg.15m metric.

func (*MetricsBuilder) RecordElasticsearchOsCPULoadAvg1mDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchOsCPULoadAvg1mDataPoint(ts pcommon.Timestamp, val float64)

RecordElasticsearchOsCPULoadAvg1mDataPoint adds a data point to elasticsearch.os.cpu.load_avg.1m metric.

func (*MetricsBuilder) RecordElasticsearchOsCPULoadAvg5mDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchOsCPULoadAvg5mDataPoint(ts pcommon.Timestamp, val float64)

RecordElasticsearchOsCPULoadAvg5mDataPoint adds a data point to elasticsearch.os.cpu.load_avg.5m metric.

func (*MetricsBuilder) RecordElasticsearchOsCPUUsageDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchOsCPUUsageDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchOsCPUUsageDataPoint adds a data point to elasticsearch.os.cpu.usage metric.

func (*MetricsBuilder) RecordElasticsearchOsMemoryDataPoint added in v0.56.0

func (mb *MetricsBuilder) RecordElasticsearchOsMemoryDataPoint(ts pcommon.Timestamp, val int64, memoryStateAttributeValue AttributeMemoryState)

RecordElasticsearchOsMemoryDataPoint adds a data point to elasticsearch.os.memory metric.

func (*MetricsBuilder) RecordElasticsearchProcessCPUTimeDataPoint added in v0.68.0

func (mb *MetricsBuilder) RecordElasticsearchProcessCPUTimeDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchProcessCPUTimeDataPoint adds a data point to elasticsearch.process.cpu.time metric.

func (*MetricsBuilder) RecordElasticsearchProcessCPUUsageDataPoint added in v0.68.0

func (mb *MetricsBuilder) RecordElasticsearchProcessCPUUsageDataPoint(ts pcommon.Timestamp, val float64)

RecordElasticsearchProcessCPUUsageDataPoint adds a data point to elasticsearch.process.cpu.usage metric.

func (*MetricsBuilder) RecordElasticsearchProcessMemoryVirtualDataPoint added in v0.68.0

func (mb *MetricsBuilder) RecordElasticsearchProcessMemoryVirtualDataPoint(ts pcommon.Timestamp, val int64)

RecordElasticsearchProcessMemoryVirtualDataPoint adds a data point to elasticsearch.process.memory.virtual metric.

func (*MetricsBuilder) RecordJvmClassesLoadedDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmClassesLoadedDataPoint(ts pcommon.Timestamp, val int64)

RecordJvmClassesLoadedDataPoint adds a data point to jvm.classes.loaded metric.

func (*MetricsBuilder) RecordJvmGcCollectionsCountDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmGcCollectionsCountDataPoint(ts pcommon.Timestamp, val int64, collectorNameAttributeValue string)

RecordJvmGcCollectionsCountDataPoint adds a data point to jvm.gc.collections.count metric.

func (*MetricsBuilder) RecordJvmGcCollectionsElapsedDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmGcCollectionsElapsedDataPoint(ts pcommon.Timestamp, val int64, collectorNameAttributeValue string)

RecordJvmGcCollectionsElapsedDataPoint adds a data point to jvm.gc.collections.elapsed metric.

func (*MetricsBuilder) RecordJvmMemoryHeapCommittedDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmMemoryHeapCommittedDataPoint(ts pcommon.Timestamp, val int64)

RecordJvmMemoryHeapCommittedDataPoint adds a data point to jvm.memory.heap.committed metric.

func (*MetricsBuilder) RecordJvmMemoryHeapMaxDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmMemoryHeapMaxDataPoint(ts pcommon.Timestamp, val int64)

RecordJvmMemoryHeapMaxDataPoint adds a data point to jvm.memory.heap.max metric.

func (*MetricsBuilder) RecordJvmMemoryHeapUsedDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmMemoryHeapUsedDataPoint(ts pcommon.Timestamp, val int64)

RecordJvmMemoryHeapUsedDataPoint adds a data point to jvm.memory.heap.used metric.

func (*MetricsBuilder) RecordJvmMemoryHeapUtilizationDataPoint added in v0.65.0

func (mb *MetricsBuilder) RecordJvmMemoryHeapUtilizationDataPoint(ts pcommon.Timestamp, val float64)

RecordJvmMemoryHeapUtilizationDataPoint adds a data point to jvm.memory.heap.utilization metric.

func (*MetricsBuilder) RecordJvmMemoryNonheapCommittedDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmMemoryNonheapCommittedDataPoint(ts pcommon.Timestamp, val int64)

RecordJvmMemoryNonheapCommittedDataPoint adds a data point to jvm.memory.nonheap.committed metric.

func (*MetricsBuilder) RecordJvmMemoryNonheapUsedDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmMemoryNonheapUsedDataPoint(ts pcommon.Timestamp, val int64)

RecordJvmMemoryNonheapUsedDataPoint adds a data point to jvm.memory.nonheap.used metric.

func (*MetricsBuilder) RecordJvmMemoryPoolMaxDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmMemoryPoolMaxDataPoint(ts pcommon.Timestamp, val int64, memoryPoolNameAttributeValue string)

RecordJvmMemoryPoolMaxDataPoint adds a data point to jvm.memory.pool.max metric.

func (*MetricsBuilder) RecordJvmMemoryPoolUsedDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmMemoryPoolUsedDataPoint(ts pcommon.Timestamp, val int64, memoryPoolNameAttributeValue string)

RecordJvmMemoryPoolUsedDataPoint adds a data point to jvm.memory.pool.used metric.

func (*MetricsBuilder) RecordJvmThreadsCountDataPoint added in v0.43.0

func (mb *MetricsBuilder) RecordJvmThreadsCountDataPoint(ts pcommon.Timestamp, val int64)

RecordJvmThreadsCountDataPoint adds a data point to jvm.threads.count metric.

func (*MetricsBuilder) Reset added in v0.43.0

func (mb *MetricsBuilder) Reset(options ...metricBuilderOption)

Reset resets metrics builder to its initial state. It should be used when external metrics source is restarted, and metrics builder should update its startTime and reset it's internal state accordingly.

type MetricsBuilderConfig added in v0.73.0

type MetricsBuilderConfig struct {
	Metrics            MetricsConfig            `mapstructure:"metrics"`
	ResourceAttributes ResourceAttributesConfig `mapstructure:"resource_attributes"`
}

MetricsBuilderConfig is a configuration for elasticsearch metrics builder.

func DefaultMetricsBuilderConfig added in v0.73.0

func DefaultMetricsBuilderConfig() MetricsBuilderConfig

type MetricsConfig added in v0.77.0

type MetricsConfig struct {
	ElasticsearchBreakerMemoryEstimated                       MetricConfig `mapstructure:"elasticsearch.breaker.memory.estimated"`
	ElasticsearchBreakerMemoryLimit                           MetricConfig `mapstructure:"elasticsearch.breaker.memory.limit"`
	ElasticsearchBreakerTripped                               MetricConfig `mapstructure:"elasticsearch.breaker.tripped"`
	ElasticsearchClusterDataNodes                             MetricConfig `mapstructure:"elasticsearch.cluster.data_nodes"`
	ElasticsearchClusterHealth                                MetricConfig `mapstructure:"elasticsearch.cluster.health"`
	ElasticsearchClusterInFlightFetch                         MetricConfig `mapstructure:"elasticsearch.cluster.in_flight_fetch"`
	ElasticsearchClusterIndicesCacheEvictions                 MetricConfig `mapstructure:"elasticsearch.cluster.indices.cache.evictions"`
	ElasticsearchClusterNodes                                 MetricConfig `mapstructure:"elasticsearch.cluster.nodes"`
	ElasticsearchClusterPendingTasks                          MetricConfig `mapstructure:"elasticsearch.cluster.pending_tasks"`
	ElasticsearchClusterPublishedStatesDifferences            MetricConfig `mapstructure:"elasticsearch.cluster.published_states.differences"`
	ElasticsearchClusterPublishedStatesFull                   MetricConfig `mapstructure:"elasticsearch.cluster.published_states.full"`
	ElasticsearchClusterShards                                MetricConfig `mapstructure:"elasticsearch.cluster.shards"`
	ElasticsearchClusterStateQueue                            MetricConfig `mapstructure:"elasticsearch.cluster.state_queue"`
	ElasticsearchClusterStateUpdateCount                      MetricConfig `mapstructure:"elasticsearch.cluster.state_update.count"`
	ElasticsearchClusterStateUpdateTime                       MetricConfig `mapstructure:"elasticsearch.cluster.state_update.time"`
	ElasticsearchIndexCacheEvictions                          MetricConfig `mapstructure:"elasticsearch.index.cache.evictions"`
	ElasticsearchIndexCacheMemoryUsage                        MetricConfig `mapstructure:"elasticsearch.index.cache.memory.usage"`
	ElasticsearchIndexCacheSize                               MetricConfig `mapstructure:"elasticsearch.index.cache.size"`
	ElasticsearchIndexDocuments                               MetricConfig `mapstructure:"elasticsearch.index.documents"`
	ElasticsearchIndexOperationsCompleted                     MetricConfig `mapstructure:"elasticsearch.index.operations.completed"`
	ElasticsearchIndexOperationsMergeDocsCount                MetricConfig `mapstructure:"elasticsearch.index.operations.merge.docs_count"`
	ElasticsearchIndexOperationsMergeSize                     MetricConfig `mapstructure:"elasticsearch.index.operations.merge.size"`
	ElasticsearchIndexOperationsTime                          MetricConfig `mapstructure:"elasticsearch.index.operations.time"`
	ElasticsearchIndexSegmentsCount                           MetricConfig `mapstructure:"elasticsearch.index.segments.count"`
	ElasticsearchIndexSegmentsMemory                          MetricConfig `mapstructure:"elasticsearch.index.segments.memory"`
	ElasticsearchIndexSegmentsSize                            MetricConfig `mapstructure:"elasticsearch.index.segments.size"`
	ElasticsearchIndexShardsSize                              MetricConfig `mapstructure:"elasticsearch.index.shards.size"`
	ElasticsearchIndexTranslogOperations                      MetricConfig `mapstructure:"elasticsearch.index.translog.operations"`
	ElasticsearchIndexTranslogSize                            MetricConfig `mapstructure:"elasticsearch.index.translog.size"`
	ElasticsearchIndexingPressureMemoryLimit                  MetricConfig `mapstructure:"elasticsearch.indexing_pressure.memory.limit"`
	ElasticsearchIndexingPressureMemoryTotalPrimaryRejections MetricConfig `mapstructure:"elasticsearch.indexing_pressure.memory.total.primary_rejections"`
	ElasticsearchIndexingPressureMemoryTotalReplicaRejections MetricConfig `mapstructure:"elasticsearch.indexing_pressure.memory.total.replica_rejections"`
	ElasticsearchMemoryIndexingPressure                       MetricConfig `mapstructure:"elasticsearch.memory.indexing_pressure"`
	ElasticsearchNodeCacheCount                               MetricConfig `mapstructure:"elasticsearch.node.cache.count"`
	ElasticsearchNodeCacheEvictions                           MetricConfig `mapstructure:"elasticsearch.node.cache.evictions"`
	ElasticsearchNodeCacheMemoryUsage                         MetricConfig `mapstructure:"elasticsearch.node.cache.memory.usage"`
	ElasticsearchNodeCacheSize                                MetricConfig `mapstructure:"elasticsearch.node.cache.size"`
	ElasticsearchNodeClusterConnections                       MetricConfig `mapstructure:"elasticsearch.node.cluster.connections"`
	ElasticsearchNodeClusterIo                                MetricConfig `mapstructure:"elasticsearch.node.cluster.io"`
	ElasticsearchNodeDiskIoRead                               MetricConfig `mapstructure:"elasticsearch.node.disk.io.read"`
	ElasticsearchNodeDiskIoWrite                              MetricConfig `mapstructure:"elasticsearch.node.disk.io.write"`
	ElasticsearchNodeDocuments                                MetricConfig `mapstructure:"elasticsearch.node.documents"`
	ElasticsearchNodeFsDiskAvailable                          MetricConfig `mapstructure:"elasticsearch.node.fs.disk.available"`
	ElasticsearchNodeFsDiskFree                               MetricConfig `mapstructure:"elasticsearch.node.fs.disk.free"`
	ElasticsearchNodeFsDiskTotal                              MetricConfig `mapstructure:"elasticsearch.node.fs.disk.total"`
	ElasticsearchNodeHTTPConnections                          MetricConfig `mapstructure:"elasticsearch.node.http.connections"`
	ElasticsearchNodeIngestDocuments                          MetricConfig `mapstructure:"elasticsearch.node.ingest.documents"`
	ElasticsearchNodeIngestDocumentsCurrent                   MetricConfig `mapstructure:"elasticsearch.node.ingest.documents.current"`
	ElasticsearchNodeIngestOperationsFailed                   MetricConfig `mapstructure:"elasticsearch.node.ingest.operations.failed"`
	ElasticsearchNodeOpenFiles                                MetricConfig `mapstructure:"elasticsearch.node.open_files"`
	ElasticsearchNodeOperationsCompleted                      MetricConfig `mapstructure:"elasticsearch.node.operations.completed"`
	ElasticsearchNodeOperationsCurrent                        MetricConfig `mapstructure:"elasticsearch.node.operations.current"`
	ElasticsearchNodeOperationsGetCompleted                   MetricConfig `mapstructure:"elasticsearch.node.operations.get.completed"`
	ElasticsearchNodeOperationsGetTime                        MetricConfig `mapstructure:"elasticsearch.node.operations.get.time"`
	ElasticsearchNodeOperationsTime                           MetricConfig `mapstructure:"elasticsearch.node.operations.time"`
	ElasticsearchNodePipelineIngestDocumentsCurrent           MetricConfig `mapstructure:"elasticsearch.node.pipeline.ingest.documents.current"`
	ElasticsearchNodePipelineIngestDocumentsPreprocessed      MetricConfig `mapstructure:"elasticsearch.node.pipeline.ingest.documents.preprocessed"`
	ElasticsearchNodePipelineIngestOperationsFailed           MetricConfig `mapstructure:"elasticsearch.node.pipeline.ingest.operations.failed"`
	ElasticsearchNodeScriptCacheEvictions                     MetricConfig `mapstructure:"elasticsearch.node.script.cache_evictions"`
	ElasticsearchNodeScriptCompilationLimitTriggered          MetricConfig `mapstructure:"elasticsearch.node.script.compilation_limit_triggered"`
	ElasticsearchNodeScriptCompilations                       MetricConfig `mapstructure:"elasticsearch.node.script.compilations"`
	ElasticsearchNodeSegmentsMemory                           MetricConfig `mapstructure:"elasticsearch.node.segments.memory"`
	ElasticsearchNodeShardsDataSetSize                        MetricConfig `mapstructure:"elasticsearch.node.shards.data_set.size"`
	ElasticsearchNodeShardsReservedSize                       MetricConfig `mapstructure:"elasticsearch.node.shards.reserved.size"`
	ElasticsearchNodeShardsSize                               MetricConfig `mapstructure:"elasticsearch.node.shards.size"`
	ElasticsearchNodeThreadPoolTasksFinished                  MetricConfig `mapstructure:"elasticsearch.node.thread_pool.tasks.finished"`
	ElasticsearchNodeThreadPoolTasksQueued                    MetricConfig `mapstructure:"elasticsearch.node.thread_pool.tasks.queued"`
	ElasticsearchNodeThreadPoolThreads                        MetricConfig `mapstructure:"elasticsearch.node.thread_pool.threads"`
	ElasticsearchNodeTranslogOperations                       MetricConfig `mapstructure:"elasticsearch.node.translog.operations"`
	ElasticsearchNodeTranslogSize                             MetricConfig `mapstructure:"elasticsearch.node.translog.size"`
	ElasticsearchNodeTranslogUncommittedSize                  MetricConfig `mapstructure:"elasticsearch.node.translog.uncommitted.size"`
	ElasticsearchOsCPULoadAvg15m                              MetricConfig `mapstructure:"elasticsearch.os.cpu.load_avg.15m"`
	ElasticsearchOsCPULoadAvg1m                               MetricConfig `mapstructure:"elasticsearch.os.cpu.load_avg.1m"`
	ElasticsearchOsCPULoadAvg5m                               MetricConfig `mapstructure:"elasticsearch.os.cpu.load_avg.5m"`
	ElasticsearchOsCPUUsage                                   MetricConfig `mapstructure:"elasticsearch.os.cpu.usage"`
	ElasticsearchOsMemory                                     MetricConfig `mapstructure:"elasticsearch.os.memory"`
	ElasticsearchProcessCPUTime                               MetricConfig `mapstructure:"elasticsearch.process.cpu.time"`
	ElasticsearchProcessCPUUsage                              MetricConfig `mapstructure:"elasticsearch.process.cpu.usage"`
	ElasticsearchProcessMemoryVirtual                         MetricConfig `mapstructure:"elasticsearch.process.memory.virtual"`
	JvmClassesLoaded                                          MetricConfig `mapstructure:"jvm.classes.loaded"`
	JvmGcCollectionsCount                                     MetricConfig `mapstructure:"jvm.gc.collections.count"`
	JvmGcCollectionsElapsed                                   MetricConfig `mapstructure:"jvm.gc.collections.elapsed"`
	JvmMemoryHeapCommitted                                    MetricConfig `mapstructure:"jvm.memory.heap.committed"`
	JvmMemoryHeapMax                                          MetricConfig `mapstructure:"jvm.memory.heap.max"`
	JvmMemoryHeapUsed                                         MetricConfig `mapstructure:"jvm.memory.heap.used"`
	JvmMemoryHeapUtilization                                  MetricConfig `mapstructure:"jvm.memory.heap.utilization"`
	JvmMemoryNonheapCommitted                                 MetricConfig `mapstructure:"jvm.memory.nonheap.committed"`
	JvmMemoryNonheapUsed                                      MetricConfig `mapstructure:"jvm.memory.nonheap.used"`
	JvmMemoryPoolMax                                          MetricConfig `mapstructure:"jvm.memory.pool.max"`
	JvmMemoryPoolUsed                                         MetricConfig `mapstructure:"jvm.memory.pool.used"`
	JvmThreadsCount                                           MetricConfig `mapstructure:"jvm.threads.count"`
}

MetricsConfig provides config for elasticsearch metrics.

func DefaultMetricsConfig added in v0.77.0

func DefaultMetricsConfig() MetricsConfig

type ResourceAttributeConfig added in v0.77.0

type ResourceAttributeConfig struct {
	Enabled bool `mapstructure:"enabled"`
	// Experimental: MetricsInclude defines a list of filters for attribute values.
	// If the list is not empty, only metrics with matching resource attribute values will be emitted.
	MetricsInclude []filter.Config `mapstructure:"metrics_include"`
	// Experimental: MetricsExclude defines a list of filters for attribute values.
	// If the list is not empty, metrics with matching resource attribute values will not be emitted.
	// MetricsInclude has higher priority than MetricsExclude.
	MetricsExclude []filter.Config `mapstructure:"metrics_exclude"`
	// contains filtered or unexported fields
}

ResourceAttributeConfig provides common config for a particular resource attribute.

func (*ResourceAttributeConfig) Unmarshal added in v0.87.0

func (rac *ResourceAttributeConfig) Unmarshal(parser *confmap.Conf) error

type ResourceAttributesConfig added in v0.77.0

type ResourceAttributesConfig struct {
	ElasticsearchClusterName ResourceAttributeConfig `mapstructure:"elasticsearch.cluster.name"`
	ElasticsearchIndexName   ResourceAttributeConfig `mapstructure:"elasticsearch.index.name"`
	ElasticsearchNodeName    ResourceAttributeConfig `mapstructure:"elasticsearch.node.name"`
	ElasticsearchNodeVersion ResourceAttributeConfig `mapstructure:"elasticsearch.node.version"`
}

ResourceAttributesConfig provides config for elasticsearch resource attributes.

func DefaultResourceAttributesConfig added in v0.77.0

func DefaultResourceAttributesConfig() ResourceAttributesConfig

type ResourceBuilder added in v0.82.0

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

ResourceBuilder is a helper struct to build resources predefined in metadata.yaml. The ResourceBuilder is not thread-safe and must not to be used in multiple goroutines.

func NewResourceBuilder added in v0.82.0

func NewResourceBuilder(rac ResourceAttributesConfig) *ResourceBuilder

NewResourceBuilder creates a new ResourceBuilder. This method should be called on the start of the application.

func (*ResourceBuilder) Emit added in v0.82.0

func (rb *ResourceBuilder) Emit() pcommon.Resource

Emit returns the built resource and resets the internal builder state.

func (*ResourceBuilder) SetElasticsearchClusterName added in v0.82.0

func (rb *ResourceBuilder) SetElasticsearchClusterName(val string)

SetElasticsearchClusterName sets provided value as "elasticsearch.cluster.name" attribute.

func (*ResourceBuilder) SetElasticsearchIndexName added in v0.82.0

func (rb *ResourceBuilder) SetElasticsearchIndexName(val string)

SetElasticsearchIndexName sets provided value as "elasticsearch.index.name" attribute.

func (*ResourceBuilder) SetElasticsearchNodeName added in v0.82.0

func (rb *ResourceBuilder) SetElasticsearchNodeName(val string)

SetElasticsearchNodeName sets provided value as "elasticsearch.node.name" attribute.

func (*ResourceBuilder) SetElasticsearchNodeVersion added in v0.82.0

func (rb *ResourceBuilder) SetElasticsearchNodeVersion(val string)

SetElasticsearchNodeVersion sets provided value as "elasticsearch.node.version" attribute.

type ResourceMetricsOption added in v0.52.0

type ResourceMetricsOption func(pmetric.ResourceMetrics)

ResourceMetricsOption applies changes to provided resource metrics.

func WithResource added in v0.82.0

func WithResource(res pcommon.Resource) ResourceMetricsOption

WithResource sets the provided resource on the emitted ResourceMetrics. It's recommended to use ResourceBuilder to create the resource.

func WithStartTimeOverride added in v0.52.0

func WithStartTimeOverride(start pcommon.Timestamp) ResourceMetricsOption

WithStartTimeOverride overrides start time for all the resource metrics data points. This option should be only used if different start time has to be set on metrics coming from different resources.

Jump to

Keyboard shortcuts

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