prometheus-net 8.0.0-pre-000351-fb39dcb

prometheus-net

This is a .NET library for instrumenting your applications and exporting metrics to Prometheus.

Build status Nuget Nuget

The library targets the following runtimes (and newer):

  • .NET Framework 4.6.2
  • .NET 6.0

Table of contents

Best practices and usage

This library allows you to instrument your code with custom metrics and provides some built-in metric collection integrations for ASP.NET Core.

The documentation here is only a minimal quick start. For detailed guidance on using Prometheus in your solutions, refer to the prometheus-users discussion group. You are also expected to be familiar with the Prometheus user guide. /r/PrometheusMonitoring on Reddit may also prove a helpful resource.

Four types of metrics are available: Counter, Gauge, Summary and Histogram. See the documentation on metric types and instrumentation best practices to learn what each is good for.

The Metrics class is the main entry point to the API of this library. The most common practice in C# code is to have a static readonly field for each metric that you wish to export from a given class.

More complex patterns may also be used (e.g. combining with dependency injection). The library is quite tolerant of different usage models - if the API allows it, it will generally work fine and provide satisfactory performance. The library is thread-safe.

Quick start

After installing the library, you should:

  1. Collect some metrics, either by using built-in integrations or publishing your own custom metrics.
  2. Export the collected metrics over an HTTP endpoint (typically /metrics).
  3. Configure a Prometheus server to poll this endpoint for metrics on a regular interval.

Minimal sample app (based on .NET 6 Console app template):

using var server = new Prometheus.KestrelMetricServer(port: 1234);
server.Start();

Console.WriteLine("Open http://localhost:1234/metrics in a web browser.");
Console.WriteLine("Press enter to exit.");
Console.ReadLine();

Refer to the sample projects for quick start instructions:

Name Description
Sample.Web ASP.NET Core application that produces custom metrics and uses multiple integrations to publish built-in metrics
Sample.Console .NET console application that exports custom metrics
Sample.Console.DotNetMeters Demonstrates how to publish custom metrics via the .NET Meters API
Sample.Console.Exemplars .NET console application that attaches exemplars to some metrics
Sample.Console.NetFramework Same as above but targeting .NET Framework
Sample.Console.NoAspNetCore .NET console application that exports custom metrics without requiring the ASP.NET Core runtime to be installed
Sample.Grpc ASP.NET Core application that publishes a gRPC service
Sample.Grpc.Client Client app for the above
Sample.NetStandard Demonstrates how to reference prometheus-net in a .NET Standard class library
Sample.Web.DifferentPort Demonstrates how to set up the metric exporter on a different port from the main web API (e.g. for security purposes)
Sample.Web.MetricExpiration Demonstrates how to use automatic metric deletion
Sample.Web.NetFramework .NET Framework web app that publishes custom metrics

The rest of this document describes how to use individual features of the library.

Installation

Nuget package for general use and metrics export via HttpListener or to Pushgateway: prometheus-net

Install-Package prometheus-net

Nuget package for ASP.NET Core middleware and stand-alone Kestrel metrics server: prometheus-net.AspNetCore

Install-Package prometheus-net.AspNetCore

Nuget package for ASP.NET Core Health Check integration: prometheus-net.AspNetCore.HealthChecks

Install-Package prometheus-net.AspNetCore.HealthChecks

Nuget package for ASP.NET Core gRPC integration: prometheus-net.AspNetCore.Grpc

Install-Package prometheus-net.AspNetCore.Grpc

Nuget package for ASP.NET Web API middleware on .NET Framework: prometheus-net.NetFramework.AspNet

Install-Package prometheus-net.NetFramework.AspNet

Counters

Counters only increase in value and reset to zero when the process restarts.

private static readonly Counter ProcessedJobCount = Metrics
    .CreateCounter("myapp_jobs_processed_total", "Number of processed jobs.");

...

ProcessJob();
ProcessedJobCount.Inc();

Gauges

Gauges can have any numeric value and change arbitrarily.

private static readonly Gauge JobsInQueue = Metrics
    .CreateGauge("myapp_jobs_queued", "Number of jobs waiting for processing in the queue.");

...

jobQueue.Enqueue(job);
JobsInQueue.Inc();

...

var job = jobQueue.Dequeue();
JobsInQueue.Dec();

Histogram

Histograms track the size and number of events in buckets. This allows for aggregatable calculation of quantiles.

private static readonly Histogram OrderValueHistogram = Metrics
    .CreateHistogram("myapp_order_value_usd", "Histogram of received order values (in USD).",
        new HistogramConfiguration
        {
            // We divide measurements in 10 buckets of $100 each, up to $1000.
            Buckets = Histogram.LinearBuckets(start: 100, width: 100, count: 10)
        });

...

OrderValueHistogram.Observe(order.TotalValueUsd);

Summary

