Index

A B C D E F G H I J K L M N O P Q R S T U V W _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

accumulate(CalculatedValue<Void>) - Method in class com.arpnetworking.tsdcore.statistics.MaxStatistic.MaxAccumulator
 
accumulate(CalculatedValue<Void>) - Method in class com.arpnetworking.tsdcore.statistics.MinStatistic.MinAccumulator
 
accumulate(CalculatedValue<Void>) - Method in class com.arpnetworking.tsdcore.statistics.SumStatistic.SumAccumulator
 
accumulate(CalculatedValue<T>) - Method in interface com.arpnetworking.tsdcore.statistics.Accumulator
Add the specified CalculatedValue to the accumulated value.
accumulate(Quantity) - Method in interface com.arpnetworking.tsdcore.statistics.Accumulator
Add the specified Quantity to the accumulated value.
accumulate(Quantity) - Method in class com.arpnetworking.tsdcore.statistics.MaxStatistic.MaxAccumulator
 
accumulate(Quantity) - Method in class com.arpnetworking.tsdcore.statistics.MinStatistic.MinAccumulator
 
accumulate(Quantity) - Method in class com.arpnetworking.tsdcore.statistics.SumStatistic.SumAccumulator
 
Accumulator<T> - Interface in com.arpnetworking.tsdcore.statistics
Specialization of Calculator directly supporting streaming calculations over Quantity and CalculatedValue streams.
actorClass() - Method in class com.arpnetworking.guice.pekko.GuiceActorCreator
 
