Tabnine Logo
MetricRegistry.meter
Code IndexAdd Tabnine to your IDE (free)

How to use
meter
method
in
com.codahale.metrics.MetricRegistry

Best Java code snippets using com.codahale.metrics.MetricRegistry.meter (Showing top 20 results out of 2,124)

origin: apache/incubator-druid

public DropwizardRowIngestionMeters()
{
 this.metricRegistry = new MetricRegistry();
 this.processed = metricRegistry.meter(PROCESSED);
 this.processedWithError = metricRegistry.meter(PROCESSED_WITH_ERROR);
 this.unparseable = metricRegistry.meter(UNPARSEABLE);
 this.thrownAway = metricRegistry.meter(THROWN_AWAY);
}
origin: Graylog2/graylog2-server

public NetflowMessageAggregationHandler(RemoteAddressCodecAggregator aggregator, MetricRegistry metricRegistry) {
  this.aggregator = aggregator;
  aggregationTimer = metricRegistry.timer("aggregationTime");
  invalidChunksMeter = metricRegistry.meter("invalidMessages");
}
origin: Graylog2/graylog2-server

public ByteBufMessageAggregationHandler(CodecAggregator aggregator, MetricRegistry metricRegistry) {
  this.aggregator = aggregator;
  aggregationTimer = metricRegistry.timer("aggregationTime");
  invalidChunksMeter = metricRegistry.meter("invalidMessages");
}
origin: Graylog2/graylog2-server

public EnvelopeMessageAggregationHandler(CodecAggregator aggregator, MetricRegistry metricRegistry) {
  this.aggregator = aggregator;
  aggregationTimer = metricRegistry.timer("aggregationTime");
  invalidChunksMeter = metricRegistry.meter("invalidMessages");
}
origin: Graylog2/graylog2-server

@Inject
public ElasticSearchOutput(MetricRegistry metricRegistry,
              Messages messages,
              Journal journal) {
  this.messages = messages;
  this.journal = journal;
  // Only constructing metrics here. write() get's another Core reference. (because this technically is a plugin)
  this.writes = metricRegistry.meter(WRITES_METRICNAME);
  this.failures = metricRegistry.meter(FAILURES_METRICNAME);
  this.processTime = metricRegistry.timer(PROCESS_TIME_METRICNAME);
  // Should be set in initialize once this becomes a real plugin.
  isRunning.set(true);
}
origin: Graylog2/graylog2-server

private Meter getIncomingMeter(String streamId) {
  Meter meter = this.streamIncomingMeters.get(streamId);
  if (meter == null) {
    meter = metricRegistry.meter(MetricRegistry.name(Stream.class, streamId, "incomingMessages"));
    this.streamIncomingMeters.put(streamId, meter);
  }
  return meter;
}
origin: Graylog2/graylog2-server

private Meter getStreamRuleTimeoutMeter(final String streamId) {
  Meter meter = this.streamRuleTimeoutMeters.get(streamId);
  if (meter == null) {
    meter = metricRegistry.meter(MetricRegistry.name(Stream.class, streamId, "ruleTimeouts"));
    this.streamRuleTimeoutMeters.put(streamId, meter);
  }
  return meter;
}
origin: Graylog2/graylog2-server

private Meter getExceptionMeter(String streamId) {
  Meter meter = this.streamExceptionMeters.get(streamId);
  if (meter == null) {
    meter = metricRegistry.meter(MetricRegistry.name(Stream.class, streamId, "matchingExceptions"));
    this.streamExceptionMeters.put(streamId, meter);
  }
  return meter;
}
origin: Graylog2/graylog2-server

  private Meter getStreamFaultsExceededMeter(final String streamId) {
    Meter meter = this.streamFaultsExceededMeters.get(streamId);
    if (meter == null) {
      meter = metricRegistry.meter(MetricRegistry.name(Stream.class, streamId, "faultsExceeded"));
      this.streamFaultsExceededMeters.put(streamId, meter);
    }

    return meter;
  }
}
origin: Graylog2/graylog2-server

@Inject
public DiscardMessageOutput(final Journal journal, final MetricRegistry metricRegistry) {
  this.journal = journal;
  this.messagesDiscarded = metricRegistry.meter(name(this.getClass(), "messagesDiscarded"));
  isRunning.set(true);
}
origin: Graylog2/graylog2-server

@Inject
public PipelineInterpreter(Journal journal,
              MetricRegistry metricRegistry,
              ConfigurationStateUpdater stateUpdater) {
  this.journal = journal;
  this.filteredOutMessages = metricRegistry.meter(name(ProcessBufferProcessor.class, "filteredOutMessages"));
  this.executionTime = metricRegistry.timer(name(PipelineInterpreter.class, "executionTime"));
  this.stateUpdater = stateUpdater;
}
origin: Graylog2/graylog2-server

@Inject
public Messages(MetricRegistry metricRegistry,
        JestClient client) {
  invalidTimestampMeter = metricRegistry.meter(name(Messages.class, "invalid-timestamps"));
  outputByteCounter = metricRegistry.counter(GlobalMetricNames.OUTPUT_TRAFFIC);
  systemTrafficCounter = metricRegistry.counter(GlobalMetricNames.SYSTEM_OUTPUT_TRAFFIC);
  this.client = client;
  // TODO: Magic number
  this.indexFailureQueue =  new LinkedBlockingQueue<>(1000);
}
origin: Graylog2/graylog2-server

/**
 * Register the metrics attached to this stage.
 *
 * @param metricRegistry the registry to add the metrics to
 */