Summaries track the trends in events over time (10 minutes by default).

private static readonly Summary RequestSizeSummary = Metrics
    .CreateSummary("myapp_request_size_bytes", "Summary of request sizes (in bytes) over last 10 minutes.");

...

RequestSizeSummary.Observe(request.Length);

By default, only the sum and total count are reported. You may also specify quantiles to measure:

private static readonly Summary RequestSizeSummary = Metrics
    .CreateSummary("myapp_request_size_bytes", "Summary of request sizes (in bytes) over last 10 minutes.",
        new SummaryConfiguration
        {
            Objectives = new[]
            {
                new QuantileEpsilonPair(0.5, 0.05),
                new QuantileEpsilonPair(0.9, 0.05),
                new QuantileEpsilonPair(0.95, 0.01),
                new QuantileEpsilonPair(0.99, 0.005),
            }
        });

The epsilon indicates the absolute error allowed in measurements. For more information, refer to the Prometheus documentation on summaries and histograms.

Measuring operation duration

Timers can be used to report the duration of an operation (in seconds) to a Summary, Histogram, Gauge or Counter. Wrap the operation you want to measure in a using block.

private static readonly Histogram LoginDuration = Metrics
    .CreateHistogram("myapp_login_duration_seconds", "Histogram of login call processing durations.");

...

using (LoginDuration.NewTimer())
{
    IdentityManager.AuthenticateUser(Request.Credentials);
}

Tracking in-progress operations

You can use Gauge.TrackInProgress() to track how many concurrent operations are taking place. Wrap the operation you want to track in a using block.

private static readonly Gauge DocumentImportsInProgress = Metrics
    .CreateGauge("myapp_document_imports_in_progress", "Number of import operations ongoing.");

...

using (DocumentImportsInProgress.TrackInProgress())
{
    DocumentRepository.ImportDocument(path);
}

Counting exceptions

You can use Counter.CountExceptions() to count the number of exceptions that occur while executing some code.

private static readonly Counter FailedDocumentImports = Metrics
    .CreateCounter("myapp_document_imports_failed_total", "Number of import operations that failed.");

...

FailedDocumentImports.CountExceptions(() => DocumentRepository.ImportDocument(path));

You can also filter the exception types to observe:

FailedDocumentImports.CountExceptions(() => DocumentRepository.ImportDocument(path), IsImportRelatedException);

bool IsImportRelatedException(Exception ex)
{
    // Do not count "access denied" exceptions - those are user error for pointing us to a forbidden file.
    if (ex is UnauthorizedAccessException)
        return false;

    return true;
}

Labels

All metrics can have labels, allowing grouping of related time series.

See the best practices on naming and labels.

Taking a counter as an example:

private static readonly Counter RequestCountByMethod = Metrics
    .CreateCounter("myapp_requests_total", "Number of requests received, by HTTP method.", labelNames: new[] { "method" });

...

// You can specify the values for the labels later, once you know the right values (e.g in your request handler code).
RequestCountByMethod.WithLabels("GET").Inc();

NB! Best practices of metric design is to minimize the number of different label values. For example:

  • HTTP request method is a good choice for labeling - there are not many values.
  • URL is a bad choice for labeling - it has many possible values and would lead to significant data processing inefficiency.

Static labels

You can add static labels that always have fixed values. This is possible on two levels:

  • on the metrics registry (e.g. Metrics.DefaultRegistry)
  • on a metric factory (e.g. Metrics.WithLabels())

All levels of labeling can be combined and instance-specific metric labels can also be applied on top, as usual.

Example with static labels on two levels and one instance-specific label:

Metrics.DefaultRegistry.SetStaticLabels(new Dictionary<string, string>
{
  // Labels applied to all metrics in the registry.
  { "environment", "testing" }
});

var backgroundServicesMetricFactory = Metrics.WithLabels(new Dictionary<string, string>
{
  // Labels applied to all metrics created via this factory.
  { "category", "background-services" }
});

var requestsHandled = backgroundServicesMetricFactory
  .CreateCounter("myapp_requests_handled_total", "Count of requests handled, labelled by response code.", labelNames: new[] { "response_code" });

// Labels applied to individual instances of the metric.
requestsHandled.WithLabels("404").Inc();
requestsHandled.WithLabels("200").Inc();

Exemplars

Exemplars facilitate distributed tracing, by attaching related trace IDs to metrics. This enables a metrics GUI to cross-references traces that explain how the metric got the value it has.

By default, prometheus-net will create an exemplar with the trace_id and span_id labels from the current .NET distributed tracing context (Activity.Current). To override this, provide your own exemplar when updating the value of the metric:

private static readonly Counter RecordsProcessed = Metrics
    .CreateCounter("sample_records_processed_total", "Total number of records processed.");