ActorConfigurator<T> - Class in com.arpnetworking.utility
A launchable intended to be used from a Configurator to notify an actor about new configuration.
ActorConfigurator(ActorRef, Class<? extends T>) - Constructor for class com.arpnetworking.utility.ActorConfigurator
Public constructor.
ActorRefDeserializer - Class in com.arpnetworking.configuration.jackson.pekko
Deserializer for a Pekko ActorRef.
ActorRefDeserializer(ActorSystem) - Constructor for class com.arpnetworking.configuration.jackson.pekko.ActorRefDeserializer
Public constructor.
ActorRefLoggingSerializer - Class in com.arpnetworking.configuration.jackson.pekko
Serializer for a Pekko ActorRef.
ActorRefLoggingSerializer() - Constructor for class com.arpnetworking.configuration.jackson.pekko.ActorRefLoggingSerializer
Public constructor.
ActorRefSerializer - Class in com.arpnetworking.configuration.jackson.pekko
Serializer for a Pekko ActorRef.
ActorRefSerializer(ActorSystem) - Constructor for class com.arpnetworking.configuration.jackson.pekko.ActorRefSerializer
Public constructor.
add(Quantity) - Method in class com.arpnetworking.tsdcore.model.Quantity
Add this Quantity to the specified one returning the result.
add(HistogramStatistic.HistogramSnapshot) - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.Histogram
Adds a histogram snapshot to this one.
addBroker(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Adds a broker to the list of brokers.
addBrokerDetails(BrokerListResponse.BrokerDetails) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker.Builder
Adds a broker details entry.
addFileName(String) - Method in class com.arpnetworking.configuration.jackson.JsonNodeDirectorySource.Builder
Add a file name.
addFileName(String) - Method in class com.arpnetworking.configuration.triggers.DirectoryTrigger.Builder
Add a file name.
addFileNamePattern(Pattern) - Method in class com.arpnetworking.configuration.jackson.JsonNodeDirectorySource.Builder
Add a file name pattern.
addFileNamePattern(Pattern) - Method in class com.arpnetworking.configuration.triggers.DirectoryTrigger.Builder
Add a file name pattern.
addFuture(Future<?>) - Method in class com.arpnetworking.utility.CollectFutureBuilder
Registers a Future in the collection.
addHeader(Header) - Method in class com.arpnetworking.configuration.jackson.JsonNodeUriSource.Builder
Add a request header for the source.
addHeader(Header) - Method in class com.arpnetworking.configuration.triggers.UriTrigger.Builder
Add a Header to the uri.
addHeaders(List<Header>) - Method in class com.arpnetworking.configuration.jackson.JsonNodeUriSource.Builder
Add a list of request headers for the source.
addHeaders(List<Header>) - Method in class com.arpnetworking.configuration.triggers.UriTrigger.Builder
Add a List of Header to the uri.
addListener(Listener) - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration.Builder
Add a Listener instance.
addModule(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails.Builder
Adds a module to the list.
addSink(Sink) - Method in class com.arpnetworking.tsdcore.sinks.MultiSink.Builder
Adds a sink to the list of sinks.
addSource(JsonNodeSource) - Method in class com.arpnetworking.configuration.jackson.JsonNodeMergingSource.Builder
Add a JsonNodeSource instance.
addSource(JsonNodeSource) - Method in class com.arpnetworking.configuration.jackson.StaticConfiguration.Builder
Add a JsonNodeSource instance.
addSourceBuilder(Builder<? extends JsonNodeSource>) - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration.Builder
addTag(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker.Builder
Adds a tag.
addTag(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Adds a tag to the list of tags.
addTrigger(Trigger) - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration.Builder
Add a Trigger instance.
AggClientConnection - Class in com.arpnetworking.clusteraggregator.client
An actor that handles the data sent from an agg client.
AggClientConnection(ActorRef, InetSocketAddress, FiniteDuration, boolean) - Constructor for class com.arpnetworking.clusteraggregator.client.AggClientConnection
Public constructor.
AggClientServer - Class in com.arpnetworking.clusteraggregator.client
TCP Server that listens for aggregation client connections.
AggClientServer(Provider<Props>, ClusterAggregatorConfiguration) - Constructor for class com.arpnetworking.clusteraggregator.client.AggClientServer
Public constructor.
AggClientSupervisor - Class in com.arpnetworking.clusteraggregator.client
Supervises the connection's actors.
AggClientSupervisor(ActorRef, ActorRef, ClusterAggregatorConfiguration) - Constructor for class com.arpnetworking.clusteraggregator.client.AggClientSupervisor
Public constructor.
AggDataUnifier - Class in com.arpnetworking.clusteraggregator
Unifies units.
AggMessageExtractor - Class in com.arpnetworking.clusteraggregator.aggregation
Handles extracting the sharding information from an aggregation message.
AggMessageExtractor(ImmutableSet<String>) - Constructor for class com.arpnetworking.clusteraggregator.aggregation.AggMessageExtractor
Public constructor.
AggregatedData - Class in com.arpnetworking.tsdcore.model
Serves as a data class for storing data for aggregated values after computation.
AggregatedData.Builder - Class in com.arpnetworking.tsdcore.model
Builder implementation for AggregatedData.
AggregationMessage - Class in com.arpnetworking.tsdcore.model
Class for building messages from the raw, on-the-wire bytes in the TCP stream.
AggregationMode - Enum Class in com.arpnetworking.clusteraggregator.models
The aggregation mode applied to data.
AggregationRequest - Class in com.arpnetworking.tsdcore.model
Encapsulates a List of AggregationMessage instances and an AggregationMode to be applied to those messages.
AggregationRequest.Builder - Class in com.arpnetworking.tsdcore.model
Builder implementation for AggregationRequest.
AggregationRouter - Class in com.arpnetworking.clusteraggregator.aggregation
Actual actor responsible for aggregating.
AggregationRouter(ActorRef, ActorRef, String, ImmutableSet<String>, boolean, Duration, PeriodicMetrics) - Constructor for class com.arpnetworking.clusteraggregator.aggregation.AggregationRouter
Public constructor.
AggregationRouter.ShutdownAggregator - Class in com.arpnetworking.clusteraggregator.aggregation
Message to request shutdown of aggregation router and subordinate streaming aggregator actor pair.
allocateShard(ActorRef, String, Map<ActorRef, IndexedSeq<String>>) - Method in class com.arpnetworking.utility.ParallelLeastShardAllocationStrategy
 
AnnotationDatabase - Interface in com.arpnetworking.utility
This class provides searchable access to runtime annotations.
apply(HttpRequest) - Method in class com.arpnetworking.clusteraggregator.http.Routes
 
apply(T) - Method in class com.arpnetworking.utility.CastMapper
 
applyConfiguration() - Method in interface com.arpnetworking.configuration.Listener
Invoked to apply the most recently offered configuration.
applyConfiguration() - Method in class com.arpnetworking.utility.ActorConfigurator
 
applyConfiguration() - Method in class com.arpnetworking.utility.Configurator
 
applyConfiguration() - Method in class com.arpnetworking.utility.Reconfigurator
 
ApplyConfiguration(C) - Constructor for class com.arpnetworking.clusteraggregator.configuration.ConfigurableActorProxy.ApplyConfiguration
Public constructor.
AppShutdown - Class in com.arpnetworking.clusteraggregator
Assists Guice-instantiated classes in shutting down.
AppShutdown() - Constructor for class com.arpnetworking.clusteraggregator.AppShutdown
 

B

BaseCalculator<T> - Class in com.arpnetworking.tsdcore.statistics
A calculator base class.
BaseCalculator(Statistic) - Constructor for class com.arpnetworking.tsdcore.statistics.BaseCalculator
Protected constructor.
BaseConfiguration - Class in com.arpnetworking.configuration
Abstract base class for Configuration implementations which implements the shared convenience methods which rely core methods.
BaseConfiguration() - Constructor for class com.arpnetworking.configuration.BaseConfiguration
 
BaseJacksonConfiguration - Class in com.arpnetworking.configuration.jackson
Common base class for Configuration implementations based on Jackson's ObjectMapper.
BaseJacksonConfiguration(BaseJacksonConfiguration.Builder<?, ?>) - Constructor for class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration
Protected constructor.
BaseJacksonConfiguration.Builder<T extends BaseJacksonConfiguration.Builder<?,?>,S extends Configuration> - Class in com.arpnetworking.configuration.jackson
Builder implementation for BaseJacksonConfiguration.
BaseJsonNodeSource - Class in com.arpnetworking.configuration.jackson
Abstract base class for JsonNodeSource implementations.
BaseJsonNodeSource(BaseJsonNodeSource.Builder<?, ?>) - Constructor for class com.arpnetworking.configuration.jackson.BaseJsonNodeSource
Protected constructor.
BaseJsonNodeSource.Builder<T extends BaseJsonNodeSource.Builder<?,?>,S extends JsonNodeSource> - Class in com.arpnetworking.configuration.jackson
Builder implementation for BaseJsonNodeSource.
BaseSink - Class in com.arpnetworking.tsdcore.sinks
Abstract base class for common functionality for publishing AggregatedData.
BaseSink(BaseSink.Builder<?, ?>) - Constructor for class com.arpnetworking.tsdcore.sinks.BaseSink
Protected constructor.
BaseSink.Builder<B extends BaseSink.Builder<B,S>,S extends Sink> - Class in com.arpnetworking.tsdcore.sinks
Base Builder implementation for Sink implementations.
BaseStatistic - Class in com.arpnetworking.tsdcore.statistics
A statistic base class.
BaseStatistic() - Constructor for class com.arpnetworking.tsdcore.statistics.BaseStatistic
 
BIT - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Bits.
BrokerListResponse - Class in com.arpnetworking.tsdcore.sinks.circonus.api
Circonus api for a broker list response.
BrokerListResponse(List<BrokerListResponse.Broker>) - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse
Public constructor.
BrokerListResponse.Broker - Class in com.arpnetworking.tsdcore.sinks.circonus.api
Represents a broker object in the Circonus API.
BrokerListResponse.Broker.Builder - Class in com.arpnetworking.tsdcore.sinks.circonus.api
Builder implementation for BrokerListResponse.Broker.
BrokerListResponse.BrokerDetails - Class in com.arpnetworking.tsdcore.sinks.circonus.api
Represents the details block of a broker object.
BrokerListResponse.BrokerDetails.Builder - Class in com.arpnetworking.tsdcore.sinks.circonus.api
Builder implementation for BrokerListResponse.BrokerDetails.
BrokerLookupComplete(BrokerListResponse) - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.BrokerRefresher.BrokerLookupComplete
Public constructor.
BrokerLookupFailure(Throwable) - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.BrokerRefresher.BrokerLookupFailure
Public constructor.
BrokerRefresher - Class in com.arpnetworking.tsdcore.sinks.circonus
Actor whose responsibility it is to refresh the list of available circonus brokers.
BrokerRefresher(CirconusClient) - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.BrokerRefresher
Public constructor.
BrokerRefresher.BrokerLookupComplete - Class in com.arpnetworking.tsdcore.sinks.circonus
Message class used to indicate that a broker lookup has completed.
BrokerRefresher.BrokerLookupFailure - Class in com.arpnetworking.tsdcore.sinks.circonus
Message class used to indicate that a broker lookup has failed.
build(ExecutionContext) - Method in class com.arpnetworking.utility.CollectFutureBuilder
Builds the final future.
Builder() - Constructor for class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.clusteraggregator.configuration.EmitterConfiguration.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.clusteraggregator.configuration.RebalanceConfiguration.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.clusteraggregator.models.CombinedMetricData.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.clusteraggregator.models.ShardAllocation.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.clusteraggregator.models.StatusResponse.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.DirectoryDynamicConfigurationFactory.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.DynamicConfiguration.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.HoconFileSource.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.JsonNodeDirectorySource.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.JsonNodeFileSource.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.JsonNodeLiteralSource.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.JsonNodeMergingSource.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.JsonNodePaginatedUriSource.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.JsonNodeUriSource.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.MergingDynamicConfigurationFactory.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.jackson.StaticConfiguration.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.triggers.DirectoryTrigger.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.triggers.FileTrigger.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.configuration.triggers.UriTrigger.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.pekko.UniformRandomTimeScheduler.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.remet.gui.ReMetGuiDynamicConfigurationFactory.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.model.AggregatedData.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.model.AggregationRequest.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.model.CalculatedValue.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.model.Condition.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.model.FQDSN.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.model.FQSN.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.model.PeriodicData.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.model.Quantity.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.model.RequestEntry.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.CarbonSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.DataDogSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.DimensionFilteringSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.DimensionInjectingSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.DomainInjectingSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.InfluxDbSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.KairosDbSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.KMonDSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.MetricNameFilteringSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.MonitordSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.MultiSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.PeriodFilteringSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.RandomMetricNameFilterSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.RrdSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.ServiceNameFilteringSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.SignalFxSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.TimeThresholdSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.sinks.UnitMappingSink.Builder
Public constructor.
Builder() - Constructor for class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSupportingData.Builder
Public constructor.
Builder(Function<B, S>) - Constructor for class com.arpnetworking.tsdcore.sinks.BaseSink.Builder
Protected constructor for subclasses.
Builder(Function<B, S>) - Constructor for class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Protected constructor for subclasses.
Builder(Function<B, S>) - Constructor for class com.arpnetworking.tsdcore.sinks.TcpSink.Builder
Protected constructor for subclasses.
Builder(Function<T, S>) - Constructor for class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration.Builder
Protected constructor for subclasses.
Builder(Function<T, S>) - Constructor for class com.arpnetworking.configuration.jackson.BaseJsonNodeSource.Builder
Protected constructor for subclasses.
BYTE - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Bytes.

C

calculate(List<Quantity>) - Method in class com.arpnetworking.tsdcore.statistics.CountStatistic
 
calculate(List<Quantity>) - Method in class com.arpnetworking.tsdcore.statistics.ExpressionStatistic
 
calculate(List<Quantity>) - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic
 
calculate(List<Quantity>) - Method in class com.arpnetworking.tsdcore.statistics.MaxStatistic
 
calculate(List<Quantity>) - Method in class com.arpnetworking.tsdcore.statistics.MeanStatistic
 
calculate(List<Quantity>) - Method in class com.arpnetworking.tsdcore.statistics.MinStatistic
 
calculate(List<Quantity>) - Method in interface com.arpnetworking.tsdcore.statistics.Statistic
Compute the statistic from the List of Quantity instances.
calculate(List<Quantity>) - Method in class com.arpnetworking.tsdcore.statistics.SumStatistic
 
calculate(List<Quantity>) - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic
 
calculate(Map<Statistic, Calculator<?>>) - Method in interface com.arpnetworking.tsdcore.statistics.Calculator
Compute the value of a statistic.
calculate(Map<Statistic, Calculator<?>>) - Method in class com.arpnetworking.tsdcore.statistics.MaxStatistic.MaxAccumulator
 
calculate(Map<Statistic, Calculator<?>>) - Method in class com.arpnetworking.tsdcore.statistics.MeanStatistic.MeanCalculator
 
calculate(Map<Statistic, Calculator<?>>) - Method in class com.arpnetworking.tsdcore.statistics.MinStatistic.MinAccumulator
 
calculate(Map<Statistic, Calculator<?>>) - Method in class com.arpnetworking.tsdcore.statistics.SumStatistic.SumAccumulator
 
calculate(Map<Statistic, Calculator<?>>) - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic.PercentileCalculator
 
calculateAggregations(List<AggregatedData>) - Method in class com.arpnetworking.tsdcore.statistics.CountStatistic
 
calculateAggregations(List<AggregatedData>) - Method in class com.arpnetworking.tsdcore.statistics.ExpressionStatistic
 
calculateAggregations(List<AggregatedData>) - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic
 
calculateAggregations(List<AggregatedData>) - Method in class com.arpnetworking.tsdcore.statistics.MaxStatistic
 
calculateAggregations(List<AggregatedData>) - Method in class com.arpnetworking.tsdcore.statistics.MeanStatistic
 
calculateAggregations(List<AggregatedData>) - Method in class com.arpnetworking.tsdcore.statistics.MinStatistic
 
calculateAggregations(List<AggregatedData>) - Method in interface com.arpnetworking.tsdcore.statistics.Statistic
Compute the statistic from the List of AggregatedData instances.
calculateAggregations(List<AggregatedData>) - Method in class com.arpnetworking.tsdcore.statistics.SumStatistic
 
calculateAggregations(List<AggregatedData>) - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic
 
CalculatedValue<T> - Class in com.arpnetworking.tsdcore.model
Represents a value that is reaggregatable.
CalculatedValue.Builder<T> - Class in com.arpnetworking.tsdcore.model
Builder implementation for CalculatedValue.
Calculator<T> - Interface in com.arpnetworking.tsdcore.statistics
Interface for classes providing computation of a statistic.
CarbonSink - Class in com.arpnetworking.tsdcore.sinks
Publisher to send data to a Carbon server.
CarbonSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for CarbonSink.
CastMapper<T,R> - Class in com.arpnetworking.utility
Map method that just casts to another class.
CastMapper() - Constructor for class com.arpnetworking.utility.CastMapper
 
CELCIUS - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Celcius.
CheckBundle - Class in com.arpnetworking.tsdcore.sinks.circonus.api
Represents a check bundle in Circonus.
CheckBundle.Builder - Class in com.arpnetworking.tsdcore.sinks.circonus.api
Builder implementation for CheckBundle.
CheckBundleActivator - Class in com.arpnetworking.tsdcore.sinks.circonus
Actor responsible for keeping check bundle metrics active.
CheckBundleActivator(CirconusClient) - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.CheckBundleActivator
Public constructor.
CheckBundleActivator.NotifyCheckBundle - Class in com.arpnetworking.tsdcore.sinks.circonus
Message class used to notify the refresher about a check bundle.
CirconusClient - Class in com.arpnetworking.tsdcore.sinks.circonus
Async Circonus API client.
CirconusClient.Builder - Class in com.arpnetworking.tsdcore.sinks.circonus
Builder implementation for CirconusClient.
CirconusSink - Class in com.arpnetworking.tsdcore.sinks.circonus
A traditional tsdcore single threaded sink to act as an adapter for the actor-based sink.
CirconusSink.Builder - Class in com.arpnetworking.tsdcore.sinks.circonus
Builder for CirconusSink.
CirconusSinkActor - Class in com.arpnetworking.tsdcore.sinks.circonus
Reports data to Circonus HttpTrap.
CirconusSinkActor(CirconusClient, String, int, int, Duration, boolean, PartitionSet) - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.CirconusSinkActor
Public constructor.
CirconusSinkActor.EmitAggregation - Class in com.arpnetworking.tsdcore.sinks.circonus
Message class to wrap a list of AggregatedData.
close() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.DimensionFilteringSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.DimensionInjectingSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.DomainInjectingSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.MetricNameFilteringSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.MultiSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.PeriodFilteringSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.RandomMetricNameFilterSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.RrdSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.ServiceNameFilteringSink
 
close() - Method in interface com.arpnetworking.tsdcore.sinks.Sink
Called to allow the publisher to clean-up.
close() - Method in class com.arpnetworking.tsdcore.sinks.TcpSink
Called to allow the publisher to clean-up.
close() - Method in class com.arpnetworking.tsdcore.sinks.TimeThresholdSink
 
close() - Method in class com.arpnetworking.tsdcore.sinks.UnitMappingSink
 
CLUSTER_KEY - Static variable in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
The key used in dimensions to specify the cluster-dimension.
ClusterAggregatorConfiguration - Class in com.arpnetworking.clusteraggregator.configuration
Representation of cluster aggregator configuration.
ClusterAggregatorConfiguration.Builder - Class in com.arpnetworking.clusteraggregator.configuration
Builder implementation for ClusterAggregatorConfiguration.
ClusterStatusCache - Class in com.arpnetworking.clusteraggregator
Caches the cluster state.
ClusterStatusCache(ActorSystem, Duration, MetricsFactory) - Constructor for class com.arpnetworking.clusteraggregator.ClusterStatusCache
Public constructor.
ClusterStatusCache.GetRequest - Class in com.arpnetworking.clusteraggregator
Request to get a cluster status.
ClusterStatusCache.StatusResponse - Class in com.arpnetworking.clusteraggregator
Response to a cluster status request.
CollectFutureBuilder<T> - Class in com.arpnetworking.utility
Collects futures and provides them in a combined promise.
CollectFutureBuilder() - Constructor for class com.arpnetworking.utility.CollectFutureBuilder
 
com.arpnetworking.clusteraggregator - package com.arpnetworking.clusteraggregator
 
com.arpnetworking.clusteraggregator.aggregation - package com.arpnetworking.clusteraggregator.aggregation
 
com.arpnetworking.clusteraggregator.client - package com.arpnetworking.clusteraggregator.client
 
com.arpnetworking.clusteraggregator.configuration - package com.arpnetworking.clusteraggregator.configuration
 
com.arpnetworking.clusteraggregator.http - package com.arpnetworking.clusteraggregator.http
 
com.arpnetworking.clusteraggregator.models - package com.arpnetworking.clusteraggregator.models
 
com.arpnetworking.clusteraggregator.models.ebean - package com.arpnetworking.clusteraggregator.models.ebean
 
com.arpnetworking.clusteraggregator.partitioning - package com.arpnetworking.clusteraggregator.partitioning
 
com.arpnetworking.configuration - package com.arpnetworking.configuration
 
com.arpnetworking.configuration.jackson - package com.arpnetworking.configuration.jackson
 
com.arpnetworking.configuration.jackson.pekko - package com.arpnetworking.configuration.jackson.pekko
 
com.arpnetworking.configuration.triggers - package com.arpnetworking.configuration.triggers
 
com.arpnetworking.guice.pekko - package com.arpnetworking.guice.pekko
 
com.arpnetworking.pekko - package com.arpnetworking.pekko
 
com.arpnetworking.remet.gui - package com.arpnetworking.remet.gui
 
com.arpnetworking.tsdcore.model - package com.arpnetworking.tsdcore.model
 
com.arpnetworking.tsdcore.sinks - package com.arpnetworking.tsdcore.sinks
 
com.arpnetworking.tsdcore.sinks.circonus - package com.arpnetworking.tsdcore.sinks.circonus
 
com.arpnetworking.tsdcore.sinks.circonus.api - package com.arpnetworking.tsdcore.sinks.circonus.api
 
com.arpnetworking.tsdcore.statistics - package com.arpnetworking.tsdcore.statistics
 
com.arpnetworking.utility - package com.arpnetworking.utility
 
com.arpnetworking.utility.partitioning - package com.arpnetworking.utility.partitioning
 
CombinedMetricData - Class in com.arpnetworking.clusteraggregator.models
A metric-based aggregation model.
CombinedMetricData.Builder - Class in com.arpnetworking.clusteraggregator.models
Builder implementationfor CombinedMetricData.
CombinedMetricData.StatisticValue - Class in com.arpnetworking.clusteraggregator.models
Representation of a computed statistic and related data.
compare(String, String) - Method in class com.arpnetworking.utility.LexicalNumericComparator
 
compareTo(Quantity) - Method in class com.arpnetworking.tsdcore.model.Quantity
 
compute() - Method in class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregationBucket
Computes all of the statistics in the bucket.
computePopulationSize(String, Map<Statistic, CombinedMetricData.StatisticValue>) - Static method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
Compute the population size for a metric from its statistic values.
computePopulationSizeFromCalculatedValues(String, Map<Statistic, CalculatedValue<?>>) - Static method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
Compute the population size for a metric from its calculated values.
Condition - Class in com.arpnetworking.tsdcore.model
Describes a condition.
Condition.Builder - Class in com.arpnetworking.tsdcore.model
Builder implementation for Condition.
ConfigurableActorProxy<T> - Class in com.arpnetworking.clusteraggregator.configuration
Serves as a router for configuration-created actors.
ConfigurableActorProxy(ConfiguredLaunchableFactory<Props, T>) - Constructor for class com.arpnetworking.clusteraggregator.configuration.ConfigurableActorProxy
Public constructor.
ConfigurableActorProxy.ApplyConfiguration<C> - Class in com.arpnetworking.clusteraggregator.configuration
Message class to cause a new configuration to be applied.
ConfigurableActorProxy.ConfigurableActorStarted - Class in com.arpnetworking.clusteraggregator.configuration
Message class to tell observers that a new actor has started due to a configuration change.
ConfigurableActorProxy.SubscribeToNotifications - Class in com.arpnetworking.clusteraggregator.configuration
Message class to send to the ConfigurableActorProxy to indicate you want to receive event notifications.
ConfigurableActorStarted(ActorRef) - Constructor for class com.arpnetworking.clusteraggregator.configuration.ConfigurableActorProxy.ConfigurableActorStarted
Public constructor.
Configuration - Interface in com.arpnetworking.configuration
Interface for classes which provide configuration.
Configurator<T extends Launchable,S> - Class in com.arpnetworking.utility
Manages configuration and reconfiguration of a Launchable instance using a POJO representation of its configuration.
Configurator(ConfiguredLaunchableFactory<T, S>, Class<? extends S>) - Constructor for class com.arpnetworking.utility.Configurator
Public constructor.
configure() - Method in class com.arpnetworking.clusteraggregator.GuiceModule
 
ConfiguredLaunchableFactory<T,S> - Interface in com.arpnetworking.utility
Defines a factory for creating Launchable objects from a config object.
convert(double, Unit) - Method in enum class com.arpnetworking.tsdcore.model.Unit
Converts a value in one unit to another.
convertTo(Unit) - Method in class com.arpnetworking.tsdcore.model.Quantity
Convert this Quantity to one in the specified unit.
convertTo(Optional<Unit>) - Method in class com.arpnetworking.tsdcore.model.Quantity
Convert this Quantity to one in the specified optional unit.
COUNTER - Enum constant in enum class com.arpnetworking.tsdcore.model.MetricType
Counter.
CountStatistic - Class in com.arpnetworking.tsdcore.statistics
Counts the entries.
create(DynamicConfiguration.Builder, Collection<DynamicConfigurationFactory.Key>) - Method in class com.arpnetworking.configuration.jackson.DirectoryDynamicConfigurationFactory
 
create(DynamicConfiguration.Builder, Collection<DynamicConfigurationFactory.Key>) - Method in interface com.arpnetworking.configuration.jackson.DynamicConfigurationFactory
Create a new DynamicConfiguration from the specified builder updated with the specified keys using the strategy defined by the specific implementation.
create(DynamicConfiguration.Builder, Collection<DynamicConfigurationFactory.Key>) - Method in class com.arpnetworking.configuration.jackson.MergingDynamicConfigurationFactory
 
create(DynamicConfiguration.Builder, Collection<DynamicConfigurationFactory.Key>) - Method in class com.arpnetworking.remet.gui.ReMetGuiDynamicConfigurationFactory
 
create(GeneratedMessageV3) - Static method in class com.arpnetworking.tsdcore.model.AggregationMessage
Static factory.
create(String, int, int) - Method in interface com.arpnetworking.utility.partitioning.PartitionSetFactory
Creates a PartitionSet in a given namespace.
create(S) - Method in interface com.arpnetworking.utility.ConfiguredLaunchableFactory
Creates a Launchable.
createCalculator() - Method in class com.arpnetworking.tsdcore.statistics.CountStatistic
 
createCalculator() - Method in class com.arpnetworking.tsdcore.statistics.ExpressionStatistic
 
createCalculator() - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic
 
createCalculator() - Method in class com.arpnetworking.tsdcore.statistics.MaxStatistic
 
createCalculator() - Method in class com.arpnetworking.tsdcore.statistics.MeanStatistic
 
createCalculator() - Method in class com.arpnetworking.tsdcore.statistics.MinStatistic
 
createCalculator() - Method in interface com.arpnetworking.tsdcore.statistics.Statistic
Create a Calculator for this statistic.
createCalculator() - Method in class com.arpnetworking.tsdcore.statistics.SumStatistic
 
createCalculator() - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic
 
createFQDSN(AggregatedData) - Static method in class com.arpnetworking.tsdcore.model.AggregatedData
Create a fully qualified data space name (FQDSN).
createFQSN(AggregatedData) - Static method in class com.arpnetworking.tsdcore.model.AggregatedData
Create a fully qualified statistic name (FQSN).
createObjectMapper() - Static method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
Create an ObjectMapper for cluster aggregator configuration.
createObjectMapper(Injector) - Static method in class com.arpnetworking.clusteraggregator.configuration.EmitterConfiguration
Create an ObjectMapper for Emitter configuration.
createReceive() - Method in class com.arpnetworking.clusteraggregator.aggregation.AggregationRouter
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregator
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.client.AggClientConnection
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.client.AggClientSupervisor
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.client.HttpSourceActor
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.ClusterStatusCache
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.configuration.ConfigurableActorProxy
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.Emitter
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.GracefulShutdownActor
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.JvmMetricsCollector
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.PeriodicStatisticsActor
 
createReceive() - Method in class com.arpnetworking.clusteraggregator.Status
 
createReceive() - Method in class com.arpnetworking.tsdcore.sinks.circonus.BrokerRefresher
 
createReceive() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CheckBundleActivator
 
createReceive() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSinkActor
 
createReceive() - Method in class com.arpnetworking.tsdcore.sinks.HttpSinkActor
 
createReceive() - Method in class com.arpnetworking.tsdcore.sinks.TcpSinkActor
 
createRequest(AsyncHttpClient, byte[]) - Method in class com.arpnetworking.tsdcore.sinks.DataDogSink
 
createRequest(AsyncHttpClient, byte[]) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
Creates an HTTP request from a serialized data entry.
createRequest(AsyncHttpClient, byte[]) - Method in class com.arpnetworking.tsdcore.sinks.InfluxDbSink
 
createRequest(AsyncHttpClient, byte[]) - Method in class com.arpnetworking.tsdcore.sinks.KMonDSink
 
createRequest(AsyncHttpClient, byte[]) - Method in class com.arpnetworking.tsdcore.sinks.MonitordSink
 
createRequest(AsyncHttpClient, byte[]) - Method in class com.arpnetworking.tsdcore.sinks.SignalFxSink
 
createRequests(AsyncHttpClient, PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
Create HTTP requests for each serialized data entry.

D

Database - Class in com.arpnetworking.utility
Database instance abstraction across database technologies: HikariCP, Flyway and EBean.
Database(String, DatabaseConfiguration) - Constructor for class com.arpnetworking.utility.Database
Public constructor.
DatabaseConfiguration - Class in com.arpnetworking.clusteraggregator.configuration
Represents the database configuration.
DatabaseConfiguration.Builder - Class in com.arpnetworking.clusteraggregator.configuration
Builder implementation for DatabaseConfiguration.
DatabasePartitionSet - Class in com.arpnetworking.clusteraggregator.partitioning
A partition set that is backed by an eBean database.
DatabasePartitionSet(Database, PartitionSet) - Constructor for class com.arpnetworking.clusteraggregator.partitioning.DatabasePartitionSet
Public constructor.
DataDogSink - Class in com.arpnetworking.tsdcore.sinks
Publishes aggregations to Data Dog.
DataDogSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for DataDogSink.
DAY - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Days.
DefaultHostResolver - Class in com.arpnetworking.utility
Resolves a host name using the built-in java functions.
DefaultHostResolver() - Constructor for class com.arpnetworking.utility.DefaultHostResolver
 
deserialize(JsonParser, DeserializationContext) - Method in class com.arpnetworking.configuration.jackson.pekko.ActorRefDeserializer
 
deserialize(JsonParser, DeserializationContext) - Method in class com.arpnetworking.tsdcore.statistics.StatisticDeserializer
 
deserialize(ByteString) - Static method in class com.arpnetworking.tsdcore.model.AggregationMessage
Deserialize message from ByteString.
DimensionFilteringSink - Class in com.arpnetworking.tsdcore.sinks
Filtering sink for excluding data based on dimensions present or absent.
DimensionFilteringSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for DimensionFilteringSink.
DimensionInjectingSink - Class in com.arpnetworking.tsdcore.sinks
Sink adds any specified dimensions.
DimensionInjectingSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for DimensionInjectingSink.
DirectoryDynamicConfigurationFactory - Class in com.arpnetworking.configuration.jackson
Implementation of DynamicConfigurationFactory which maps keys to file names in a directory.
DirectoryDynamicConfigurationFactory.Builder - Class in com.arpnetworking.configuration.jackson
Builder implementation for DirectoryDynamicConfigurationFactory.
DirectoryTrigger - Class in com.arpnetworking.configuration.triggers
Trigger implementation based on the contents of a directory.
DirectoryTrigger.Builder - Class in com.arpnetworking.configuration.triggers
Builder implementation for DirectoryTrigger.
divide(Quantity) - Method in class com.arpnetworking.tsdcore.model.Quantity
Divide this Quantity by the specified one returning the result.
DomainInjectingSink - Class in com.arpnetworking.tsdcore.sinks
Sink extracts and adds dimension for "domain" based on hostname.
DomainInjectingSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for DomainInjectingSink.
DynamicConfiguration - Class in com.arpnetworking.configuration.jackson
Dynamic configuration implementation of Configuration.
DynamicConfiguration.Builder - Class in com.arpnetworking.configuration.jackson
DynamicConfigurationFactory - Interface in com.arpnetworking.configuration.jackson
Interface for classes which create DynamicConfiguration instances.
DynamicConfigurationFactory.Key - Class in com.arpnetworking.configuration.jackson
Key descriptor.

E

EmitAggregation(PeriodicData) - Constructor for class com.arpnetworking.tsdcore.sinks.HttpSinkActor.EmitAggregation
Public constructor.
EmitAggregation(PeriodicData) - Constructor for class com.arpnetworking.tsdcore.sinks.TcpSinkActor.EmitAggregation
Public constructor.
EmitAggregation(Collection<AggregatedData>) - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.CirconusSinkActor.EmitAggregation
Public constructor.
Emitter - Class in com.arpnetworking.clusteraggregator
Holds the sinks and emits to them.
Emitter(EmitterConfiguration) - Constructor for class com.arpnetworking.clusteraggregator.Emitter
Public constructor.
EmitterConfiguration - Class in com.arpnetworking.clusteraggregator.configuration
Representation of an emitter configuration for cluster aggregator.
EmitterConfiguration.Builder - Class in com.arpnetworking.clusteraggregator.configuration
Builder implementation for EmitterConfiguration.
entityId(Object) - Method in class com.arpnetworking.clusteraggregator.aggregation.AggMessageExtractor
entityMessage(Object) - Method in class com.arpnetworking.clusteraggregator.aggregation.AggMessageExtractor
equals(Object) - Method in class com.arpnetworking.configuration.jackson.DynamicConfigurationFactory.Key
 
equals(Object) - Method in class com.arpnetworking.tsdcore.model.AggregatedData
 
equals(Object) - Method in class com.arpnetworking.tsdcore.model.FQDSN
 
equals(Object) - Method in class com.arpnetworking.tsdcore.model.FQSN
 
equals(Object) - Method in class com.arpnetworking.tsdcore.model.PeriodicData
 
equals(Object) - Method in class com.arpnetworking.tsdcore.model.Quantity
 
equals(Object) - Method in class com.arpnetworking.tsdcore.statistics.BaseCalculator
 
equals(Object) - Method in class com.arpnetworking.tsdcore.statistics.BaseStatistic
 
equals(Object) - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic
 
equals(Object) - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic.PercentileCalculator
 
evaluateAndReset() - Method in interface com.arpnetworking.configuration.Trigger
Evaluate the trigger.
evaluateAndReset() - Method in class com.arpnetworking.configuration.triggers.DirectoryTrigger
 
evaluateAndReset() - Method in class com.arpnetworking.configuration.triggers.FileTrigger
 
evaluateAndReset() - Method in class com.arpnetworking.configuration.triggers.UriTrigger
 
ExpressionStatistic - Class in com.arpnetworking.tsdcore.statistics
The aggregation is performed with a user-defined expression.

F

FAHRENHEIT - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Fahrenheit.
FileTrigger - Class in com.arpnetworking.configuration.triggers
Trigger implementation based on a file's modified date and its hash.
FileTrigger.Builder - Class in com.arpnetworking.configuration.triggers
Builder implementation for FileTrigger.
findByKey(String, PartitionSet, Database) - Static method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
Looks up a partition entry by key and partition set name.
findClassesWithAnnotation(Class<? extends Annotation>) - Method in interface com.arpnetworking.utility.AnnotationDatabase
Retrieve the Set of classes with the declared annotation.
findClassesWithAnnotation(Class<? extends Annotation>) - Method in class com.arpnetworking.utility.ReflectionsDatabase
 
findClassesWithInterface(Class<T>) - Method in interface com.arpnetworking.utility.InterfaceDatabase
Retrieve the Set of classes with the implemented interface.
findClassesWithInterface(Class<T>) - Method in class com.arpnetworking.utility.ReflectionsDatabase
 
findOrCreate(String, Database, int, int) - Static method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
Finds or creates a partition set.
FQDSN - Class in com.arpnetworking.tsdcore.model
Fully qualified data space name.
FQDSN.Builder - Class in com.arpnetworking.tsdcore.model
Builder implementation for FQDSN.
FQSN - Class in com.arpnetworking.tsdcore.model
Fully qualified statistic name.
FQSN.Builder - Class in com.arpnetworking.tsdcore.model
Builder implementation for FQSN.
fromFQDSN(FQDSN) - Method in class com.arpnetworking.tsdcore.model.FQSN.Builder
The full qualified data space name.
fromStatisticSetRecord(Messages.StatisticSetRecord) - Static method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData.Builder
Initializes the builder with fields from a Messages.StatisticSetRecord.

G

GAUGE - Enum constant in enum class com.arpnetworking.tsdcore.model.MetricType
Gauge.
getActor() - Method in class com.arpnetworking.clusteraggregator.configuration.ConfigurableActorProxy.ConfigurableActorStarted
 
getAggregationHost() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getAggregationMessages() - Method in class com.arpnetworking.tsdcore.model.AggregationRequest
 
getAggregationMode() - Method in class com.arpnetworking.tsdcore.model.AggregationRequest
 
getAggregationPort() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getAliases() - Method in class com.arpnetworking.tsdcore.statistics.BaseStatistic
 
getAliases() - Method in class com.arpnetworking.tsdcore.statistics.CountStatistic
 
getAliases() - Method in class com.arpnetworking.tsdcore.statistics.MaxStatistic
 
getAliases() - Method in class com.arpnetworking.tsdcore.statistics.MinStatistic
 
getAliases() - Method in interface com.arpnetworking.tsdcore.statistics.Statistic
Accessor for any aliases of the statistic.
getAliases() - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic
 
getAllocations() - Method in class com.arpnetworking.clusteraggregator.ClusterStatusCache.StatusResponse
 
getAllocations() - Method in class com.arpnetworking.clusteraggregator.models.StatusResponse
 
getAs(Class<? extends T>) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getAs(Class<? extends T>) - Method in class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration
 
getAs(Class<? extends T>, T) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getAs(Class<? extends T>, T) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getAs(Type) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getAs(Type) - Method in class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration
 
getAs(Type, T) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getAs(Type, T) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getAysncHttpClientUri() - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
Accessor for the AysncHttpClient Uri.
getBody() - Method in class com.arpnetworking.clusteraggregator.models.HttpRequest
 
getBrokers() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse
 
getBrokers() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient
Gets the list of brokers from the Circonus API.
getCalculateClusterAggregations() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getCalculatedValues() - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
 
getCause() - Method in class com.arpnetworking.tsdcore.sinks.circonus.BrokerRefresher.BrokerLookupFailure
 
getCheckBundle() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CheckBundleActivator.NotifyCheckBundle
 
getCheckBundle(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient
Gets a check bundle in Circonus.
getCid() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker
 
getCid() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle
 
getCluster() - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
 
getCluster() - Method in class com.arpnetworking.tsdcore.model.FQDSN
 
getCluster() - Method in class com.arpnetworking.tsdcore.model.FQSN
 
getClusterHostSuffix() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getClusterLeader() - Method in class com.arpnetworking.clusteraggregator.models.StatusResponse
 
getClusterPipelineConfiguration() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getClusterState() - Method in class com.arpnetworking.clusteraggregator.ClusterStatusCache.StatusResponse
 
getClusterStatusInterval() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getCn() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails
 
getConditions() - Method in class com.arpnetworking.tsdcore.model.PeriodicData
 
getConfig() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle
 
getConfiguration() - Method in class com.arpnetworking.clusteraggregator.configuration.ConfigurableActorProxy.ApplyConfiguration
 
getCount() - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
getCount() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
getCreatedAt() - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
getCreatedAt() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
getCreatedAt() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
getCurrentAllocations() - Method in class com.arpnetworking.utility.ParallelLeastShardAllocationStrategy.RebalanceNotification
 
getCurrentShards() - Method in class com.arpnetworking.clusteraggregator.models.ShardAllocation
 
getData() - Method in class com.arpnetworking.tsdcore.model.CalculatedValue
 
getData() - Method in class com.arpnetworking.tsdcore.model.PeriodicData
 
getData() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSinkActor.EmitAggregation
 
getData() - Method in class com.arpnetworking.tsdcore.sinks.HttpSinkActor.EmitAggregation
 
getData() - Method in class com.arpnetworking.tsdcore.sinks.TcpSinkActor.EmitAggregation
 
getDatabaseConfigurations() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getDataSource() - Method in class com.arpnetworking.utility.Database
 
getDependencies() - Method in class com.arpnetworking.tsdcore.statistics.BaseStatistic
 
getDependencies() - Method in class com.arpnetworking.tsdcore.statistics.ExpressionStatistic
 
getDependencies() - Method in class com.arpnetworking.tsdcore.statistics.MeanStatistic
 
getDependencies() - Method in interface com.arpnetworking.tsdcore.statistics.Statistic
Accessor for any dependencies.
getDependencies() - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic
 
getDetails() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker
 
getDimensions() - Method in class com.arpnetworking.tsdcore.model.PeriodicData
 
getDriverName() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
getEbeanServer() - Method in class com.arpnetworking.utility.Database
 
getEnterTime() - Method in class com.arpnetworking.tsdcore.model.RequestEntry
 
getEntries() - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
getEntriesCount() - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSnapshot
 
getExistingPartition(String) - Method in class com.arpnetworking.clusteraggregator.partitioning.DatabasePartitionSet
 
getExistingPartition(String) - Method in class com.arpnetworking.clusteraggregator.partitioning.InMemoryPartitionSet
 
getExistingPartition(String) - Method in interface com.arpnetworking.utility.partitioning.PartitionSet
Will return an existing partition mapping, or Optional.absent if one does not exist.
getExtensions() - Method in class com.arpnetworking.tsdcore.model.Condition
 
getFlyway() - Method in class com.arpnetworking.utility.Database
 
getFQDSN() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
 
getFQDSN() - Method in class com.arpnetworking.tsdcore.model.Condition
 
getFull() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
getHeaders() - Method in class com.arpnetworking.clusteraggregator.models.HttpRequest
 
getHistogramSnapshot() - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSupportingData
 
getHost() - Method in class com.arpnetworking.clusteraggregator.models.ShardAllocation
 
getHost() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
Deprecated.
Migrate to PeriodicData.
getHostPipelineConfiguration() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getHttpHealthCheckPath() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getHttpHost() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getHttpPort() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getHttpStatusPath() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getHttpVersionPath() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getId() - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
getId() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
getId() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
getIdleTimeout() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
getIncomingShards() - Method in class com.arpnetworking.clusteraggregator.models.ShardAllocation
 
getInflightRebalances() - Method in class com.arpnetworking.utility.ParallelLeastShardAllocationStrategy.RebalanceNotification
 
getInstance() - Static method in class com.arpnetworking.clusteraggregator.models.VersionInfo
 
getIpAddress() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails
 
getJdbcUrl() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
getJsonSource() - Method in class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration
Accessor for active root JsonNodeSource instance.
getJsonSource() - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration
 
getJsonSource() - Method in class com.arpnetworking.configuration.jackson.StaticConfiguration
 
getJvmMetricsCollectionInterval() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getKey() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
getLatestPeriod() - Method in class com.arpnetworking.clusteraggregator.models.PeriodMetrics
 
getLength() - Method in class com.arpnetworking.tsdcore.model.AggregationMessage
 
getLocalAddress() - Method in class com.arpnetworking.clusteraggregator.models.StatusResponse
 
getLocalHostName() - Method in class com.arpnetworking.utility.DefaultHostResolver
 
getLocalHostName() - Method in interface com.arpnetworking.utility.HostResolver
Provides the local host name.
getLocalMetrics() - Method in class com.arpnetworking.clusteraggregator.models.StatusResponse
 
getLogDirectory() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getMaxConnectionTimeout() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getMaximumAttempts() - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
Accessor for the MaximumAttempts.
getMaximumEntriesPerPartition() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
getMaximumPartitions() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
getMaximumPoolSize() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
getMaxParallel() - Method in class com.arpnetworking.clusteraggregator.configuration.RebalanceConfiguration
 
getMembers() - Method in class com.arpnetworking.clusteraggregator.models.StatusResponse
 
getMessage() - Method in class com.arpnetworking.tsdcore.model.AggregationMessage
 
getMetric() - Method in class com.arpnetworking.tsdcore.model.FQDSN
 
getMetric() - Method in class com.arpnetworking.tsdcore.model.FQSN
 
getMetricName() - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
 
getMetrics() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle
 
getMetricSafeName() - Method in class com.arpnetworking.tsdcore.sinks.BaseSink
 
getMetricsLatestPeriod() - Method in class com.arpnetworking.clusteraggregator.models.PeriodMetrics
 
getMigrationLocations() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
getMigrationSchemas() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
getMinConnectionTimeout() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getMinimumIdle() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
getMinRequestTime() - Method in class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregationBucket
 
getMinRequestTime() - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
 
getMinRequestTime() - Method in class com.arpnetworking.tsdcore.model.PeriodicData
 
getModelPackages() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
getModules() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails
 
getMonitoringCluster() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getMonitoringHost() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
Deprecated.
getMonitoringPort() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
Deprecated.
getMonitoringService() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getMonitoringSinks() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getName() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
getName() - Method in class com.arpnetworking.clusteraggregator.models.VersionInfo
 
getName() - Method in class com.arpnetworking.tsdcore.model.Condition
 
getName() - Method in class com.arpnetworking.tsdcore.sinks.BaseSink
 
getName() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker
 
getName() - Method in class com.arpnetworking.tsdcore.statistics.CountStatistic
 
getName() - Method in class com.arpnetworking.tsdcore.statistics.ExpressionStatistic
 
getName() - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic
 
getName() - Method in class com.arpnetworking.tsdcore.statistics.MaxStatistic
 
getName() - Method in class com.arpnetworking.tsdcore.statistics.MeanStatistic
 
getName() - Method in class com.arpnetworking.tsdcore.statistics.MedianStatistic
 
getName() - Method in class com.arpnetworking.tsdcore.statistics.MinStatistic
 
getName() - Method in interface com.arpnetworking.tsdcore.statistics.Statistic
Accessor for the name of the statistic.
getName() - Method in class com.arpnetworking.tsdcore.statistics.SumStatistic
 
getName() - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic
 
getName() - Method in class com.arpnetworking.utility.Database
 
getOrCreateCheckBundle(CheckBundle) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient
Gets or creates a check bundle in Circonus.
getOrCreatePartition(String) - Method in class com.arpnetworking.clusteraggregator.partitioning.DatabasePartitionSet
 
getOrCreatePartition(String) - Method in class com.arpnetworking.clusteraggregator.partitioning.InMemoryPartitionSet
 
getOrCreatePartition(String) - Method in interface com.arpnetworking.utility.partitioning.PartitionSet
Will return the partition mapping, creating one if possible.
getOther() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle
 
getOutgoingShards() - Method in class com.arpnetworking.clusteraggregator.models.ShardAllocation
 
getPartition() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
getPartition(PartitionSet, int, Database) - Static method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
Fetches a partition by partitionSet and partitionNumber.
getPartitionNumber() - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
getPartitionSet() - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
getParts() - Method in class com.arpnetworking.configuration.jackson.DynamicConfigurationFactory.Key
 
getPassword() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
getPath() - Method in class com.arpnetworking.clusteraggregator.models.HttpRequest
 
getPekkoConfiguration() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getPendingRebalances() - Method in class com.arpnetworking.utility.ParallelLeastShardAllocationStrategy.RebalanceNotification
 
getPercentile() - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic
Accessor for the percentile from 0 to 100 (inclusive).
getPeriod() - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
 
getPeriod() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
Deprecated.
Migrate to PeriodicData.
getPeriod() - Method in class com.arpnetworking.tsdcore.model.FQSN
 
getPeriod() - Method in class com.arpnetworking.tsdcore.model.PeriodicData
 
getPeriodStart() - Method in class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregationBucket
 
getPeriodStart() - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
 
getPeriodStart() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
Deprecated.
Migrate to PeriodicData.
getPoolSize() - Method in class com.arpnetworking.clusteraggregator.configuration.EmitterConfiguration
 
getPopulationSize() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
 
getPopulationSize() - Method in class com.arpnetworking.tsdcore.model.RequestEntry
 
getPrecision() - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSnapshot
 
getProperty(String) - Method in interface com.arpnetworking.configuration.Configuration
Retrieve the value of a particular property by its name.
getProperty(String) - Method in class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration
 
getProperty(String, String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getProperty(String, String) - Method in interface com.arpnetworking.configuration.Configuration
Retrieve the value of a particular property by its name and if it does not exist return the specified default.
getPropertyAs(String, Class<? extends T>) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getPropertyAs(String, Class<? extends T>) - Method in class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration
 
getPropertyAs(String, Class<? extends T>, T) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAs(String, Class<? extends T>, T) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getPropertyAs(String, Type) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getPropertyAs(String, Type) - Method in class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration
 
getPropertyAs(String, Type, T) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAs(String, Type, T) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getPropertyAsBoolean(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsBoolean(String) - Method in interface com.arpnetworking.configuration.Configuration
Boolean specific accessor.
getPropertyAsBoolean(String, boolean) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsBoolean(String, boolean) - Method in interface com.arpnetworking.configuration.Configuration
Boolean specific accessor.
getPropertyAsDouble(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsDouble(String) - Method in interface com.arpnetworking.configuration.Configuration
Double specific accessor.
getPropertyAsDouble(String, double) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsDouble(String, double) - Method in interface com.arpnetworking.configuration.Configuration
Double specific accessor.
getPropertyAsFloat(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsFloat(String) - Method in interface com.arpnetworking.configuration.Configuration
Float specific accessor.
getPropertyAsFloat(String, float) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsFloat(String, float) - Method in interface com.arpnetworking.configuration.Configuration
Float specific accessor.
getPropertyAsInteger(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsInteger(String) - Method in interface com.arpnetworking.configuration.Configuration
Integer specific accessor.
getPropertyAsInteger(String, int) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsInteger(String, int) - Method in interface com.arpnetworking.configuration.Configuration
Integer specific accessor.
getPropertyAsLong(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsLong(String) - Method in interface com.arpnetworking.configuration.Configuration
Long specific accessor.
getPropertyAsLong(String, long) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsLong(String, long) - Method in interface com.arpnetworking.configuration.Configuration
Long specific accessor.
getPropertyAsShort(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsShort(String) - Method in interface com.arpnetworking.configuration.Configuration
Short specific accessor.
getPropertyAsShort(String, short) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getPropertyAsShort(String, short) - Method in interface com.arpnetworking.configuration.Configuration
Short specific accessor.
getReaggregationDimensions() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getReaggregationInjectClusterAsHost() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getReaggregationTimeout() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getRebalanceConfiguration() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
getRequest() - Method in class com.arpnetworking.tsdcore.model.RequestEntry
 
GetRequest() - Constructor for class com.arpnetworking.clusteraggregator.ClusterStatusCache.GetRequest
 
getRequiredAs(Class<? extends T>) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredAs(Class<? extends T>) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getRequiredAs(Type) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredAs(Type) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getRequiredProperty(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredProperty(String) - Method in interface com.arpnetworking.configuration.Configuration
Retrieve the value of a particular property by its name and if it does not exist throw a RuntimeException.
getRequiredPropertyAs(String, Class<? extends T>) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredPropertyAs(String, Class<? extends T>) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getRequiredPropertyAs(String, Type) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredPropertyAs(String, Type) - Method in interface com.arpnetworking.configuration.Configuration
Generic object accessor.
getRequiredPropertyAsBoolean(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredPropertyAsBoolean(String) - Method in interface com.arpnetworking.configuration.Configuration
Boolean specific accessor.
getRequiredPropertyAsDouble(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredPropertyAsDouble(String) - Method in interface com.arpnetworking.configuration.Configuration
Double specific accessor.
getRequiredPropertyAsFloat(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredPropertyAsFloat(String) - Method in interface com.arpnetworking.configuration.Configuration
Float specific accessor.
getRequiredPropertyAsInteger(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredPropertyAsInteger(String) - Method in interface com.arpnetworking.configuration.Configuration
Integer specific accessor.
getRequiredPropertyAsLong(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredPropertyAsLong(String) - Method in interface com.arpnetworking.configuration.Configuration
Long specific accessor.
getRequiredPropertyAsShort(String) - Method in class com.arpnetworking.configuration.BaseConfiguration
 
getRequiredPropertyAsShort(String) - Method in interface com.arpnetworking.configuration.Configuration
Short specific accessor.
getResponse() - Method in class com.arpnetworking.tsdcore.sinks.circonus.BrokerRefresher.BrokerLookupComplete
 
getRetryBaseBackoff() - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
Accessor for the BaseBackoff of retries Duration.
getRetryMaximumDelay() - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
Accessor for the MaximumDelay of retries Duration.
getSamples() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
 
getService() - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
 
getService() - Method in class com.arpnetworking.tsdcore.model.FQDSN
 
getService() - Method in class com.arpnetworking.tsdcore.model.FQSN
 
getServicesLatestPeriod() - Method in class com.arpnetworking.clusteraggregator.models.PeriodMetrics
 
getSha() - Method in class com.arpnetworking.clusteraggregator.models.VersionInfo
 
getShardRegion() - Method in class com.arpnetworking.clusteraggregator.models.ShardAllocation
 
getSinks() - Method in class com.arpnetworking.clusteraggregator.configuration.EmitterConfiguration
 
getSkew() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails
 
getSmallerUnit(Unit) - Method in enum class com.arpnetworking.tsdcore.model.Unit
Gets the smaller unit of two.
getSmallerUnit(Optional<Unit>, Optional<Unit>) - Static method in enum class com.arpnetworking.tsdcore.model.Unit
Return the smaller of two Optional units or absent if neither is present.
getSmallestUnit() - Method in enum class com.arpnetworking.tsdcore.model.Unit
Gets the smallest unit for this unit's type.
getSnapshot() - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.Histogram
 
getStart() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
Deprecated.
Migrate to PeriodicData.
getStart() - Method in class com.arpnetworking.tsdcore.model.FQSN
 
getStart() - Method in class com.arpnetworking.tsdcore.model.PeriodicData
 
getStatistic() - Method in class com.arpnetworking.tsdcore.model.FQDSN
 
getStatistic() - Method in class com.arpnetworking.tsdcore.model.FQSN
 
getStatistic() - Method in class com.arpnetworking.tsdcore.statistics.BaseCalculator
 
getStatistic() - Method in interface com.arpnetworking.tsdcore.statistics.Calculator
Accessor for the Statistic computed by this Calculator.
getStatistic(String) - Method in class com.arpnetworking.tsdcore.statistics.StatisticFactory
Get a statistic by name.
getStatisticsLatestPeriod() - Method in class com.arpnetworking.clusteraggregator.models.PeriodMetrics
 
getStatus() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails
 
getStatus() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle
 
getSubmissionUrl() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle
Gets the submission url for an http trap check bundle.
getSupportingData() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
 
getTags() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker
 
getThreshold() - Method in class com.arpnetworking.clusteraggregator.configuration.RebalanceConfiguration
 
getThreshold() - Method in class com.arpnetworking.tsdcore.model.Condition
 
getTimestamp() - Method in class com.arpnetworking.utility.ParallelLeastShardAllocationStrategy.RebalanceNotification
 
getType() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker
 
getUnit() - Method in class com.arpnetworking.tsdcore.model.Quantity
 
getUnit() - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSupportingData
 
getUpdatedAt() - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
getUpdatedAt() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
getUpdatedAt() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
getUri() - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
Accessor for the URI.
getUsername() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
getUserSpecified() - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData.StatisticValue
 
getValue() - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData.StatisticValue
 
getValue() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
 
getValue() - Method in class com.arpnetworking.tsdcore.model.CalculatedValue
 
getValue() - Method in class com.arpnetworking.tsdcore.model.Quantity
 
getValue(String...) - Method in class com.arpnetworking.configuration.jackson.HoconFileSource
Retrieve the JsonNode by looking up the sequence of keys or return Optional.empty() if any key in the sequence does not exist.
getValue(String...) - Method in class com.arpnetworking.configuration.jackson.JsonNodeDirectorySource
 
getValue(String...) - Method in class com.arpnetworking.configuration.jackson.JsonNodeFileSource
 
getValue(String...) - Method in class com.arpnetworking.configuration.jackson.JsonNodeLiteralSource
 
getValue(String...) - Method in class com.arpnetworking.configuration.jackson.JsonNodeMergingSource
 
getValue(String...) - Method in class com.arpnetworking.configuration.jackson.JsonNodePaginatedUriSource
 
getValue(String...) - Method in interface com.arpnetworking.configuration.jackson.JsonNodeSource
Retrieve the JsonNode by looking up the sequence of keys or return Optional.empty() if any key in the sequence does not exist.
getValue(String...) - Method in class com.arpnetworking.configuration.jackson.JsonNodeUriSource
 
getValue(Optional<JsonNode>, String...) - Static method in class com.arpnetworking.configuration.jackson.BaseJsonNodeSource
Find the JsonNode if one exists from a specified root node given a sequence of keys to look-up.
getValueAtPercentile(double) - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSnapshot
Gets the value of the bucket that corresponds to the percentile.
getValues() - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSnapshot
 
getVersion() - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
getVersion() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
getVersion() - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
getVersion() - Method in class com.arpnetworking.clusteraggregator.models.VersionInfo
 
getVersion() - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails
 
getVersionInfo() - Method in class com.arpnetworking.clusteraggregator.models.StatusResponse
 
GIGABIT - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Gigabits.
GIGABYTE - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Gigabytes.
GracefulShutdownActor - Class in com.arpnetworking.clusteraggregator
Shuts down the Pekko cluster gracefully.
GracefulShutdownActor(ActorRef) - Constructor for class com.arpnetworking.clusteraggregator.GracefulShutdownActor
Public constructor.
GracefulShutdownActor.Shutdown - Class in com.arpnetworking.clusteraggregator
Message to initiate a graceful shutdown.
GuiceActorCreator - Class in com.arpnetworking.guice.pekko
A Guice-based factory for Pekko actors.
GuiceActorCreator(Injector, Class<? extends Actor>) - Constructor for class com.arpnetworking.guice.pekko.GuiceActorCreator
Public constructor.
GuiceModule - Class in com.arpnetworking.clusteraggregator
The primary Guice module used to bootstrap the cluster aggregator.
GuiceModule(ClusterAggregatorConfiguration, LifecycleRegistration) - Constructor for class com.arpnetworking.clusteraggregator.GuiceModule
Public constructor.

H

hashCode() - Method in class com.arpnetworking.configuration.jackson.DynamicConfigurationFactory.Key
 
hashCode() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
 
hashCode() - Method in class com.arpnetworking.tsdcore.model.FQDSN
 
hashCode() - Method in class com.arpnetworking.tsdcore.model.FQSN
 
hashCode() - Method in class com.arpnetworking.tsdcore.model.PeriodicData
 
hashCode() - Method in class com.arpnetworking.tsdcore.model.Quantity
 
hashCode() - Method in class com.arpnetworking.tsdcore.statistics.BaseCalculator
 
hashCode() - Method in class com.arpnetworking.tsdcore.statistics.BaseStatistic
 
hashCode() - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic
 
hashCode() - Method in class com.arpnetworking.tsdcore.statistics.TPStatistic.PercentileCalculator
 
HealthRequest() - Constructor for class com.arpnetworking.clusteraggregator.Status.HealthRequest
 
Histogram() - Constructor for class com.arpnetworking.tsdcore.statistics.HistogramStatistic.Histogram
Public constructor.
Histogram(int) - Constructor for class com.arpnetworking.tsdcore.statistics.HistogramStatistic.Histogram
Public constructor.
HistogramStatistic - Class in com.arpnetworking.tsdcore.statistics
Histogram statistic.
HistogramStatistic.Histogram - Class in com.arpnetworking.tsdcore.statistics
A simple histogram implementation.
HistogramStatistic.HistogramSnapshot - Class in com.arpnetworking.tsdcore.statistics
Represents a snapshot of immutable histogram data.
HistogramStatistic.HistogramSupportingData - Class in com.arpnetworking.tsdcore.statistics
Supporting data based on a histogram.
HistogramStatistic.HistogramSupportingData.Builder - Class in com.arpnetworking.tsdcore.statistics
Builder implementation for HistogramStatistic.HistogramSupportingData.
HistogramSupportingData(HistogramStatistic.HistogramSupportingData.Builder) - Constructor for class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSupportingData
Public constructor.
HoconFileSource - Class in com.arpnetworking.configuration.jackson
Typesafe config based configuration sourced from a file and mapped to a JsonNode.
HoconFileSource.Builder - Class in com.arpnetworking.configuration.jackson
Builder for HoconFileSource.
HOST_KEY - Static variable in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
The key used in dimensions to specify the host-dimension.
HostResolver - Interface in com.arpnetworking.utility
Used to get the local hostname.
HOUR - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Hours.
HttpPostSink - Class in com.arpnetworking.tsdcore.sinks
Publishes to an HTTP endpoint.
HttpPostSink(HttpPostSink.Builder<?, ?>) - Constructor for class com.arpnetworking.tsdcore.sinks.HttpPostSink
Protected constructor.
HttpPostSink.Builder<B extends BaseSink.Builder<B,S>,S extends HttpPostSink> - Class in com.arpnetworking.tsdcore.sinks
Implementation of abstract builder pattern for HttpPostSink.
HttpRequest - Class in com.arpnetworking.clusteraggregator.models
Represents a parsable HTTP request.
HttpRequest(String, ImmutableMultimap<String, String>, ByteString) - Constructor for class com.arpnetworking.clusteraggregator.models.HttpRequest
Public constructor.
HttpSinkActor - Class in com.arpnetworking.tsdcore.sinks
Actor that sends HTTP requests via a Ning HTTP client.
HttpSinkActor(AsyncHttpClient, HttpPostSink, int, int, Duration, PeriodicMetrics) - Constructor for class com.arpnetworking.tsdcore.sinks.HttpSinkActor
Public constructor.
HttpSinkActor.EmitAggregation - Class in com.arpnetworking.tsdcore.sinks
Message class to wrap a list of AggregatedData.
HttpSourceActor - Class in com.arpnetworking.clusteraggregator.client
Source that uses HTTP POSTs as input.
HttpSourceActor(ActorRef, ActorRef, ClusterAggregatorConfiguration, PeriodicMetrics) - Constructor for class com.arpnetworking.clusteraggregator.client.HttpSourceActor
Public constructor.

I

INCOMING_DATA_PERSIST_V1_PATH - Static variable in class com.arpnetworking.clusteraggregator.http.Routes
This HTTP endpoint is for only persisting data directly and through the host emitter.
INCOMING_DATA_REAGGREGATE_V1_PATH - Static variable in class com.arpnetworking.clusteraggregator.http.Routes
This HTTP endpoint is for only reaggregating data and then persisting through the cluster emitter.
INCOMING_DATA_V1_PATH - Static variable in class com.arpnetworking.clusteraggregator.http.Routes
The legacy path for incoming data over HTTP.
InfluxDbSink - Class in com.arpnetworking.tsdcore.sinks
Publishes to a InfluxDB endpoint.
InfluxDbSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for InfluxDbSink.
InMemoryPartitionSet - Class in com.arpnetworking.clusteraggregator.partitioning
Simple in-memory partition manager.
InMemoryPartitionSet(int, int) - Constructor for class com.arpnetworking.clusteraggregator.partitioning.InMemoryPartitionSet
Public constructor.
instance() - Static method in class com.arpnetworking.clusteraggregator.GracefulShutdownActor.Shutdown
Gets the singleton instance of this object.
InterfaceDatabase - Interface in com.arpnetworking.utility
This class provides searchable access to classes by interface.
isLeader() - Method in class com.arpnetworking.clusteraggregator.models.StatusResponse
 
isSmallerThan(Unit) - Method in enum class com.arpnetworking.tsdcore.model.Unit
Determines if the current unit is smaller than another.
isSpecified() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
 
isSpecified(Statistic) - Method in class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregationBucket
Looks up a Statistic to see if it is user specified.
isTriggered() - Method in class com.arpnetworking.tsdcore.model.Condition
 

J

JsonNodeDirectorySource - Class in com.arpnetworking.configuration.jackson
JsonNode based configuration sourced from a directory.
JsonNodeDirectorySource.Builder - Class in com.arpnetworking.configuration.jackson
JsonNodeFileSource - Class in com.arpnetworking.configuration.jackson
JsonNode based configuration sourced from a file.
JsonNodeFileSource.Builder - Class in com.arpnetworking.configuration.jackson
Builder for JsonNodeFileSource.
JsonNodeLiteralSource - Class in com.arpnetworking.configuration.jackson
JsonNode based configuration sourced from a literal string.
JsonNodeLiteralSource.Builder - Class in com.arpnetworking.configuration.jackson
JsonNodeMergingSource - Class in com.arpnetworking.configuration.jackson
Json based configuration sourced by merging zero or more JsonNodeSource instances together.
JsonNodeMergingSource.Builder - Class in com.arpnetworking.configuration.jackson
Builder implementation for JsonNodeMergingSource.
JsonNodePaginatedUriSource - Class in com.arpnetworking.configuration.jackson
JsonNode based configuration sourced from a paginated URI.
JsonNodePaginatedUriSource.Builder - Class in com.arpnetworking.configuration.jackson
Builder for JsonNodeUriSource.
JsonNodeSource - Interface in com.arpnetworking.configuration.jackson
Interface for sourcing JsonNode based configuration.
JsonNodeUriSource - Class in com.arpnetworking.configuration.jackson
JsonNode based configuration sourced from a file.
JsonNodeUriSource.Builder - Class in com.arpnetworking.configuration.jackson
Builder for JsonNodeUriSource.
JvmMetricsCollector - Class in com.arpnetworking.clusteraggregator
Actor responsible for collecting JVM metrics on a periodic basis.

K

KairosDbSink - Class in com.arpnetworking.tsdcore.sinks
Publishes to a KairosDbSink endpoint.
KairosDbSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for KairosDbSink.
KELVIN - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Kelvin.
Key(String) - Constructor for class com.arpnetworking.configuration.jackson.DynamicConfigurationFactory.Key
Public constructor for key with one part.
Key(String...) - Constructor for class com.arpnetworking.configuration.jackson.DynamicConfigurationFactory.Key
Public constructor from an array or variable number of key parts.
Key(String, String) - Constructor for class com.arpnetworking.configuration.jackson.DynamicConfigurationFactory.Key
Public constructor for key with two parts.
Key(List<String>) - Constructor for class com.arpnetworking.configuration.jackson.DynamicConfigurationFactory.Key
Public constructor from a list of key parts.
keyToFileName(DynamicConfigurationFactory.Key) - Method in class com.arpnetworking.configuration.jackson.DirectoryDynamicConfigurationFactory
Convert the DynamicConfigurationFactory.Key to a file name.
KILOBIT - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Kilobits.
KILOBYTE - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Kilobytes.
KMonDSink - Class in com.arpnetworking.tsdcore.sinks
Publishes aggregations to KMonD.
KMonDSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for MonitordSink.

L

launch() - Method in class com.arpnetworking.clusteraggregator.Main
Launch the component.
launch() - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration
 
launch() - Method in class com.arpnetworking.utility.Configurator
 
launch() - Method in class com.arpnetworking.utility.Database
 
launch() - Method in interface com.arpnetworking.utility.Launchable
Launch the component.
Launchable - Interface in com.arpnetworking.utility
Interface for components which can be started and stopped.
LexicalNumericComparator - Class in com.arpnetworking.utility
Compares strings lexically and numerically by splitting on digits and using the full number for numerical comparison.
LexicalNumericComparator() - Constructor for class com.arpnetworking.utility.LexicalNumericComparator
 
LifecycleRegistration - Interface in com.arpnetworking.clusteraggregator
Provides a way to register for lifecycle events, ensuring that Guice-instantiated classes can be notified.
Listener - Interface in com.arpnetworking.configuration
Interface for consumers registered for configuration events.
lock(Database) - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
Locks the record with a select for update.
lock(Database) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
Locks the record with a select for update.

M

main(String[]) - Static method in class com.arpnetworking.clusteraggregator.Main
Entry point.
Main - Class in com.arpnetworking.clusteraggregator
Entry point for the pekko-based cluster aggregator.
Main(ClusterAggregatorConfiguration) - Constructor for class com.arpnetworking.clusteraggregator.Main
Public constructor.
map(Function0<T>) - Method in class com.arpnetworking.utility.CollectFutureBuilder
Method to create a <T> from the completed Futures.
MaxAccumulator(Statistic) - Constructor for class com.arpnetworking.tsdcore.statistics.MaxStatistic.MaxAccumulator
Public constructor.
MaxStatistic - Class in com.arpnetworking.tsdcore.statistics
Max statistic (e.g.
MaxStatistic.MaxAccumulator - Class in com.arpnetworking.tsdcore.statistics
Accumulator computing the maximum of values.
MeanCalculator(Statistic) - Constructor for class com.arpnetworking.tsdcore.statistics.MeanStatistic.MeanCalculator
Public constructor.
MeanStatistic - Class in com.arpnetworking.tsdcore.statistics
Takes the mean of the entries.
MeanStatistic.MeanCalculator - Class in com.arpnetworking.tsdcore.statistics
Calculator computing the average.
MedianStatistic - Class in com.arpnetworking.tsdcore.statistics
Top median statistic (aka 50th percentile).
MEGABIT - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Megabits.
MEGABYTE - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Megabytes.
MergingDynamicConfigurationFactory - Class in com.arpnetworking.configuration.jackson
Implementation of DynamicConfigurationFactory which maps keys to zero or more subordinate DynamicConfigurationFactory instances.
MergingDynamicConfigurationFactory.Builder - Class in com.arpnetworking.configuration.jackson
Builder implementation for MergingDynamicConfigurationFactory.
MetricNameFilteringSink - Class in com.arpnetworking.tsdcore.sinks
A publisher that wraps another, filters the metrics with regular expressions, and forwards included metrics to the wrapped sink.
MetricNameFilteringSink(MetricNameFilteringSink.Builder) - Constructor for class com.arpnetworking.tsdcore.sinks.MetricNameFilteringSink
Protected constructor.
MetricNameFilteringSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Base MetricNameFilteringSink.Builder implementation.
MetricsRequest - Class in com.arpnetworking.clusteraggregator.models
Message class to request the collected metrics.
MetricsRequest() - Constructor for class com.arpnetworking.clusteraggregator.models.MetricsRequest
Public constructor.
MetricType - Enum Class in com.arpnetworking.tsdcore.model
The type of data.
MICROSECOND - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Microseconds.
MILLISECOND - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Milliseconds.
MinAccumulator(Statistic) - Constructor for class com.arpnetworking.tsdcore.statistics.MinStatistic.MinAccumulator
Public constructor.
MinStatistic - Class in com.arpnetworking.tsdcore.statistics
Min statistic (e.g.
MinStatistic.MinAccumulator - Class in com.arpnetworking.tsdcore.statistics
Accumulator computing the minimum of values.
MINUTE - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Minutes.
MonitordSink - Class in com.arpnetworking.tsdcore.sinks
Publishes aggregations to Monitord.
MonitordSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for MonitordSink.
multiply(Quantity) - Method in class com.arpnetworking.tsdcore.model.Quantity
Multiply this Quantity with the specified one returning the result.
MultiSink - Class in com.arpnetworking.tsdcore.sinks
A publisher that wraps multiple others and publishes to all of them.
MultiSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for MultiSink.

N

NANOSECOND - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Nanoseconds.
newInstance() - Static method in class com.arpnetworking.tsdcore.statistics.StatisticDeserializer
Create a new instance of JsonDeserializer<Statistic>.
newInstance() - Static method in class com.arpnetworking.utility.ReflectionsDatabase
Create a new instance of InterfaceDatabase.
NotifyCheckBundle(CheckBundle) - Constructor for class com.arpnetworking.tsdcore.sinks.circonus.CheckBundleActivator.NotifyCheckBundle
Public constructor.

O

offerConfiguration(Configuration) - Method in interface com.arpnetworking.configuration.Listener
Invoked before new configuration is applied.
offerConfiguration(Configuration) - Method in class com.arpnetworking.utility.ActorConfigurator
 
offerConfiguration(Configuration) - Method in class com.arpnetworking.utility.Configurator
 
offerConfiguration(Configuration) - Method in class com.arpnetworking.utility.Reconfigurator
 
onReceive(Object) - Method in class com.arpnetworking.clusteraggregator.client.AggClientServer
 
OrderedStatistic - Interface in com.arpnetworking.tsdcore.statistics
Marker interface for statistics which require values to be ordered from smallest to largest.

P

ParallelLeastShardAllocationStrategy - Class in com.arpnetworking.utility
Implementation of the least shard allocation strategy that seeks to parallelize shard rebalancing.
ParallelLeastShardAllocationStrategy(int, int, Optional<ActorSelection>) - Constructor for class com.arpnetworking.utility.ParallelLeastShardAllocationStrategy
Public constructor.
ParallelLeastShardAllocationStrategy.RebalanceNotification - Class in com.arpnetworking.utility
Notification message that contains rebalance status.
Partition - Class in com.arpnetworking.clusteraggregator.models.ebean
Model that holds the count of entries in a partition.
Partition() - Constructor for class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
PartitionEntry - Class in com.arpnetworking.clusteraggregator.models.ebean
Model that holds the data for a partition.
PartitionEntry() - Constructor for class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
PartitionSet - Class in com.arpnetworking.clusteraggregator.models.ebean
Model that holds the aggregate partitions for a PartitionSet.
PartitionSet - Interface in com.arpnetworking.utility.partitioning
Represents a set of partitions and a way to register and retrieve the mappings.
PartitionSetFactory - Interface in com.arpnetworking.utility.partitioning
Factory for creating partition sets.
pause() - Method in class com.arpnetworking.pekko.UniformRandomTimeScheduler
Pauses the scheduling of messages.
PekkoLoggingModule - Class in com.arpnetworking.configuration.jackson.pekko
Jackson module for serializing and deserializing Pekko objects.
PekkoLoggingModule() - Constructor for class com.arpnetworking.configuration.jackson.pekko.PekkoLoggingModule
Public constructor.
PekkoModule - Class in com.arpnetworking.configuration.jackson.pekko
Jackson module for serializing and deserializing Pekko objects.
PekkoModule(ActorSystem) - Constructor for class com.arpnetworking.configuration.jackson.pekko.PekkoModule
Public constructor.
PercentileCalculator(TPStatistic) - Constructor for class com.arpnetworking.tsdcore.statistics.TPStatistic.PercentileCalculator
Public constructor.
PeriodFilteringSink - Class in com.arpnetworking.tsdcore.sinks
A publisher that wraps another, filters the metrics with specific periods, and forwards included metrics to the wrapped sink.
PeriodFilteringSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Base PeriodFilteringSink.Builder implementation.
PeriodicData - Class in com.arpnetworking.tsdcore.model
Contains the data for a specific period in time.
PeriodicData.Builder - Class in com.arpnetworking.tsdcore.model
Builder implementation for PeriodicData.
PeriodicStatisticsActor - Class in com.arpnetworking.clusteraggregator
Actor that listens for metrics messages, updates internal state, and emits them.
PeriodicStatisticsActor(MetricsFactory) - Constructor for class com.arpnetworking.clusteraggregator.PeriodicStatisticsActor
Public constructor.
PeriodicStatisticsSink - Class in com.arpnetworking.tsdcore.sinks
Aggregates and periodically logs metrics about the aggregated data being record; effectively, this is metrics about metrics.
PeriodicStatisticsSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for PeriodicStatisticsSink.
PeriodMetrics - Class in com.arpnetworking.clusteraggregator.models
Holds the node metrics for a single period.
PeriodMetrics(MetricsFactory) - Constructor for class com.arpnetworking.clusteraggregator.models.PeriodMetrics
Public constructor.
PERSIST - Enum constant in enum class com.arpnetworking.clusteraggregator.models.AggregationMode
Persist the statistics data as provided by the client.
PERSIST_AND_REAGGREGATE - Enum constant in enum class com.arpnetworking.clusteraggregator.models.AggregationMode
Persist the statistics data as provided by the client AND reaggregate the statistics data provided by the client persisting the reaggregated data as well.
PETABIT - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Petabits.
PETABYTE - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Petabytes.
postStop() - Method in class com.arpnetworking.clusteraggregator.aggregation.AggregationRouter
 
postStop() - Method in class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregator
 
postStop() - Method in class com.arpnetworking.clusteraggregator.ClusterStatusCache
 
postStop() - Method in class com.arpnetworking.clusteraggregator.Emitter
 
postStop() - Method in class com.arpnetworking.clusteraggregator.JvmMetricsCollector
 
postStop() - Method in class com.arpnetworking.tsdcore.sinks.circonus.BrokerRefresher
 
postStop() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CheckBundleActivator
 
postStop() - Method in class com.arpnetworking.tsdcore.sinks.HttpSinkActor
 
postStop() - Method in class com.arpnetworking.tsdcore.sinks.TcpSinkActor
preRestart(Throwable, Optional<Object>) - Method in class com.arpnetworking.clusteraggregator.aggregation.AggregationRouter
 
preRestart(Throwable, Optional<Object>) - Method in class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregator
 
preRestart(Throwable, Optional<Object>) - Method in class com.arpnetworking.tsdcore.sinks.HttpSinkActor
 
preStart() - Method in class com.arpnetworking.clusteraggregator.aggregation.AggregationRouter
 
preStart() - Method in class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregator
 
preStart() - Method in class com.arpnetworking.clusteraggregator.client.AggClientServer
 
preStart() - Method in class com.arpnetworking.clusteraggregator.ClusterStatusCache
 
preStart() - Method in class com.arpnetworking.clusteraggregator.JvmMetricsCollector
 
preStart() - Method in class com.arpnetworking.tsdcore.sinks.HttpSinkActor
 
produce() - Method in class com.arpnetworking.guice.pekko.GuiceActorCreator
 
props(EmitterConfiguration) - Static method in class com.arpnetworking.clusteraggregator.Emitter
Creates a Props for construction in Pekko.
props(MetricsFactory) - Static method in class com.arpnetworking.clusteraggregator.PeriodicStatisticsActor
Creates a Props for construction in Pekko.
props(CirconusClient) - Static method in class com.arpnetworking.tsdcore.sinks.circonus.BrokerRefresher
Creates a Props in a type safe way.
props(CirconusClient) - Static method in class com.arpnetworking.tsdcore.sinks.circonus.CheckBundleActivator
Creates a Props in a type safe way.
props(CirconusClient, String, int, int, Duration, boolean, PartitionSet) - Static method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSinkActor
Creates a Props for use in Pekko.
props(TcpSink, String, int, int, Duration) - Static method in class com.arpnetworking.tsdcore.sinks.TcpSinkActor
Factory method to create a Props.
props(ConfiguredLaunchableFactory<Props, T>) - Static method in class com.arpnetworking.clusteraggregator.configuration.ConfigurableActorProxy
Creates a Props.
props(Injector, Class<? extends Actor>) - Static method in class com.arpnetworking.guice.pekko.GuiceActorCreator
Creates a Props for this creator.
props(Duration, MetricsFactory) - Static method in class com.arpnetworking.clusteraggregator.JvmMetricsCollector
Creates a Props for construction in Pekko.
props(ActorRef, InetSocketAddress, FiniteDuration, boolean) - Static method in class com.arpnetworking.clusteraggregator.client.AggClientConnection
Creates a Props for use in Pekko.
props(ActorRef, ActorRef, String, ImmutableSet<String>, boolean, Duration, PeriodicMetrics) - Static method in class com.arpnetworking.clusteraggregator.aggregation.AggregationRouter
Creates a Props for use in Pekko.
props(ActorRef, ActorRef, String, ImmutableSet<String>, boolean, Duration, PeriodicMetrics) - Static method in class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregator
Creates a Props for use in Pekko.
props(ActorSystem, Duration, MetricsFactory) - Static method in class com.arpnetworking.clusteraggregator.ClusterStatusCache
Creates a Props for use in Pekko.
props(Cluster, ActorRef, ActorRef) - Static method in class com.arpnetworking.clusteraggregator.Status
Creates a Props for use in Pekko.
props(AsyncHttpClient, HttpPostSink, int, int, Duration, PeriodicMetrics) - Static method in class com.arpnetworking.tsdcore.sinks.HttpSinkActor
Factory method to create a Props.
provider(Class<? extends Actor>, String) - Static method in class com.arpnetworking.guice.pekko.GuiceActorCreator
Creates a provider that is suitable for eager singleton binding.

Q

Quantity - Class in com.arpnetworking.tsdcore.model
Represents a sample.
Quantity.Builder - Class in com.arpnetworking.tsdcore.model
Builder implementation for Quantity.

R

RandomMetricNameFilterSink - Class in com.arpnetworking.tsdcore.sinks
A Sink that only allows a percentage of data through to the wrapped Sink.
RandomMetricNameFilterSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of the builder pattern for RandomMetricNameFilterSink.
REAGGREGATE - Enum constant in enum class com.arpnetworking.clusteraggregator.models.AggregationMode
Reaggregate the statistics data provided by the client and persist only the reaggregated data.
rebalance(Map<ActorRef, IndexedSeq<String>>, Set<String>) - Method in class com.arpnetworking.utility.ParallelLeastShardAllocationStrategy
 
RebalanceConfiguration - Class in com.arpnetworking.clusteraggregator.configuration
Represents the shard rebalancing configuration.
RebalanceConfiguration.Builder - Class in com.arpnetworking.clusteraggregator.configuration
Builder implementation for RebalanceConfiguration.
RebalanceNotification(Map<ActorRef, Set<String>>, Set<String>, Map<String, ActorRef>) - Constructor for class com.arpnetworking.utility.ParallelLeastShardAllocationStrategy.RebalanceNotification
Public constructor.
Reconfigurator<T extends Relaunchable<? super S>,S> - Class in com.arpnetworking.utility
Manages configuration and reconfiguration of a Relaunchable instance using a POJO representation of its configuration.
Reconfigurator(Relaunchable<S>, Class<? extends S>) - Constructor for class com.arpnetworking.utility.Reconfigurator
Public constructor.
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.DimensionFilteringSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.DimensionInjectingSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.DomainInjectingSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.MetricNameFilteringSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.MultiSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.PeriodFilteringSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.RandomMetricNameFilterSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.RrdSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.ServiceNameFilteringSink
 
recordAggregateData(PeriodicData) - Method in interface com.arpnetworking.tsdcore.sinks.Sink
Called when additional PeriodicData instances are available for publication.
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.TcpSink
Called when additional PeriodicData instances are available for publication.
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.TimeThresholdSink
 
recordAggregateData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.UnitMappingSink
 
recordAggregation(AggregatedData) - Method in class com.arpnetworking.clusteraggregator.models.PeriodMetrics
Stores the report of a metric into the counters.
recordPacked(long, long) - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.Histogram
Records a packed value into the histogram.
recordValue(double) - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.Histogram
Records a value into the histogram.
recordValue(double, long) - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.Histogram
Records a value into the histogram.
ReflectionsDatabase - Class in com.arpnetworking.utility
Default implementation of InterfaceDatabase.
registerShutdown(Supplier<CompletionStage<Void>>) - Method in class com.arpnetworking.clusteraggregator.AppShutdown
Registers a method to be called when the application is shutting down.
registerShutdown(Supplier<CompletionStage<Void>>) - Method in interface com.arpnetworking.clusteraggregator.LifecycleRegistration
Registers a method to be called when the application is shutting down.
relaunch(T) - Method in interface com.arpnetworking.utility.Relaunchable
Relaunch the component.
Relaunchable<T> - Interface in com.arpnetworking.utility
Interface for components which can be restarted.
ReMetGuiDynamicConfigurationFactory - Class in com.arpnetworking.remet.gui
Implementation of DynamicConfigurationFactory which maps two part keys to cluster and service parameter values in API calls to ReMet Gui for configuration data.
ReMetGuiDynamicConfigurationFactory.Builder - Class in com.arpnetworking.remet.gui
Builder implementation for ReMetGuiDynamicConfigurationFactory.
RequestEntry - Class in com.arpnetworking.tsdcore.model
Contains the info for a http request.
RequestEntry.Builder - Class in com.arpnetworking.tsdcore.model
Builder implementation for RequestEntry.
resume() - Method in class com.arpnetworking.pekko.UniformRandomTimeScheduler
Resumes the scheduling of the messages.
Routes - Class in com.arpnetworking.clusteraggregator.http
Http server routes.
Routes(ActorSystem, PeriodicMetrics, String, String, String) - Constructor for class com.arpnetworking.clusteraggregator.http.Routes
Public constructor.
RrdSink - Class in com.arpnetworking.tsdcore.sinks
RRD publisher that maintains all the rrd databases for a cluster.
RrdSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for RrdSink.

S

SECOND - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Seconds.
self() - Method in class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration.Builder
Called by setters to always return appropriate subclass of BaseJacksonConfiguration.Builder, even from setters of base class.
self() - Method in class com.arpnetworking.configuration.jackson.BaseJsonNodeSource.Builder
Called by setters to always return appropriate subclass of BaseJsonNodeSource.Builder, even from setters of base class.
self() - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration.Builder
 
self() - Method in class com.arpnetworking.configuration.jackson.HoconFileSource.Builder
Called by setters to always return appropriate subclass of BaseJsonNodeSource.Builder, even from setters of base class.
self() - Method in class com.arpnetworking.configuration.jackson.JsonNodeDirectorySource.Builder
 
self() - Method in class com.arpnetworking.configuration.jackson.JsonNodeFileSource.Builder
 
self() - Method in class com.arpnetworking.configuration.jackson.JsonNodeLiteralSource.Builder
 
self() - Method in class com.arpnetworking.configuration.jackson.JsonNodePaginatedUriSource.Builder
 
self() - Method in class com.arpnetworking.configuration.jackson.JsonNodeUriSource.Builder
 
self() - Method in class com.arpnetworking.configuration.jackson.StaticConfiguration.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.BaseSink.Builder
Called by setters to always return appropriate subclass of BaseSink.Builder, even from setters of base class.
self() - Method in class com.arpnetworking.tsdcore.sinks.CarbonSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Called by setters to always return appropriate subclass of CirconusSink.Builder, even from setters of base class.
self() - Method in class com.arpnetworking.tsdcore.sinks.DataDogSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.DimensionFilteringSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.DimensionInjectingSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.DomainInjectingSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.InfluxDbSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.KairosDbSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.KMonDSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.MetricNameFilteringSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.MonitordSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.MultiSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.PeriodFilteringSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.RandomMetricNameFilterSink.Builder
Return this instance of RandomMetricNameFilterSink.Builder as this sub-type.
self() - Method in class com.arpnetworking.tsdcore.sinks.RrdSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.ServiceNameFilteringSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.SignalFxSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.TimeThresholdSink.Builder
 
self() - Method in class com.arpnetworking.tsdcore.sinks.UnitMappingSink.Builder
 
sendToHttpTrap(Map<String, Object>, URI) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient
Sends a request to store data to an http trap monitor.
serialize() - Method in class com.arpnetworking.tsdcore.model.AggregationMessage
Serialize the message into a ByteString.
serialize(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.DataDogSink
 
serialize(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
Serialize the PeriodicData instance for posting.
serialize(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.InfluxDbSink
 
serialize(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.KairosDbSink
 
serialize(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.KMonDSink
 
serialize(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.MonitordSink
 
serialize(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.SignalFxSink
 
serialize(ActorRef, JsonGenerator, SerializerProvider) - Method in class com.arpnetworking.configuration.jackson.pekko.ActorRefLoggingSerializer
 
serialize(ActorRef, JsonGenerator, SerializerProvider) - Method in class com.arpnetworking.configuration.jackson.pekko.ActorRefSerializer
 
serializeData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.CarbonSink
 
serializeData(PeriodicData) - Method in class com.arpnetworking.tsdcore.sinks.TcpSink
Serialize a PeriodicData to binary.
SERVICE_KEY - Static variable in class com.arpnetworking.clusteraggregator.models.CombinedMetricData
The key used in dimensions to specify the service-dimension.
ServiceNameFilteringSink - Class in com.arpnetworking.tsdcore.sinks
A publisher that wraps another, filters the metrics with regular expressions, and forwards included metrics to the wrapped sink.
ServiceNameFilteringSink(ServiceNameFilteringSink.Builder) - Constructor for class com.arpnetworking.tsdcore.sinks.ServiceNameFilteringSink
Protected constructor.
ServiceNameFilteringSink.Builder - Class in com.arpnetworking.tsdcore.sinks
setAcceptedStatusCodes(ImmutableSet<Integer>) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Sets the http status codes accepted as success.
setActorSystem(ActorSystem) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Sets the actor system to create the sink actor in.
setActorSystem(ActorSystem) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Sets the actor system to create the sink actor in.
setActorSystem(ActorSystem) - Method in class com.arpnetworking.tsdcore.sinks.TcpSink.Builder
The actor system to run the actors in.
setAggregationHost(String) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The aggregation server host address to bind to.
setAggregationMessages(ImmutableList<AggregationMessage>) - Method in class com.arpnetworking.tsdcore.model.AggregationRequest.Builder
Set the aggregation messages.
setAggregationMode(AggregationMode) - Method in class com.arpnetworking.tsdcore.model.AggregationRequest.Builder
Set the aggregation mode.
setAggregationPort(Integer) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The http port to listen on.
setApiKey(String) - Method in class com.arpnetworking.tsdcore.sinks.DataDogSink.Builder
The API key.
setApiToken(String) - Method in class com.arpnetworking.tsdcore.sinks.SignalFxSink.Builder
The API token.
setAppName(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient.Builder
Sets the application name.
setAppName(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Sets the app name in Circonus.
setAuthToken(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient.Builder
Sets the authentication token.
setAuthToken(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Sets the auth token.
setBaseBackoff(Duration) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Sets the base backoff period.
setBroker(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Sets the broker name to push metrics to.
setBrokerDetails(List<BrokerListResponse.BrokerDetails>) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker.Builder
Sets the broker details.
setBrokers(List<String>) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Sets the List of brokers.
setCalculateClusterAggregations(Boolean) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
Whether or not to perform cluster-level aggregations.
setCid(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker.Builder
Sets the cid.
setCid(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Sets the CID.
setCluster(String) - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData.Builder
Set the name of the cluster.
setCluster(String) - Method in class com.arpnetworking.tsdcore.model.FQDSN.Builder
The cluster.
setCluster(String) - Method in class com.arpnetworking.tsdcore.model.FQSN.Builder
The cluster.
setClusterHostSuffix(String) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The suffix to append to the cluster host when reporting metrics.
setClusterKey(String) - Method in class com.arpnetworking.remet.gui.ReMetGuiDynamicConfigurationFactory.Builder
Set the cluster parameter key.
setClusterPipelineConfiguration(File) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The cluster pipeline configuration file.
setClusterState(ClusterStatusCache.StatusResponse) - Method in class com.arpnetworking.clusteraggregator.models.StatusResponse.Builder
Sets the cluster state.
setClusterStatusInterval(Duration) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
Interval for polling cluster status.
setConditions(ImmutableList<Condition>) - Method in class com.arpnetworking.tsdcore.model.PeriodicData.Builder
Set the conditions.
setConfig(Map<String, String>) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Sets the config block.
setCount(Integer) - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
setCount(Integer) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
setCreatedAt(Timestamp) - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
setCreatedAt(Timestamp) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
setCreatedAt(Timestamp) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
setCurrentShards(Set<String>) - Method in class com.arpnetworking.clusteraggregator.models.ShardAllocation.Builder
The shards currently on the node.
setData(ImmutableList<AggregatedData>) - Method in class com.arpnetworking.tsdcore.model.PeriodicData.Builder
Set the data.
setData(T) - Method in class com.arpnetworking.tsdcore.model.CalculatedValue.Builder
Set the data.
setDatabaseConfigurations(Map<String, DatabaseConfiguration>) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
Configuration for the databases.
setDataKeys(List<String>) - Method in class com.arpnetworking.configuration.jackson.JsonNodePaginatedUriSource.Builder
Set the keys to the data.
setDefaultDimensionsValues(ImmutableMap<String, String>) - Method in class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink.Builder
Supply default dimension values by original dimension key.
setDimensions(ImmutableMap<String, String>) - Method in class com.arpnetworking.tsdcore.model.PeriodicData.Builder
Set the dimensions.
setDimensions(ImmutableMap<String, String>) - Method in class com.arpnetworking.tsdcore.sinks.DimensionInjectingSink.Builder
Sets the dimensions to inject.
setDimensions(ImmutableSet<String>) - Method in class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink.Builder
Dimension names to partition the periodic statistics on.
setDirectories(List<File>) - Method in class com.arpnetworking.configuration.jackson.DirectoryDynamicConfigurationFactory.Builder
Set the directories.
setDirectory(File) - Method in class com.arpnetworking.configuration.jackson.JsonNodeDirectorySource.Builder
Set the directory.
setDirectory(File) - Method in class com.arpnetworking.configuration.triggers.DirectoryTrigger.Builder
Set the directory.
setDisplayName(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Sets the display name.
setDriverName(String) - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Data driver name.
setEnableHistograms(Boolean) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Controls publication of histograms.
setEnterTime(Instant) - Method in class com.arpnetworking.tsdcore.model.RequestEntry.Builder
Set the time when the request enter the pending request queue.
setEntries(List<PartitionEntry>) - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
setExclude(Set<Duration>) - Method in class com.arpnetworking.tsdcore.sinks.PeriodFilteringSink.Builder
Sets excluded periods.
setExcludedServices(Set<String>) - Method in class com.arpnetworking.tsdcore.sinks.TimeThresholdSink.Builder
Sets excluded services.
setExcludeFilters(List<String>) - Method in class com.arpnetworking.tsdcore.sinks.MetricNameFilteringSink.Builder
Sets exclude filters.
setExcludeFilters(List<String>) - Method in class com.arpnetworking.tsdcore.sinks.ServiceNameFilteringSink.Builder
Sets exclude filters.
setExcludeGreaterThan(Duration) - Method in class com.arpnetworking.tsdcore.sinks.PeriodFilteringSink.Builder
Sets excluded periods greater than this period.
setExcludeLessThan(Duration) - Method in class com.arpnetworking.tsdcore.sinks.PeriodFilteringSink.Builder
Sets excluded periods less than this period.
setExcludeWithDimensions(ImmutableSet<String>) - Method in class com.arpnetworking.tsdcore.sinks.DimensionFilteringSink.Builder
Sets exclude with dimensions.
setExcludeWithoutDimensions(ImmutableSet<String>) - Method in class com.arpnetworking.tsdcore.sinks.DimensionFilteringSink.Builder
Sets exclude without dimensions.
setExecutionContext(ExecutionContext) - Method in class com.arpnetworking.pekko.UniformRandomTimeScheduler.Builder
The execution context to run the send on.
setExtensions(ImmutableMap<String, Object>) - Method in class com.arpnetworking.tsdcore.model.Condition.Builder
Set supporting data.
setFactories(List<DynamicConfigurationFactory>) - Method in class com.arpnetworking.configuration.jackson.MergingDynamicConfigurationFactory.Builder
Set the factories.
setFile(File) - Method in class com.arpnetworking.configuration.jackson.HoconFileSource.Builder
Set the source File.
setFile(File) - Method in class com.arpnetworking.configuration.jackson.JsonNodeFileSource.Builder
Set the source File.
setFile(File) - Method in class com.arpnetworking.configuration.triggers.FileTrigger.Builder
Set the File to monitor.
setFileNamePatterns(Collection<Pattern>) - Method in class com.arpnetworking.configuration.jackson.JsonNodeDirectorySource.Builder
Set the Collection of file name patterns.
setFileNamePatterns(Collection<Pattern>) - Method in class com.arpnetworking.configuration.triggers.DirectoryTrigger.Builder
Set the Collection of file name patterns.
setFileNames(Collection<String>) - Method in class com.arpnetworking.configuration.jackson.JsonNodeDirectorySource.Builder
Set the Collection of file names.
setFileNames(Collection<String>) - Method in class com.arpnetworking.configuration.triggers.DirectoryTrigger.Builder
Set the Collection of file names.
setFQDSN(FQDSN) - Method in class com.arpnetworking.tsdcore.model.AggregatedData.Builder
The fully qualified data space name (FQDSN).
setFQDSN(FQDSN) - Method in class com.arpnetworking.tsdcore.model.Condition.Builder
Set the fully qualified data space name (FQDSN).
setFull(Boolean) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
setFutures(List<Future<?>>) - Method in class com.arpnetworking.utility.CollectFutureBuilder
Sets the list of Futures to wait on.
setHeaders(List<Header>) - Method in class com.arpnetworking.configuration.jackson.JsonNodeUriSource.Builder
Overrides the existing headers with a List of Header.
setHeaders(List<Header>) - Method in class com.arpnetworking.configuration.triggers.UriTrigger.Builder
Overrides the existing headers with a List of Header.
setHistogramSnapshot(HistogramStatistic.HistogramSnapshot) - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSupportingData.Builder
Sets the histogram.
setHistogramTtl(Duration) - Method in class com.arpnetworking.tsdcore.sinks.KairosDbSink.Builder
Sets the TTL of histograms.
setHost(String) - Method in class com.arpnetworking.clusteraggregator.models.ShardAllocation.Builder
The name of the host.
setHost(String) - Method in class com.arpnetworking.tsdcore.model.AggregatedData.Builder
The host.
setHostPipelineConfiguration(File) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The host pipeline configuration file.
setHttpHealthCheckPath(String) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The http health check path.
setHttpHost(String) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The http host address to bind to.
setHttpPort(Integer) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The http port to listen on.
setHttpStatusPath(String) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The http status path.
setHttpVersionPath(String) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The http version path.
setId(Long) - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
setId(Long) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
setId(Long) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
setIdleTimeout(Integer) - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Idle timeout in milliseconds.
setInclude(Set<Duration>) - Method in class com.arpnetworking.tsdcore.sinks.PeriodFilteringSink.Builder
Sets included periods.
setIncludeFilters(List<String>) - Method in class com.arpnetworking.tsdcore.sinks.MetricNameFilteringSink.Builder
Sets include filters.
setIncludeFilters(List<String>) - Method in class com.arpnetworking.tsdcore.sinks.ServiceNameFilteringSink.Builder
Sets include filters.
setIncomingShards(Set<String>) - Method in class com.arpnetworking.clusteraggregator.models.ShardAllocation.Builder
The shards in the process of being rebalanced to this node.
setIntervalInMilliseconds(Long) - Method in class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink.Builder
The interval in milliseconds between statistic flushes.
setIpAddress(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails.Builder
Sets the IP address.
setIsSpecified(Boolean) - Method in class com.arpnetworking.tsdcore.model.AggregatedData.Builder
The aggregated data was specified.
setJdbcUrl(String) - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Database JDBC url.
setJvmMetricsCollectionInterval(Duration) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
Period for collecting JVM metrics.
setKey(String) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
setLinesPerRequest(Long) - Method in class com.arpnetworking.tsdcore.sinks.InfluxDbSink.Builder
Sets maximum lines per request.
setListeners(List<Listener>) - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration.Builder
Set the List of Listener instances.
setLocalAddress(Address) - Method in class com.arpnetworking.clusteraggregator.models.StatusResponse.Builder
Sets the local address of this cluster node.
setLocalMetrics(Map<Duration, PeriodMetrics>) - Method in class com.arpnetworking.clusteraggregator.models.StatusResponse.Builder
Sets the local metrics for this cluster node.
setLogDirectory(File) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The log directory.
setLogOnly(Boolean) - Method in class com.arpnetworking.tsdcore.sinks.TimeThresholdSink.Builder
Flag to only log violations instead of dropping data.
setMap(Map<Unit, Unit>) - Method in class com.arpnetworking.tsdcore.sinks.UnitMappingSink.Builder
The map of unit to unit.
setMappedDimensions(ImmutableMap<String, String>) - Method in class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink.Builder
Incoming dimension names to partition the periodic statistics on mapped to an outbound dimension name.
setMaterializer(Materializer) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient.Builder
Sets the materializer for callbacks.
setMaxConnectionTimeout(Duration) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The maximum connection cycling time for a client.
setMaximumAttempts(Integer) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Sets the maximum number of attempts of the http requests.
setMaximumConcurrency(Integer) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Sets the maximum concurrency of the http requests.
setMaximumConcurrency(Integer) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Sets the maximum concurrency of the http requests.
setMaximumDelay(Duration) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Sets the maximum delay for retries.
setMaximumPoolSize(Integer) - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Maximum pool size.
setMaximumQueueSize(Integer) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Sets the maximum pending queue size.
setMaximumQueueSize(Integer) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Sets the maximum pending queue size.
setMaximumTime(FiniteDuration) - Method in class com.arpnetworking.pekko.UniformRandomTimeScheduler.Builder
The maximum time.
setMaxMetricDimensions(Integer) - Method in class com.arpnetworking.tsdcore.sinks.SignalFxSink.Builder
Sets the maximum metric-dimensions per request.
setMaxParallel(Integer) - Method in class com.arpnetworking.clusteraggregator.configuration.RebalanceConfiguration.Builder
Maximum parallel shards to rebalance.
setMaxQueueSize(Integer) - Method in class com.arpnetworking.tsdcore.sinks.TcpSink.Builder
The maximum queue size.
setMaxRequestSize(Integer) - Method in class com.arpnetworking.tsdcore.sinks.KairosDbSink.Builder
Sets the maximum size of the request to publish.
setMessage(Object) - Method in class com.arpnetworking.pekko.UniformRandomTimeScheduler.Builder
The message to send.
setMetric(String) - Method in class com.arpnetworking.tsdcore.model.FQDSN.Builder
The metric.
setMetric(String) - Method in class com.arpnetworking.tsdcore.model.FQSN.Builder
The metric.
setMetricLimit(Integer) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Sets the metric limit.
setMetricName(String) - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData.Builder
Set the name of the metric.
setMetrics(List<Map<String, String>>) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Sets the metrics block.
setMetricsFactory(MetricsFactory) - Method in class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink.Builder
Instance of MetricsFactory.
setMigrationLocations(List<String>) - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Migration location(s).
setMigrationSchemas(List<String>) - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Migration schema(s).
setMinConnectionTimeout(Duration) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The minimum connection cycling time for a client.
setMinimumIdle(Integer) - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Minimum idle connections.
setMinimumTime(FiniteDuration) - Method in class com.arpnetworking.pekko.UniformRandomTimeScheduler.Builder
The minimum time.
setMinRequestTime(ZonedDateTime) - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData.Builder
Set the minimum request time.
setMinRequestTime(ZonedDateTime) - Method in class com.arpnetworking.tsdcore.model.PeriodicData.Builder
Set the minimum request time.
setModelPackages(List<String>) - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Model package(s).
setModules(List<String>) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails.Builder
Sets the modules.
setMonitoringCluster(String) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The monitoring cluster.
setMonitoringHost(String) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
setMonitoringPort(Integer) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
setMonitoringService(String) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The monitoring service.
setMonitoringSinks(ImmutableList<JsonNode>) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The monitoring sinks.
setName(String) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
setName(String) - Method in class com.arpnetworking.tsdcore.model.Condition.Builder
Set the name.
setName(String) - Method in class com.arpnetworking.tsdcore.sinks.BaseSink.Builder
Sets name.
setName(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker.Builder
Sets the name.
setNextPageKeys(List<String>) - Method in class com.arpnetworking.configuration.jackson.JsonNodePaginatedUriSource.Builder
Set the keys to the next page uri.
setObjectMapper(ObjectMapper) - Method in class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration.Builder
Set the ObjectMapper instance.
setObjectMapper(ObjectMapper) - Method in class com.arpnetworking.configuration.jackson.BaseJsonNodeSource.Builder
Set the ObjectMapper instance.
setOrganizationId(String) - Method in class com.arpnetworking.tsdcore.sinks.SignalFxSink.Builder
The organization identifier.
setOther(Map<String, Object>) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Setter for other properties that get serialized to/from json.
setOutgoingShards(Set<String>) - Method in class com.arpnetworking.clusteraggregator.models.ShardAllocation.Builder
The shards in the process of being rebalanced away from this node.
setPartition(Partition) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
setPartitionNumber(Integer) - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
setPartitionSet(PartitionSet) - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
setPartitionSet(PartitionSet) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Sets the partition set to partition check bundles.
setPassPercent(Integer) - Method in class com.arpnetworking.tsdcore.sinks.RandomMetricNameFilterSink.Builder
The percentage of data to pass to the wrapped sink.
setPassword(String) - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Database password.
setPath(String) - Method in class com.arpnetworking.tsdcore.sinks.RrdSink.Builder
The path to the RRD root.
setPekkoConfiguration(Map<String, ?>) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
Pekko configuration.
setPeriod(Integer) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Sets the period.
setPeriod(Duration) - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData.Builder
Set the period.
setPeriod(Duration) - Method in class com.arpnetworking.tsdcore.model.AggregatedData.Builder
The period.
setPeriod(Duration) - Method in class com.arpnetworking.tsdcore.model.FQSN.Builder
The period.
setPeriod(Duration) - Method in class com.arpnetworking.tsdcore.model.PeriodicData.Builder
Set the period.
setPeriodDimensionName(String) - Method in class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink.Builder
The name of the outbound dimension for the periodicity of the data.
setPeriodicMetrics(PeriodicMetrics) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Instance of PeriodicMetrics.
setPeriodStart(ZonedDateTime) - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData.Builder
Set the start of the period.
setPoolSize(Integer) - Method in class com.arpnetworking.clusteraggregator.configuration.EmitterConfiguration.Builder
The number of emitters to create in a pool.
setPopulationSize(Long) - Method in class com.arpnetworking.tsdcore.model.AggregatedData.Builder
The population size.
setPopulationSize(Optional<Long>) - Method in class com.arpnetworking.tsdcore.model.RequestEntry.Builder
Set the population size of the request.
setPublishHistograms(Boolean) - Method in class com.arpnetworking.tsdcore.sinks.KairosDbSink.Builder
Sets whether or not to publish full histograms.
setPublishStandardMetrics(Boolean) - Method in class com.arpnetworking.tsdcore.sinks.KairosDbSink.Builder
Sets whether or not to publish non-histogram metrics.
setReaggregationDimensions(ImmutableSet<String>) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The reaggregation dimensions.
setReaggregationInjectClusterAsHost(Boolean) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
Whether to inject a host dimension with a value based on the cluster dimension.
setReaggregationTimeout(Duration) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
The time from period start to wait for all data to arrive.
setRebalanceConfiguration(RebalanceConfiguration) - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration.Builder
Configuration for the shard rebalance settings.
setRequest(Request) - Method in class com.arpnetworking.tsdcore.model.RequestEntry.Builder
Set the request.
setRetryableStatusCodes(ImmutableSet<Integer>) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Sets the http status codes that can be retried.
setRrdTool(String) - Method in class com.arpnetworking.tsdcore.sinks.RrdSink.Builder
The RRD tool to use.
setSafeHttps(Boolean) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient.Builder
Sets the safety of HTTPS.
setSafeHttps(Boolean) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Sets the safety of HTTPS.
setSamples(Collection<Quantity>) - Method in class com.arpnetworking.tsdcore.model.AggregatedData.Builder
The samples.
setScheduler(Scheduler) - Method in class com.arpnetworking.pekko.UniformRandomTimeScheduler.Builder
The scheduler to schedule with.
setSender(ActorRef) - Method in class com.arpnetworking.pekko.UniformRandomTimeScheduler.Builder
The actor the message will be from.
setServerAddress(String) - Method in class com.arpnetworking.tsdcore.sinks.TcpSink.Builder
The server host name.
setServerPort(Integer) - Method in class com.arpnetworking.tsdcore.sinks.TcpSink.Builder
The server port.
setService(String) - Method in class com.arpnetworking.clusteraggregator.models.CombinedMetricData.Builder
Set the name of the service.
setService(String) - Method in class com.arpnetworking.tsdcore.model.FQDSN.Builder
The service.
setService(String) - Method in class com.arpnetworking.tsdcore.model.FQSN.Builder
The service.
setServiceKey(String) - Method in class com.arpnetworking.remet.gui.ReMetGuiDynamicConfigurationFactory.Builder
Set the service parameter key.
setSeverityToStatus(Map<String, Integer>) - Method in class com.arpnetworking.tsdcore.sinks.KMonDSink.Builder
Set severity to status map.
setSeverityToStatus(Map<String, Integer>) - Method in class com.arpnetworking.tsdcore.sinks.MonitordSink.Builder
Set severity to status map.
setShardRegion(ActorRef) - Method in class com.arpnetworking.clusteraggregator.models.ShardAllocation.Builder
The shard region owning the shards.
setSink(Sink) - Method in class com.arpnetworking.tsdcore.sinks.DimensionFilteringSink.Builder
The sink to wrap.
setSink(Sink) - Method in class com.arpnetworking.tsdcore.sinks.DimensionInjectingSink.Builder
The sink to wrap.
setSink(Sink) - Method in class com.arpnetworking.tsdcore.sinks.DomainInjectingSink.Builder
The sink to wrap.
setSink(Sink) - Method in class com.arpnetworking.tsdcore.sinks.MetricNameFilteringSink.Builder
The aggregated data sink to filter.
setSink(Sink) - Method in class com.arpnetworking.tsdcore.sinks.PeriodFilteringSink.Builder
The aggregated data sink to filter.
setSink(Sink) - Method in class com.arpnetworking.tsdcore.sinks.RandomMetricNameFilterSink.Builder
The aggregated data sink to limit.
setSink(Sink) - Method in class com.arpnetworking.tsdcore.sinks.ServiceNameFilteringSink.Builder
The sink to wrap.
setSink(Sink) - Method in class com.arpnetworking.tsdcore.sinks.TimeThresholdSink.Builder
The aggregated data sink to filter.
setSink(Sink) - Method in class com.arpnetworking.tsdcore.sinks.UnitMappingSink.Builder
The sink to wrap.
setSinks(Collection<Sink>) - Method in class com.arpnetworking.tsdcore.sinks.MultiSink.Builder
The aggregated data sinks to wrap.
setSinks(List<Sink>) - Method in class com.arpnetworking.clusteraggregator.configuration.EmitterConfiguration.Builder
The sinks.
setSkew(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails.Builder
Sets the skew.
setSource(String) - Method in class com.arpnetworking.configuration.jackson.JsonNodeLiteralSource.Builder
Set the source.
setSource(String) - Method in class com.arpnetworking.tsdcore.sinks.SignalFxSink.Builder
The source name.
setSourceBuilders(List<Builder<? extends JsonNodeSource>>) - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration.Builder
Set the List of JsonNodeSource instance DynamicConfiguration.Builder instances.
setSources(List<JsonNodeSource>) - Method in class com.arpnetworking.configuration.jackson.JsonNodeMergingSource.Builder
Set the List of JsonNodeSource instances in order of importance (least significant first).
setSources(List<JsonNodeSource>) - Method in class com.arpnetworking.configuration.jackson.StaticConfiguration.Builder
Set the List of JsonNodeSource instances.
setSpreadPeriod(Duration) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Sets the maximum delay before starting to send data to the server.
setSpreadPeriod(Duration) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
Sets the maximum delay before starting to send data to the server.
setStart(ZonedDateTime) - Method in class com.arpnetworking.tsdcore.model.AggregatedData.Builder
The period start.
setStart(ZonedDateTime) - Method in class com.arpnetworking.tsdcore.model.FQSN.Builder
The period start.
setStart(ZonedDateTime) - Method in class com.arpnetworking.tsdcore.model.PeriodicData.Builder
Set the start.
setStatistic(Statistic) - Method in class com.arpnetworking.tsdcore.model.FQDSN.Builder
The statistic.
setStatistic(Statistic) - Method in class com.arpnetworking.tsdcore.model.FQSN.Builder
The Statistic instance.
setStatus(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails.Builder
Sets the status.
setStatus(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Sets the status.
setSuffixes(ImmutableSet<String>) - Method in class com.arpnetworking.tsdcore.sinks.DomainInjectingSink.Builder
Sets recognized domain suffixes.
setSupportingData(Object) - Method in class com.arpnetworking.tsdcore.model.AggregatedData.Builder
The supporting data.
setTags(List<String>) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker.Builder
Sets the tags.
setTags(List<String>) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Sets the List of tags.
setTarget(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.CheckBundle.Builder
Sets the name of the target.
setTarget(ActorRef) - Method in class com.arpnetworking.pekko.UniformRandomTimeScheduler.Builder
The target actor.
setThreshold(Quantity) - Method in class com.arpnetworking.tsdcore.model.Condition.Builder
Set the threshold.
setThreshold(Integer) - Method in class com.arpnetworking.clusteraggregator.configuration.RebalanceConfiguration.Builder
Minimum difference in shards between hosts to trigger a rebalance.
setThreshold(Duration) - Method in class com.arpnetworking.tsdcore.sinks.TimeThresholdSink.Builder
The freshness threshold to log or drop data.
setTriggered(Boolean) - Method in class com.arpnetworking.tsdcore.model.Condition.Builder
Set the whether it was triggered.
setTriggers(List<Trigger>) - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration.Builder
Set the List of Trigger instances.
setTtl(Duration) - Method in class com.arpnetworking.tsdcore.sinks.KairosDbSink.Builder
Sets the TTL of non-histogram metrics.
setType(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.Broker.Builder
Sets the type.
setUnit(Unit) - Method in class com.arpnetworking.tsdcore.model.Quantity.Builder
Set the unit.
setUnit(Optional<Unit>) - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSupportingData.Builder
Sets the unit.
setUnknownSeverityStatus(Integer) - Method in class com.arpnetworking.tsdcore.sinks.KMonDSink.Builder
The status for unknown Condition severities; e.g.
setUnknownSeverityStatus(Integer) - Method in class com.arpnetworking.tsdcore.sinks.MonitordSink.Builder
The status for unknown Condition severities; e.g.
setUpdatedAt(Timestamp) - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
setUpdatedAt(Timestamp) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
setUpdatedAt(Timestamp) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
setupModule(Module.SetupContext) - Method in class com.arpnetworking.configuration.jackson.pekko.PekkoLoggingModule
 
setupModule(Module.SetupContext) - Method in class com.arpnetworking.configuration.jackson.pekko.PekkoModule
 
setUri(URI) - Method in class com.arpnetworking.configuration.jackson.JsonNodePaginatedUriSource.Builder
Set the source URI.
setUri(URI) - Method in class com.arpnetworking.configuration.jackson.JsonNodeUriSource.Builder
Set the source URI.
setUri(URI) - Method in class com.arpnetworking.configuration.triggers.UriTrigger.Builder
Set the source URI.
setUri(URI) - Method in class com.arpnetworking.remet.gui.ReMetGuiDynamicConfigurationFactory.Builder
Set the URI.
setUri(URI) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient.Builder
Sets the base URI.
setUri(URI) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink.Builder
Sets the base url for the Circonus API.
setUri(URI) - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink.Builder
The URI to post the aggregated data to.
setUsername(String) - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration.Builder
Database username.
setValue(Quantity) - Method in class com.arpnetworking.tsdcore.model.AggregatedData.Builder
The value.
setValue(Quantity) - Method in class com.arpnetworking.tsdcore.model.CalculatedValue.Builder
Set the value.
setValue(Double) - Method in class com.arpnetworking.tsdcore.model.Quantity.Builder
Set the value.
setVersion(Long) - Method in class com.arpnetworking.clusteraggregator.models.ebean.Partition
 
setVersion(Long) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionEntry
 
setVersion(Long) - Method in class com.arpnetworking.clusteraggregator.models.ebean.PartitionSet
 
setVersion(String) - Method in class com.arpnetworking.tsdcore.sinks.circonus.api.BrokerListResponse.BrokerDetails.Builder
Sets the version.
ShardAllocation - Class in com.arpnetworking.clusteraggregator.models
Represents a shard allocation.
ShardAllocation.Builder - Class in com.arpnetworking.clusteraggregator.models
Builder implementation for ShardAllocation.
shardId(Object) - Method in class com.arpnetworking.clusteraggregator.aggregation.AggMessageExtractor
shouldPersist() - Method in enum class com.arpnetworking.clusteraggregator.models.AggregationMode
Whether this AggregationMode should persist client statistics.
shouldReaggregate() - Method in enum class com.arpnetworking.clusteraggregator.models.AggregationMode
Whether this AggregationMode should reaggregate client statistics.
shutdown() - Method in class com.arpnetworking.clusteraggregator.AppShutdown
Executes all of the registered shutdown hooks and waits for them to complete.
shutdown() - Method in class com.arpnetworking.clusteraggregator.Main
Shutdown the component.
shutdown() - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration
 
shutdown() - Method in class com.arpnetworking.utility.Configurator
 
shutdown() - Method in class com.arpnetworking.utility.Database
 
shutdown() - Method in interface com.arpnetworking.utility.Launchable
Shutdown the component.
ShutdownAggregator() - Constructor for class com.arpnetworking.clusteraggregator.aggregation.AggregationRouter.ShutdownAggregator
 
SignalFxSink - Class in com.arpnetworking.tsdcore.sinks
Publishes aggregations to Signal FX.
SignalFxSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for SignalFxSink.
Sink - Interface in com.arpnetworking.tsdcore.sinks
Interface to describe a class that publishes PeriodicData.
StaticConfiguration - Class in com.arpnetworking.configuration.jackson
Static configuration implementation of Configuration.
StaticConfiguration.Builder - Class in com.arpnetworking.configuration.jackson
Builder for StaticConfiguration.
Statistic - Interface in com.arpnetworking.tsdcore.statistics
Interface for a statistic calculator.
StatisticDeserializer - Class in com.arpnetworking.tsdcore.statistics
Jackson JsonDeserializer implementation for Statistic using StatisticFactory.
StatisticDeserializer() - Constructor for class com.arpnetworking.tsdcore.statistics.StatisticDeserializer
 
StatisticFactory - Class in com.arpnetworking.tsdcore.statistics
Creates statistics.
StatisticFactory() - Constructor for class com.arpnetworking.tsdcore.statistics.StatisticFactory
 
StatisticValue(CalculatedValue<?>, boolean) - Constructor for class com.arpnetworking.clusteraggregator.models.CombinedMetricData.StatisticValue
Public constructor.
Status - Class in com.arpnetworking.clusteraggregator
Periodically polls the cluster status and caches the result.
Status(Cluster, ActorRef, ActorRef) - Constructor for class com.arpnetworking.clusteraggregator.Status
Public constructor.
Status.HealthRequest - Class in com.arpnetworking.clusteraggregator
Represents a health check request.
Status.StatusRequest - Class in com.arpnetworking.clusteraggregator
Represents a status request.
StatusRequest() - Constructor for class com.arpnetworking.clusteraggregator.Status.StatusRequest
 
StatusResponse - Class in com.arpnetworking.clusteraggregator.models
Response model for the status http endpoint.
StatusResponse(ClusterEvent.CurrentClusterState, Optional<ParallelLeastShardAllocationStrategy.RebalanceNotification>) - Constructor for class com.arpnetworking.clusteraggregator.ClusterStatusCache.StatusResponse
Public constructor.
StatusResponse.Builder - Class in com.arpnetworking.clusteraggregator.models
Builder implementation for StatusResponse.
stop() - Method in class com.arpnetworking.pekko.UniformRandomTimeScheduler
Stops the scheduling.
StreamingAggregationBucket - Class in com.arpnetworking.clusteraggregator.aggregation
Container class that holds aggregation pending records.
StreamingAggregationBucket(ZonedDateTime) - Constructor for class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregationBucket
Public constructor.
StreamingAggregator - Class in com.arpnetworking.clusteraggregator.aggregation
Actual actor responsible for aggregating.
StreamingAggregator(ActorRef, ActorRef, String, ImmutableSet<String>, boolean, Duration, PeriodicMetrics) - Constructor for class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregator
Public constructor.
SubscribeToNotifications() - Constructor for class com.arpnetworking.clusteraggregator.configuration.ConfigurableActorProxy.SubscribeToNotifications
 
subtract(Quantity) - Method in class com.arpnetworking.tsdcore.model.Quantity
Subtract the specified Quantity from this one returning the result.
SumAccumulator(Statistic) - Constructor for class com.arpnetworking.tsdcore.statistics.SumStatistic.SumAccumulator
Public constructor.
SumStatistic - Class in com.arpnetworking.tsdcore.statistics
Takes the sum of the entries.
SumStatistic.SumAccumulator - Class in com.arpnetworking.tsdcore.statistics
Accumulator computing the sum of values.
supervisorStrategy() - Method in class com.arpnetworking.clusteraggregator.client.AggClientSupervisor
 

T

TcpSink - Class in com.arpnetworking.tsdcore.sinks
Abstract publisher to send data to a server via Pekko TCP channel.
TcpSink(TcpSink.Builder<?, ?>) - Constructor for class com.arpnetworking.tsdcore.sinks.TcpSink
Protected constructor.
TcpSink.Builder<B extends BaseSink.Builder<B,S>,S extends Sink> - Class in com.arpnetworking.tsdcore.sinks
Implementation of base builder pattern for TcpSink.
TcpSinkActor - Class in com.arpnetworking.tsdcore.sinks
Actor that sends TCP data with Pekko.
TcpSinkActor(TcpSink, String, int, int, Duration) - Constructor for class com.arpnetworking.tsdcore.sinks.TcpSinkActor
Public constructor.
TcpSinkActor.EmitAggregation - Class in com.arpnetworking.tsdcore.sinks
Message class to wrap a list of AggregatedData.
TERABIT - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Terabits.
TERABYTE - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Terabytes.
TIMER - Enum constant in enum class com.arpnetworking.tsdcore.model.MetricType
Timer.
TimeThresholdSink - Class in com.arpnetworking.tsdcore.sinks
A sink to filter old data.
TimeThresholdSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Base TimeThresholdSink.Builder implementation.
toFQDSN() - Method in class com.arpnetworking.tsdcore.model.FQSN
Return the fully qualified data space name portion of the fully qualified statistic name.
toLogValue() - Method in class com.arpnetworking.configuration.BaseConfiguration
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration
 
toLogValue() - Method in class com.arpnetworking.configuration.jackson.BaseJsonNodeSource
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.jackson.DirectoryDynamicConfigurationFactory
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.jackson.DynamicConfiguration
 
toLogValue() - Method in class com.arpnetworking.configuration.jackson.HoconFileSource
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.jackson.JsonNodeDirectorySource
 
toLogValue() - Method in class com.arpnetworking.configuration.jackson.JsonNodeFileSource
 
toLogValue() - Method in class com.arpnetworking.configuration.jackson.JsonNodeLiteralSource
 
toLogValue() - Method in class com.arpnetworking.configuration.jackson.JsonNodeMergingSource
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.jackson.JsonNodePaginatedUriSource
 
toLogValue() - Method in class com.arpnetworking.configuration.jackson.JsonNodeUriSource
 
toLogValue() - Method in class com.arpnetworking.configuration.jackson.MergingDynamicConfigurationFactory
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.jackson.pekko.ActorRefDeserializer
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.jackson.pekko.ActorRefSerializer
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.jackson.pekko.PekkoModule
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.jackson.StaticConfiguration
 
toLogValue() - Method in class com.arpnetworking.configuration.triggers.DirectoryTrigger
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.triggers.FileTrigger
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.configuration.triggers.UriTrigger
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.guice.pekko.GuiceActorCreator
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.remet.gui.ReMetGuiDynamicConfigurationFactory
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.BaseSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSinkActor
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.DataDogSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.HttpPostSink
 
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.HttpSinkActor
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.KairosDbSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.KMonDSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.MetricNameFilteringSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.MonitordSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.MultiSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.PeriodFilteringSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.PeriodicStatisticsSink
 
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.RandomMetricNameFilterSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.RrdSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.ServiceNameFilteringSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.SignalFxSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.TcpSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.TcpSinkActor
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.TimeThresholdSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.tsdcore.sinks.UnitMappingSink
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.utility.Configurator
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.utility.Reconfigurator
Generate a Steno log compatible representation.
toLogValue() - Method in class com.arpnetworking.utility.ReflectionsDatabase
Generate a Steno log compatible representation.
toString() - Method in class com.arpnetworking.clusteraggregator.configuration.ClusterAggregatorConfiguration
 
toString() - Method in class com.arpnetworking.clusteraggregator.configuration.DatabaseConfiguration
 
toString() - Method in class com.arpnetworking.configuration.BaseConfiguration
 
toString() - Method in class com.arpnetworking.configuration.jackson.BaseJsonNodeSource
 
toString() - Method in class com.arpnetworking.configuration.jackson.DirectoryDynamicConfigurationFactory
 
toString() - Method in class com.arpnetworking.configuration.jackson.DynamicConfigurationFactory.Key
 
toString() - Method in class com.arpnetworking.configuration.jackson.JsonNodeMergingSource
 
toString() - Method in class com.arpnetworking.configuration.jackson.JsonNodeUriSource
 
toString() - Method in class com.arpnetworking.configuration.jackson.MergingDynamicConfigurationFactory
 
toString() - Method in class com.arpnetworking.configuration.jackson.pekko.ActorRefDeserializer
 
toString() - Method in class com.arpnetworking.configuration.jackson.pekko.ActorRefSerializer
 
toString() - Method in class com.arpnetworking.configuration.jackson.pekko.PekkoModule
 
toString() - Method in class com.arpnetworking.configuration.triggers.DirectoryTrigger
 
toString() - Method in class com.arpnetworking.configuration.triggers.FileTrigger
 
toString() - Method in class com.arpnetworking.configuration.triggers.UriTrigger
 
toString() - Method in class com.arpnetworking.guice.pekko.GuiceActorCreator
 
toString() - Method in class com.arpnetworking.remet.gui.ReMetGuiDynamicConfigurationFactory
 
toString() - Method in class com.arpnetworking.tsdcore.model.AggregatedData
 
toString() - Method in class com.arpnetworking.tsdcore.model.Condition
 
toString() - Method in class com.arpnetworking.tsdcore.model.FQDSN
 
toString() - Method in class com.arpnetworking.tsdcore.model.FQSN
 
toString() - Method in class com.arpnetworking.tsdcore.model.PeriodicData
 
toString() - Method in class com.arpnetworking.tsdcore.model.Quantity
 
toString() - Method in class com.arpnetworking.tsdcore.sinks.BaseSink
 
toString() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient
 
toString() - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusSinkActor
 
toString() - Method in class com.arpnetworking.tsdcore.sinks.HttpSinkActor
 
toString() - Method in class com.arpnetworking.tsdcore.sinks.TcpSinkActor
toString() - Method in class com.arpnetworking.tsdcore.statistics.BaseStatistic
 
toString() - Method in class com.arpnetworking.utility.Configurator
 
toString() - Method in class com.arpnetworking.utility.Database
 
toString() - Method in class com.arpnetworking.utility.Reconfigurator
 
toString() - Method in class com.arpnetworking.utility.ReflectionsDatabase
 
toUnit(Unit) - Method in class com.arpnetworking.tsdcore.statistics.HistogramStatistic.HistogramSupportingData
Transforms the histogram to a new unit.
TPStatistic - Class in com.arpnetworking.tsdcore.statistics
Base class for percentile based statistics.
TPStatistic(double) - Constructor for class com.arpnetworking.tsdcore.statistics.TPStatistic
Public constructor.
TPStatistic.PercentileCalculator - Class in com.arpnetworking.tsdcore.statistics
Calculator computing the percentile of values.
Trigger - Interface in com.arpnetworking.configuration
Interface for classes which evaluate when to reload configuration.
Trigger - Interface in com.arpnetworking.utility
A simple interface that blocks the current thread.
tryGetStatistic(String) - Method in class com.arpnetworking.tsdcore.statistics.StatisticFactory
Get a statistic by name.

U

UniformRandomTimeScheduler - Class in com.arpnetworking.pekko
Scheduler that will send a message in a uniform random time interval.
UniformRandomTimeScheduler.Builder - Class in com.arpnetworking.pekko
Builder implementation for UniformRandomTimeScheduler.
unify(Collection<AggregatedData>) - Static method in class com.arpnetworking.clusteraggregator.AggDataUnifier
Unifies AggregatedData units.
unify(Collection<Quantity>) - Static method in class com.arpnetworking.tsdcore.model.Quantity
Ensures all Quantity instances have the same (including no) Unit.
Unit - Enum Class in com.arpnetworking.tsdcore.model
Specifies the unit on a counter variable.
UnitMappingSink - Class in com.arpnetworking.tsdcore.sinks
Implementation of Sink which maps values in one unit to another.
UnitMappingSink.Builder - Class in com.arpnetworking.tsdcore.sinks
Implementation of builder pattern for UnitMappingSink.
update(CombinedMetricData) - Method in class com.arpnetworking.clusteraggregator.aggregation.StreamingAggregationBucket
Add CombinedMetricData instance.
update(DynamicConfiguration.Builder, Collection<DynamicConfigurationFactory.Key>) - Method in class com.arpnetworking.configuration.jackson.DirectoryDynamicConfigurationFactory
 
update(DynamicConfiguration.Builder, Collection<DynamicConfigurationFactory.Key>) - Method in interface com.arpnetworking.configuration.jackson.DynamicConfigurationFactory
Update a DynamicConfiguration.Builder with the specified keys using the strategy defined by the specific implementation.
update(DynamicConfiguration.Builder, Collection<DynamicConfigurationFactory.Key>) - Method in class com.arpnetworking.configuration.jackson.MergingDynamicConfigurationFactory
 
update(DynamicConfiguration.Builder, Collection<DynamicConfigurationFactory.Key>) - Method in class com.arpnetworking.remet.gui.ReMetGuiDynamicConfigurationFactory
 
updateCheckBundle(CheckBundle) - Method in class com.arpnetworking.tsdcore.sinks.circonus.CirconusClient
Updates a check bundle in Circonus.
UriTrigger - Class in com.arpnetworking.configuration.triggers
Trigger implementation based on a uri's last modified date and ETag.
UriTrigger.Builder - Class in com.arpnetworking.configuration.triggers
Builder implementation for UriTrigger.

V

valueOf(String) - Static method in enum class com.arpnetworking.clusteraggregator.models.AggregationMode
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.arpnetworking.tsdcore.model.MetricType
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class com.arpnetworking.tsdcore.model.Unit
Returns the enum constant of this class with the specified name.
values() - Static method in enum class com.arpnetworking.clusteraggregator.models.AggregationMode
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.arpnetworking.tsdcore.model.MetricType
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class com.arpnetworking.tsdcore.model.Unit
Returns an array containing the constants of this enum class, in the order they are declared.
VersionInfo - Class in com.arpnetworking.clusteraggregator.models
Represents the model for the version of the service currently running.

W

waitOnTrigger() - Method in interface com.arpnetworking.utility.Trigger
Blocks the current thread.
WEEK - Enum constant in enum class com.arpnetworking.tsdcore.model.Unit
Weeks.

_

_objectMapper - Variable in class com.arpnetworking.configuration.jackson.BaseJacksonConfiguration
 
_objectMapper - Variable in class com.arpnetworking.configuration.jackson.BaseJsonNodeSource
 
_objectMapper - Variable in class com.arpnetworking.configuration.jackson.BaseJsonNodeSource.Builder
 
A B C D E F G H I J K L M N O P Q R S T U V W _ 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form