public void registerMetrics(MetricRegistry metricRegistry, String pipelineId) {
  meterName = name(Pipeline.class, pipelineId, "stage", String.valueOf(stage()), "executed");
  executed = metricRegistry.meter(meterName);
}
origin: Graylog2/graylog2-server

private Meter registerLocalMeter(MetricRegistry metricRegistry,
                 String pipelineId,
                 String stageId, String type) {
  final String name = MetricRegistry.name(Rule.class, id(), pipelineId, stageId, type);
  metricNames.add(name);
  return metricRegistry.meter(name);
}
origin: Graylog2/graylog2-server

@AssistedInject
public ProcessBufferProcessor(MetricRegistry metricRegistry, OrderedMessageProcessors orderedMessageProcessors, OutputBuffer outputBuffer,
               @Assisted DecodingProcessor decodingProcessor, @DefaultStream Provider<Stream> defaultStreamProvider) {
  this.orderedMessageProcessors = orderedMessageProcessors;
  this.outputBuffer = outputBuffer;
  this.decodingProcessor = decodingProcessor;
  this.defaultStreamProvider = defaultStreamProvider;
  incomingMessages = metricRegistry.meter(name(ProcessBufferProcessor.class, "incomingMessages"));
  outgoingMessages = metricRegistry.meter(name(ProcessBufferProcessor.class, "outgoingMessages"));
  processTime = metricRegistry.timer(name(ProcessBufferProcessor.class, "processTime"));
}
origin: Graylog2/graylog2-server

private Meter registerGlobalMeter(MetricRegistry metricRegistry, String type) {
  final String name = MetricRegistry.name(Rule.class, id(), type);
  metricNames.add(name);
  return metricRegistry.meter(name);
}
origin: Graylog2/graylog2-server

/**
 * Register the metrics attached to this pipeline.
 *
 * @param metricRegistry the registry to add the metrics to
 */
public void registerMetrics(MetricRegistry metricRegistry) {
  if (id() != null) {
    metricName = MetricRegistry.name(Pipeline.class, id(), "executed");
    executed = metricRegistry.meter(metricName);
  }
}
origin: apache/storm

public static Meter meter(String name, WorkerTopologyContext context, String componentId, Integer taskId, String streamId) {
  String metricName = metricName(name, context.getStormId(), componentId, streamId, taskId, context.getThisWorkerPort());
  return REGISTRY.meter(metricName);
}
origin: Graylog2/graylog2-server

public MeteredMetricsFilter(MetricRegistry metricRegistry, ResourceInfo resourceInfo) {
  final Metered annotation = resourceInfo.getResourceMethod().getAnnotation(Metered.class);
  meter = metricRegistry.meter(chooseName(annotation.name(), annotation.absolute(), resourceInfo.getResourceMethod()));
}
@Override
origin: Graylog2/graylog2-server

public ExceptionMeteredMetricsFilter(MetricRegistry metricRegistry, ResourceInfo resourceInfo) {
  final ExceptionMetered annotation = resourceInfo.getResourceMethod().getAnnotation(ExceptionMetered.class);
  meter = metricRegistry.meter(chooseName(annotation.name(), annotation.absolute(), resourceInfo.getResourceMethod(), ExceptionMetered.DEFAULT_NAME_SUFFIX));
  exceptionClass = annotation.cause();
}
com.codahale.metricsMetricRegistrymeter

Javadoc

Return the Meter registered under this name; or create and register a new Meter if none is registered.

Popular methods of MetricRegistry

  • name
    Concatenates elements to form a dotted name, eliding any null values or empty strings.
  • timer
    Return the Timer registered under this name; or create and register a new Timer using the provided M
  • register
    Given a Metric, registers it under the given name.
  • <init>
    Creates a new MetricRegistry.
  • counter
    Return the Counter registered under this name; or create and register a new Counter using the provid
  • histogram
    Return the Histogram registered under this name; or create and register a new Histogram using the pr
  • remove
    Removes the metric with the given name.
  • getGauges
    Returns a map of all the gauges in the registry and their names which match the given filter.
  • getTimers
    Returns a map of all the timers in the registry and their names which match the given filter.
  • getMetrics
  • getCounters
    Returns a map of all the counters in the registry and their names which match the given filter.
  • getMeters
    Returns a map of all the meters in the registry and their names which match the given filter.
  • getCounters,
  • getMeters,
  • registerAll,
  • getHistograms,
  • removeMatching,
  • getNames,
  • addListener,
  • gauge,
  • removeListener

Popular in Java

  • Running tasks concurrently on multiple threads
  • putExtra (Intent)
  • getSystemService (Context)
  • notifyDataSetChanged (ArrayAdapter)
  • Kernel (java.awt.image)
  • URLEncoder (java.net)
    This class is used to encode a string using the format required by application/x-www-form-urlencoded
  • Enumeration (java.util)
    A legacy iteration interface.New code should use Iterator instead. Iterator replaces the enumeration
  • ThreadPoolExecutor (java.util.concurrent)
    An ExecutorService that executes each submitted task using one of possibly several pooled threads, n
  • JFrame (javax.swing)
  • JTextField (javax.swing)
  • Best IntelliJ plugins
Tabnine Logo
  • Products

    Search for Java codeSearch for JavaScript code
  • IDE Plugins

    IntelliJ IDEAWebStormVisual StudioAndroid StudioEclipseVisual Studio CodePyCharmSublime TextPhpStormVimGoLandRubyMineEmacsJupyter NotebookJupyter LabRiderDataGripAppCode
  • Company

    About UsContact UsCareers
  • Resources

    FAQBlogTabnine AcademyTerms of usePrivacy policyJava Code IndexJavascript Code Index
Get Tabnine for your IDE now