// The key from an exemplar key-value pair should be created once and reused to minimize memory allocations.
private static readonly Exemplar.LabelKey RecordIdKey = Exemplar.Key("record_id");
...

foreach (var record in recordsToProcess)
{
    var recordIdKeyValuePair = RecordIdKey.WithValue(record.Id.ToString());
    RecordsProcessed.Inc(recordIdKeyValuePair);
}

Exemplars are only present if the metrics are being scraped by an OpenMetrics-capable client. For development purposes, you can force the library to use the OpenMetrics exposition format by adding ?accept=application/openmetrics-text to the /metrics URL. The Prometheus database automatically negotiates OpenMetrics support when scraping metrics - you do not need to take any special action in production scenarios.

Warning Exemplars are limited to 128 bytes - they are meant to contain IDs for cross-referencing with trace databases, not as a replacement for trace databases.

See also, Sample.Console.Exemplars.

When are metrics published?

Metrics without labels are published immediately after the Metrics.CreateX() call. Metrics that use labels are published when you provide the label values for the first time.

Sometimes you want to delay publishing a metric until you have loaded some data and have a meaningful value to supply for it. The API allows you to suppress publishing of the initial value until you decide the time is right.

private static readonly Gauge UsersLoggedIn = Metrics
    .CreateGauge("myapp_users_logged_in", "Number of active user sessions",
        new GaugeConfiguration
        {
            SuppressInitialValue = true
        });

...

// After setting the value for the first time, the metric becomes published.
UsersLoggedIn.Set(LoadSessions().Count);

You can also use .Publish() on a metric to mark it as ready to be published without modifying the initial value (e.g. to publish a zero). Conversely, you can use .Unpublish() to hide a metric temporarily. Note that the metric remains in memory and retains its value.

Deleting metrics

You can use .Dispose() or .RemoveLabelled() methods on the metric classes to manually delete metrics at any time.

In some situations, it can be hard to determine when a metric with a specific set of labels becomes irrelevant and needs to be removed. The library provides some assistance here by enabling automatic expiration of metrics when they are no longer used.

To enable automatic expiration, create the metrics via the metric factory returned by Metrics.WithManagedLifetime(). All such metrics will have a fixed expiration time, with the expiration restarting based on certain conditions that indicate the metric is in use.

Option 1: metric lifetime can be controlled by leases - the metric expiration timer starts when the last lease is released (and will be reset when a new lease is taken again).

var factory = Metrics.WithManagedLifetime(expiresAfter: TimeSpan.FromMinutes(5));

// With expiring metrics, we get back handles to the metric, not the metric directly.
var inProgressHandle = expiringMetricFactory
  .CreateGauge("documents_in_progress", "Number of documents currently being processed.",
    // Automatic metric deletion only makes sense if we have a high/unknown cardinality label set,
    // so here is a sample label for each "document provider", whoever that may be.
    labelNames: new[] { "document_provider" });

...

public void ProcessDocument(string documentProvider)
{
  // Automatic metric deletion will not occur while this lease is held.
  // This will also reset any existing expiration timer for this document provider.
  inProgressHandle.WithLease(metric =>
  {
    using (metric.TrackInProgress())
      DoDocumentProcessingWork();
  }, documentProvider);
  // Lease is released here.
  // If this was the last lease for this document provider, the expiration timer will now start.
}

Scenario 2: sometimes managing the leases is not required because you simply want the metric lifetime to be extended whenever the value is updated.

var factory = Metrics.WithManagedLifetime(expiresAfter: TimeSpan.FromMinutes(5));

// With expiring metrics, we get back handles to the metric, not the metric directly.
var processingStartedHandle = expiringMetricFactory
  .CreateGauge("documents_started_processing_total", "Number of documents for which processing has started.",
    // Automatic metric deletion only makes sense if we have a high/unknown cardinality label set,
    // so here is a sample label for each "document provider", whoever that may be.
    labelNames: new[] { "document_provider" });

// This returns a metric instance that will reset the expiration timer whenever the metric value is updated.
var processingStarted = processingStartedHandle.WithExtendLifetimeOnUse();

...

public void ProcessDocument(string documentProvider)
{
  // This will reset the expiration timer for this document provider.
  processingStarted.WithLabels(documentProvider).Inc();

  DoDocumentProcessingWork();
}

The expiration logic is scoped to the factory. Multiple handles for the same metric from the same factory will share their expiration logic. However, handles for the same metric from different factories will have independent expiration logic.

See also, Sample.Web.MetricExpiration.

ASP.NET Core exporter middleware

For projects built with ASP.NET Core, a middleware plugin is provided.

If you use the default Visual Studio project templates, modify the UseEndpoints call as follows:

  • Add endpoints.MapMetrics() anywhere in the delegate body.
public void Configure(IApplicationBuilder app, ...)
{
    // ...

    app.UseEndpoints(endpoints =>
    {
        // ...

        endpoints.MapMetrics();
    });
}

The default configuration will publish metrics on the /metrics URL.

The ASP.NET Core functionality is delivered in the prometheus-net.AspNetCore NuGet package.

See also, Sample.Web.

ASP.NET Core HTTP request metrics

The library exposes some metrics from ASP.NET Core applications:

  • Number of HTTP requests in progress.
  • Total number of received HTTP requests.
  • Duration of HTTP requests.

The ASP.NET Core functionality is delivered in the prometheus-net.AspNetCore NuGet package.

You can expose HTTP metrics by modifying your Startup.Configure() method:

  • After app.UseRouting() add app.UseHttpMetrics().

Example Startup.cs:

public void Configure(IApplicationBuilder app, ...)
{
    // ...

    app.UseRouting();
    app.UseHttpMetrics();

    // ...
}

By default, metrics are collected separately for each response status code (200, 201, 202, 203, ...). You can considerably reduce the size of the data set by only preserving information about the first digit of the status code:

app.UseHttpMetrics(options =>
{
    // This will preserve only the first digit of the status code.
    // For example: 200, 201, 203 -> 2xx
    options.ReduceStatusCodeCardinality();
});

NB! Exception handler middleware that changes HTTP response codes must be registered after UseHttpMetrics() in order to ensure that prometheus-net reports the correct HTTP response status code.

The action, controller and endpoint route parameters are always captured by default. If Razor Pages is in use, the page label will be captured to show the path to the page.

You can include additional route parameters as follows:

app.UseHttpMetrics(options =>
{
    // Assume there exists a custom route parameter with this name.
    options.AddRouteParameter("api-version");
});

You can also extract arbitrary data from the HttpContext into label values as follows:

app.UseHttpMetrics(options =>
{
    options.AddCustomLabel("host", context => context.Request.Host.Host);
});

See also, Sample.Web.

ASP.NET Core gRPC request metrics

The library allows you to expose some metrics from ASP.NET Core gRPC services. These metrics include labels for service and method name.

You can expose gRPC metrics by modifying your Startup.Configure() method:

  • After app.UseRouting() add app.UseGrpcMetrics().

Example Startup.cs:

public void Configure(IApplicationBuilder app, ...)
{
    // ...

    app.UseRouting();
    app.UseGrpcMetrics();

    // ...
}

The gRPC functionality is delivered in the prometheus-net.AspNetCore.Grpc NuGet package.

See also, Sample.Grpc.

IHttpClientFactory metrics

This library allows you to expose metrics about HttpClient instances created using IHttpClientFactory.

The exposed metrics include:

  • Number of HTTP requests in progress.
  • Total number of started HTTP requests.
  • Duration of HTTP client requests (from start of request to end of reading response headers).
  • Duration of HTTP client responses (from start of request to end of reading response body).

Example Startup.cs modification to enable these metrics:

public void ConfigureServices(IServiceCollection services)
{
    // ...

    services.AddHttpClient(Options.DefaultName)
        .UseHttpClientMetrics();

    // ...
}

See also, Sample.Web.

ASP.NET Core health check status metrics

You can expose the current status of ASP.NET Core health checks as Prometheus metrics by extending your IHealthChecksBuilder in the Startup.ConfigureServices() method:

public void ConfigureServices(IServiceCollection services, ...)
{
    // ...

    services.AddHealthChecks()
        // ...
        <Your Health Checks>
        // ...
        .ForwardToPrometheus();

    // ...
}

The status of each health check will be published in the aspnetcore_healthcheck_status metric.

The ASP.NET Core health check integration is delivered in the prometheus-net.AspNetCore.HealthChecks NuGet package.

See also, Sample.Web.

Protecting the metrics endpoint from unauthorized access

You may wish to restrict access to the metrics export URL. Documentation on how to apply ASP.NET Core security mechanisms is beyond the scope of this readme file but a good starting point may be to require an authorization policy to be satisfied for accessing the endpoint

app.UseEndpoints(endpoints =>
{
    // ...

    // Assumes that you have previously configured the "ReadMetrics" policy (not shown).
    endpoints.MapMetrics().RequireAuthorization("ReadMetrics");
});

Another commonly used option is to expose a separate web server endpoint (e.g. a new KestrelMetricServer instance) on a different port, with firewall rules limiting access to only certain IP addresses. Refer to the sample project Sample.Web.DifferentPort.

ASP.NET Web API exporter

The easiest way to export metrics from an ASP.NET Web API app on the full .NET Framework is to use AspNetMetricServer in your Global.asax.cs file. Insert the following line to the top of the Application_Start method:

protected void Application_Start(object sender, EventArgs e)
{
    AspNetMetricServer.RegisterRoutes(GlobalConfiguration.Configuration);

    // Other code follows.
}

The above snippet exposes metrics on the /metrics URL.

The AspNetMetricServer class is provided by the prometheus-net.NetFramework.AspNet NuGet package.

Kestrel stand-alone server

In some situation, you may wish to start a stand-alone metric server using Kestrel (e.g. if your app has no other HTTP-accessible functionality).

var metricServer = new KestrelMetricServer(port: 1234);
metricServer.Start();

The default configuration will publish metrics on the /metrics URL.

If your app is an ASP.NET Core web app, you can use a pipeline-integrated mechanism:

services.AddMetricServer(options =>
{
    options.Port = 1234;
});

Publishing to Pushgateway

Metrics can be posted to a Pushgateway server.

var pusher = new MetricPusher(new MetricPusherOptions
{
    Endpoint = "https://pushgateway.example.org:9091/metrics",
    Job = "some_job"
});

pusher.Start();

Note that the default behavior of the metric pusher is to append metrics. You can use MetricPusherOptions.ReplaceOnPush to make it replace existing metrics in the same group, removing any that are no longer pushed.

Publishing to Pushgateway with basic authentication

You can use a custom HttpClient to supply credentials for the Pushgateway.

// Placeholder username and password here - replace with your own data.
var headerValue = Convert.ToBase64String(Encoding.UTF8.GetBytes("username:password"));
var httpClient = new HttpClient();
httpClient.DefaultRequestHeaders.Authorization = new AuthenticationHeaderValue("Basic", headerValue);

var pusher = new MetricPusher(new MetricPusherOptions
{
    Endpoint =  "https://pushgateway.example.org:9091/metrics",
    Job = "some_job",
    HttpClientProvider = () => httpClient
});

pusher.Start();

Publishing via standalone HTTP handler

As a fallback option for scenarios where Kestrel or ASP.NET Core hosting is unsuitable, an HttpListener based metrics server implementation is also available.

var metricServer = new MetricServer(port: 1234);
metricServer.Start();

The default configuration will publish metrics on the /metrics URL.

MetricServer.Start() may throw an access denied exception on Windows if your user does not have the right to open a web server on the specified port. You can use the netsh command to grant yourself the required permissions:

netsh http add urlacl url=http://+:1234/metrics user=DOMAIN\user

Publishing raw metrics document

In scenarios where you handle publishing via a custom endpoint, you can export the entire metrics data set as a Prometheus text document.

await Metrics.DefaultRegistry.CollectAndExportAsTextAsync(outputStream);

Just-in-time updates

In some scenarios you may want to only collect data when it is requested by Prometheus. To easily implement this scenario prometheus-net enables you to register a callback before every collection occurs. Register your callback using Metrics.DefaultRegistry.AddBeforeCollectCallback().

Every callback will be executed before each collection, which will not finish until every callback has finished executing. Prometheus will expect each scrape to complete within a certain amount of seconds. To avoid timeouts, ensure that any registered callbacks execute quickly.

  • A synchronous callback (of type Action) should not take more than a few milliseconds. Do not read data from remote systems in these callbacks.
  • An asynchronous callback (of type Func<CancellationToken, Task>) is more suitable for long-running data collection work (lasting a few seconds). You can use asynchronous callbacks for reading data from remote systems.
Metrics.DefaultRegistry.AddBeforeCollectCallback(async (cancel) =>
{
    // Probe a remote system.
    var response = await httpClient.GetAsync("https://google.com", cancel);

    // Increase a counter by however many bytes we loaded.
    googlePageBytes.Inc(response.Content.Headers.ContentLength ?? 0);
});

Suppressing default metrics

The library enables various default metrics and integrations by default. If these default metrics are not desirable you may remove them by calling Metrics.SuppressDefaultMetrics() before registering any of your own metrics.

DiagnosticSource integration

.NET Core provides the DiagnosticSource mechanism for reporting diagnostic events, used widely by .NET and ASP.NET Core classes. To expose basic data on these events via Prometheus, you can use the DiagnosticSourceAdapter class:

// An optional "options" parameter is available to customize adapter behavior.
var registration = DiagnosticSourceAdapter.StartListening();

...

// Stops listening for DiagnosticSource events.
registration.Dispose();

Any events that occur are exported as Prometheus metrics, indicating the name of the event source and the name of the event:

diagnostic_events_total{source="Microsoft.AspNetCore",event="Microsoft.AspNetCore.Mvc.AfterAction"} 4
diagnostic_events_total{source="HttpHandlerDiagnosticListener",event="System.Net.Http.Request"} 8

The level of detail obtained from this is rather low - only the total count for each event is exported. For more fine-grained analytics, you need to listen to DiagnosticSource events on your own and create custom metrics that can understand the meaning of each particular type of event that is of interest to you.

EventCounter integration

Note The output produced by this integration has changed significantly between prometheus-net 6.0 and prometheus-net 7.0. The old output format is no longer supported.

.NET Core provides the EventCounter mechanism for reporting diagnostic events, used used widely by .NET and ASP.NET Core classes. This library publishes all .NET EventCounter data by default. To suppress this, see Suppressing default metrics.

You can configure the integration using Metrics.ConfigureEventCounterAdapter().

See also, Sample.Console.

.NET Meters integration

Note The output produced by this integration has changed significantly between prometheus-net 6.0 and prometheus-net 7.0. The old output format is no longer supported.

.NET provides the Meters mechanism for reporting diagnostic metrics. This library publishes all .NET Meters API data by default. To suppress this, see Suppressing default metrics.

You can configure the integration using Metrics.ConfigureMeterAdapter().

See also, Sample.Console.DotNetMeters.

Benchmarks

A suite of benchmarks is included if you wish to explore the performance characteristics of the app. Simply build and run the Benchmarks.NetCore project in Release mode.

As an example of the performance of measuring data using prometheus-net, we have the results of the MeasurementBenchmarks here:

BenchmarkDotNet=v0.13.2, OS=Windows 10 (10.0.19044.2006/21H2/November2021Update)
AMD Ryzen 9 5950X, 1 CPU, 32 logical and 16 physical cores
.NET SDK=7.0.100-rc.1.22431.12
  [Host]     : .NET 6.0.9 (6.0.922.41905), X64 RyuJIT AVX2

| MeasurementCount | ThreadCount | TargetMetricType |           Mean | Lock Contentions | Allocated |
|------------------|-------------|------------------|---------------:|-----------------:|----------:|
| 100000           | 1           | Counter          |       406.4 us |                - |     480 B |
| 100000           | 1           | Gauge            |       207.8 us |                - |     480 B |
| 100000           | 1           | Histogram        |     1,416.5 us |                - |     480 B |
| 100000           | 1           | Summary          |    42,601.8 us |                - |     480 B |
| 100000           | 16          | Counter          |   176,601.2 us |          13.0000 |     480 B |
| 100000           | 16          | Gauge            |    31,241.0 us |          14.0000 |     480 B |
| 100000           | 16          | Histogram        |   179,327.9 us |          14.0000 |     480 B |
| 100000           | 16          | Summary          | 1,017,871.1 us |       10332.0000 |     480 B |

Note The 480 byte allocation is benchmark harness overhead. Metric measurements do not allocate memory.

Converting this to more everyday units:

Metric type Concurrency Measurements per second
Counter 1 thread 246 million
Gauge 1 thread 481 million
Histogram 1 thread 71 million
Summary 1 thread 2 million
Counter 16 threads 9 million
Gauge 16 threads 51 million
Histogram 16 threads 9 million
Summary 16 threads 2 million

Note All measurements on all threads are recorded by the same metric instance, for maximum stress and concurrent load. If you have more than 1 metric in your app, multithreaded performance will likely be similar to single-threaded performance.

Community projects

Some useful related projects are:

Note: to avoid confusion between "official" prometheus-net and community maintained packages, the prometheus-net namespace is protected on nuget.org. However, the prometheus-net.Contrib.* namespace allows package publishing by all authors.

Showing the top 20 packages that depend on prometheus-net.

Packages Downloads
KubernetesClient
Client library for the Kubernetes open source container orchestrator.
26
KubernetesClient
Client library for the Kubernetes open source container orchestrator.
27
KubernetesClient
Client library for the Kubernetes open source container orchestrator.
28
KubernetesClient
Client library for the Kubernetes open source container orchestrator.
29
KubernetesClient
Client library for the Kubernetes open source container orchestrator.
33
KubernetesClient
Client library for the Kubernetes open source container orchestrator.
34
KubernetesClient
Client library for the Kubernetes open source container orchestrator.
36

Version Downloads Last updated
8.2.1 36 02/09/2024
8.2.1-pre-240103185829-60e9106 24 02/15/2024
8.2.0 27 02/09/2024
8.2.0-pre-231205215128-a2c1c8f 29 02/15/2024
8.2.0-pre-231205134623-36b4750 25 02/15/2024
8.2.0-pre-231204222617-7837255 24 02/15/2024
8.2.0-pre-231204170437-99f640f 28 02/15/2024
8.2.0-pre-231204094406-885f52c 26 02/15/2024
8.2.0-pre-231204084751-4d19b42 27 02/15/2024
8.2.0-pre-231128134008-9a7dad2 28 02/15/2024
8.1.1 24 02/09/2024
8.1.1-pre-231128114341-17bb2a0 28 02/15/2024
8.1.0 27 01/21/2024
8.1.0-pre-231028004937-71a8668 28 12/03/2023
8.0.1 34 01/14/2024
8.0.1-pre-230718073955-ea794f6 27 12/23/2023
8.0.1-pre-230718042806-718dffc 27 12/27/2023
8.0.0 25 12/28/2023
8.0.0-pre-230212122408-a055f5b 41 01/03/2024
8.0.0-pre-230210074852-a7c1277 27 12/24/2023
8.0.0-pre-230209100041-c35ac64 27 12/10/2023
8.0.0-pre-230209074620-4f8f59c 24 01/08/2024
8.0.0-pre-230203154858-4bf76fb 26 02/15/2024
8.0.0-pre-230203125716-1813839 34 02/15/2024
8.0.0-pre-230203073826-06c2e2f 22 02/15/2024
8.0.0-pre-230201062733-ece2743 24 02/15/2024
8.0.0-pre-230127154206-9ec9e9b 27 12/25/2023
8.0.0-pre-230127124604-8b7c7e1 22 12/05/2023
8.0.0-pre-230127111923-d72115a 27 02/15/2024
8.0.0-pre-230127084218-90f4311 25 02/15/2024
8.0.0-pre-230127075825-bfc1041 29 01/04/2024
8.0.0-pre-230126143551-210a1ab 22 12/05/2023
8.0.0-pre-230119065217-312c2e9 26 12/25/2023
8.0.0-pre-230116052305-1ed397b 25 02/15/2024
8.0.0-pre-230102092516-2351266 27 12/25/2023
8.0.0-pre-230101195105-9f23889 28 12/22/2023
8.0.0-pre-230101084444-630935f 27 02/15/2024
8.0.0-pre-221231102537-13e7ac6 24 12/10/2023
8.0.0-pre-221231100152-fb39dcb 24 12/13/2023
8.0.0-pre-000351-fb39dcb 26 12/26/2023
8.0.0-pre-000347-e83cc87 26 12/25/2023
8.0.0-pre-000346-e83cc87 26 12/30/2023
8.0.0-pre-000342-4d6812e 36 12/23/2023
7.1.0-pre-000318-0479f53 33 02/11/2024
7.1.0-pre-000310-9c9e1e9 22 12/14/2023
7.1.0-pre-000307-f980713 30 12/22/2023
7.0.0 28 12/07/2023
7.0.0-pre-000305-75cc817 28 02/09/2024
7.0.0-pre-000304-cbb305a 30 12/25/2023
7.0.0-pre-000303-5a44ada 26 12/26/2023
7.0.0-pre-000301-06c5932 40 02/11/2024
7.0.0-pre-000298-4b8d3e7 60 01/12/2024
7.0.0-pre-000297-7068d28 26 12/26/2023
7.0.0-pre-000296-5b1a1c4 29 12/28/2023
7.0.0-pre-000294-486fcd8 38 01/13/2024
7.0.0-pre-000293-d13fe06 26 02/11/2024
7.0.0-pre-000292-88fbe2a 25 12/26/2023
7.0.0-pre-000288-4688bd3 27 02/11/2024
7.0.0-pre-000282-d90ebf3 22 02/09/2024
7.0.0-pre-000280-ce6d494 24 02/11/2024
7.0.0-pre-000277-6bc5023 25 01/06/2024
7.0.0-pre-000276-9e65611 27 01/02/2024
7.0.0-pre-000270-ee6c23e 22 02/09/2024
7.0.0-pre-000269-08d9f2c 25 02/09/2024
7.0.0-pre-000259-7317089 28 12/24/2023
7.0.0-pre-000244-66d82e6 27 12/27/2023
6.0.0 28 09/13/2022
6.0.0-pre-000234-4598e28 26 12/18/2023
6.0.0-pre-000233-0dd30d3 31 12/18/2023
6.0.0-pre-000231-38d45fa 42 12/04/2023
6.0.0-pre-000223-ab9edeb 27 12/31/2023
5.1.0-pre-000215-c81d12d 26 12/15/2023
5.0.2 30 02/09/2024
5.0.2-pre-000210-fbf24c8 27 02/09/2024
5.0.1 25 12/29/2023
5.0.1-pre-000202-59e0610 29 12/23/2023
5.0.0 23 02/09/2024
5.0.0-pre-000201-8d79f11 24 12/03/2023
5.0.0-pre-000200-0afede9 23 12/25/2023
4.3.0-pre-000199-35f4961 33 02/11/2024
4.3.0-pre-000198-79466f7 25 12/29/2023
4.2.0 28 02/09/2024
4.2.0-pre-000195-ec10b08 27 02/09/2024
4.2.0-pre-000194-7aacfb0 25 12/26/2023
4.1.1 23 12/04/2023
4.1.1-pre-000180-1cfbebb 26 12/07/2023
4.1.0 25 12/26/2023
4.1.0-pre-000179-9582014 27 12/30/2023
4.1.0-pre-000171-15be8f3 27 02/09/2024
4.0.0 27 12/31/2023
4.0.0-pre-000158-d425fff 24 12/25/2023
4.0.0-pre-000134-2fea549 27 02/11/2024
3.6.0 23 02/09/2024
3.6.0-pre-000131-673cfe2 44 01/01/2024
3.6.0-pre-000129-bd91778 25 02/11/2024
3.5.0 24 02/09/2024
3.5.0-pre-000099-ee2bdbd 24 12/04/2023
3.5.0-pre-000098-f9cb93e 23 12/20/2023
3.4.0 24 02/09/2024
3.4.0-pre-000084-e9d0f37 22 12/23/2023
3.4.0-pre-000082-546478d 33 02/11/2024
3.4.0-pre-000081-1712a44 25 02/11/2024
3.4.0-pre-000079-eff2a83 24 12/30/2023
3.4.0-pre-000078-34a900d 28 12/20/2023
3.4.0-pre-000077-0ace5bd 26 12/26/2023
3.4.0-pre-000067-701dfdc 28 12/04/2023
3.3.1-pre-000052-0842664 22 12/04/2023
3.3.0 29 12/03/2023
3.3.0-pre-000042-252e89c 27 02/11/2024
3.2.1 23 12/18/2023
3.2.1-pre-000036-696f4ab 29 12/16/2023
3.2.0 21 02/09/2024
3.2.0-pre-000035-8d4cf7d 29 02/11/2024
3.2.0-pre-000032-9939133 26 12/20/2023
3.2.0-pre-000028-abe3225 21 12/27/2023
3.2.0-pre-000027-29e0fce 23 02/09/2024
3.1.5-pre-000023-d29ca37 34 12/14/2023
3.1.5-pre-000021-8c7b328 30 02/09/2024
3.1.5-pre-000020-5a2fc50 21 02/11/2024
3.1.4 24 12/26/2023
3.1.4-pre-000016-95d0170 23 02/09/2024
3.1.3 24 12/05/2023
3.1.3-pre-000009-505a08e 26 02/09/2024
3.1.3-cb-000009-505a08e 27 02/07/2024
3.1.2 24 01/01/2024
3.1.2-pre-006681-4f8ce09 27 12/14/2023
3.1.1 25 01/02/2024
3.1.1-pre-006463-cd3cd18 22 12/27/2023
3.1.0 22 02/09/2024
3.1.0-pre-006304-959164e 25 12/18/2023
3.1.0-pre-006267-9aac888 27 12/31/2023
3.1.0-pre-006177-d35e0b8 29 12/26/2023
3.0.3 24 02/09/2024
3.0.2 23 02/09/2024
3.0.1 27 01/11/2024
3.0.0 23 01/04/2024
3.0.0-pre-005830-d9493da 31 12/17/2023
3.0.0-pre-005828-27b7100 29 12/18/2023
3.0.0-pre-005823-68ad8e2 44 12/20/2023
3.0.0-pre-005803-4289c4a 36 12/18/2023
3.0.0-pre-005801-6f306bc 35 12/03/2023
3.0.0-pre-005800-ec1da05 27 12/16/2023
3.0.0-pre-005795-6aca95b 27 01/18/2024
3.0.0-pre-005647-e277cbe 24 12/21/2023
2.1.3 26 12/05/2023
2.1.3-pre-005238-380e4ab 25 12/16/2023
2.1.2 37 02/09/2024
2.1.2-pre-005131-012bc01 26 12/23/2023
2.1.1-pre-004445-bc00b93 27 12/23/2023
2.1.0 26 12/31/2023
2.1.0-pre-003985-910fb52 26 02/11/2024
2.1.0-pre-003982-37c9f93 25 02/09/2024
2.0.0 32 02/09/2024
2.0.0-pre-003523-49de0a3 24 02/09/2024
2.0.0-pre-003112-3de1c34 28 12/28/2023
2.0.0-pre-003077-0447c86 25 12/15/2023
2.0.0-pre-003054-ffb96c7 30 12/09/2023
2.0.0-pre-003051-6f12a46 27 02/11/2024
2.0.0-pre-003009-4e26344 24 02/09/2024
2.0.0-pre-002968-9fcb8aa 32 12/21/2023
1.3.6-rc 27 01/10/2024
1.3.5 31 02/09/2024
1.3.4 29 02/09/2024
1.3.4-beta 25 02/09/2024
1.2.4 24 02/09/2024
1.2.3 31 01/12/2024
1.2.2.1 22 02/09/2024
1.1.4 32 02/09/2024
1.1.3 26 02/09/2024
1.1.2 24 02/09/2024
1.1.1 29 12/28/2023
1.1.0 26 01/17/2024
0.0.11 26 01/06/2024
0.0.10 26 12/26/2023
0.0.9 26 02/09/2024
0.0.8 24 02/09/2024
0.0.7 24 02/09/2024
0.0.6 25 02/09/2024
0.0.5 27 02/09/2024
0.0.3 24 02/09/2024