Skip navigation links
A B C D E F G H I J K L M O P Q R S T U V W Z 

A

AbstractAgent - Class in com.wavefront.agent
Agent that runs remotely on a server collecting metrics.
AbstractAgent() - Constructor for class com.wavefront.agent.AbstractAgent
 
AbstractAgent(boolean, boolean) - Constructor for class com.wavefront.agent.AbstractAgent
 
AccumulationCache - Class in com.wavefront.agent.histogram.accumulator
Expose a local cache of limited size along with a task to flush that cache to the backing store.
AccumulationCache(ConcurrentMap<Utils.HistogramKey, AgentDigest>, long, Ticker) - Constructor for class com.wavefront.agent.histogram.accumulator.AccumulationCache
Constructs a new AccumulationCache instance around backingStore and builds an in-memory index maintaining dispatch times in milliseconds for all HistogramKeys in backingStore Setting cacheSize to 0 disables in-memory caching so the cache only maintains the dispatch time index.
AccumulationCache(ConcurrentMap<Utils.HistogramKey, AgentDigest>, long, Ticker, Runnable) - Constructor for class com.wavefront.agent.histogram.accumulator.AccumulationCache
Constructs a new AccumulationCache instance around backingStore and builds an in-memory index maintaining dispatch times in milliseconds for all HistogramKeys in backingStore Setting cacheSize to 0 disables in-memory caching so the cache only maintains the dispatch time index.
AccumulationCache.AccumulationCacheMonitor - Class in com.wavefront.agent.histogram.accumulator
 
AccumulationCacheMonitor() - Constructor for class com.wavefront.agent.histogram.accumulator.AccumulationCache.AccumulationCacheMonitor
 
AccumulationTask - Class in com.wavefront.agent.histogram.accumulator
Histogram accumulation task.
AccumulationTask(ObjectQueue<List<String>>, AccumulationCache, Decoder<String>, PointHandler, Validation.Level, long, Utils.Granularity, short) - Constructor for class com.wavefront.agent.histogram.accumulator.AccumulationTask
 
Ack - Class in org.logstash.beats
 
Ack(byte, int) - Constructor for class org.logstash.beats.Ack
 
AckEncoder - Class in org.logstash.beats
This Class is mostly used in the test suite to make the right assertions with the encoded data frame.
AckEncoder() - Constructor for class org.logstash.beats.AckEncoder
 
add(double, int) - Method in class com.tdunning.math.stats.AgentDigest
 
add(double, int, List<Double>) - Method in class com.tdunning.math.stats.AgentDigest
 
add(T) - Method in interface com.wavefront.agent.handlers.SenderTask
Add valid item to the send queue (memory buffers).
add(Iterable<T>) - Method in interface com.wavefront.agent.handlers.SenderTask
Add multiple valid items to the send queue (memory buffers).
add(ResubmissionTask) - Method in class com.wavefront.agent.ResubmissionTaskQueue
 
addBlockedSample(String) - Method in class com.wavefront.agent.PostPushDataTimedTask
 
addFilter(AnnotatedPredicate<T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a filter rule
addFilter(int, AnnotatedPredicate<T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a filter rule and place it at a specific index
addHyphensToUuid(String) - Static method in class com.wavefront.agent.Utils
Requires an input uuid string Encoded as 32 hex characters.
additionalPatterns - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Additional grok patterns to use in pattern matching for the above MetricMatchers.
addMessage(Message) - Method in class org.logstash.beats.Batch
 
addPoint(String) - Method in class com.wavefront.agent.PostPushDataTimedTask
 
addPoints(List<String>) - Method in class com.wavefront.agent.PostPushDataTimedTask
 
addTransformer(Function<T, T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a transformation rule
addTransformer(int, Function<T, T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a transformation rule and place it at a specific index
agentAPI - Variable in class com.wavefront.agent.AbstractAgent
 
agentConfigProcessed(UUID) - Method in class com.wavefront.agent.QueuedAgentService
 
AgentDigest - Class in com.tdunning.math.stats
NOTE: This is a pruned and modified version of MergingDigest.
AgentDigest(short, long) - Constructor for class com.tdunning.math.stats.AgentDigest
 
AgentDigest.AgentDigestMarshaller - Class in com.tdunning.math.stats
Stateless AgentDigest codec for chronicle maps
agentError(UUID, String) - Method in class com.wavefront.agent.QueuedAgentService
 
agentId - Variable in class com.wavefront.agent.AbstractAgent
 
agentMetrics - Variable in class com.wavefront.agent.AbstractAgent
 
agentMetricsCaptureTs - Variable in class com.wavefront.agent.AbstractAgent
 
agentMetricsPointTags - Variable in class com.wavefront.agent.AbstractAgent
 
AgentPreprocessorConfiguration - Class in com.wavefront.agent.preprocessor
Parses and stores all preprocessor rules (organized by listening port) Created by Vasily on 9/15/16.
AgentPreprocessorConfiguration() - Constructor for class com.wavefront.agent.preprocessor.AgentPreprocessorConfiguration
 
aggregationIntervalSeconds - Variable in class com.wavefront.agent.config.LogsIngestionConfig
How often metrics are aggregated and sent to wavefront.
AnnotatedPredicate<T> - Class in com.wavefront.agent.preprocessor
This is the base class for all "filter"-type rules.
AnnotatedPredicate() - Constructor for class com.wavefront.agent.preprocessor.AnnotatedPredicate
 
apply(ChannelHandlerContext, String) - Method in class com.wavefront.agent.channel.CachingGraphiteHostAnnotator
 
apply(String) - Method in class com.wavefront.agent.formatter.GraphiteFormatter
 
apply(T) - Method in class com.wavefront.agent.preprocessor.AnnotatedPredicate
 
apply(String) - Method in class com.wavefront.agent.preprocessor.PointLineBlacklistRegexFilter
 
apply(String) - Method in class com.wavefront.agent.preprocessor.PointLineReplaceRegexTransformer
 
apply(String) - Method in class com.wavefront.agent.preprocessor.PointLineWhitelistRegexFilter
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointAddPrefixTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointAddTagIfNotExistsTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointBlacklistRegexFilter
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointDropTagTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointExtractTagIfNotExistsTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointForceLowercaseTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointLimitLengthTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointRenameTagTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointReplaceRegexTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointTimestampInRangeFilter
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointWhitelistRegexFilter
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanAddAnnotationIfNotExistsTransformer
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanAddAnnotationTransformer
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanBlacklistRegexFilter
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanDropAnnotationTransformer
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanExtractAnnotationIfNotExistsTransformer
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanForceLowercaseTransformer
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanLimitLengthTransformer
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanReplaceRegexTransformer
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanWhitelistRegexFilter
 
aroundWriteTo(WriterInterceptorContext) - Method in class com.wavefront.agent.channel.DisableGZIPEncodingInterceptor
 
asBytes(ByteBuffer) - Method in class com.tdunning.math.stats.AgentDigest
 
asSmallBytes(ByteBuffer) - Method in class com.tdunning.math.stats.AgentDigest
 
authMethod - Variable in class com.wavefront.agent.AbstractAgent
 
authorize(String) - Method in interface com.wavefront.agent.auth.TokenAuthenticator
Validate a token.
authorized(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
 
authRequired() - Method in interface com.wavefront.agent.auth.TokenAuthenticator
Check whether authentication is required (i.e.
authResponseMaxTtl - Variable in class com.wavefront.agent.AbstractAgent
 
authResponseRefreshInterval - Variable in class com.wavefront.agent.AbstractAgent
 
authStaticToken - Variable in class com.wavefront.agent.AbstractAgent
 
authTokenIntrospectionAuthorizationHeader - Variable in class com.wavefront.agent.AbstractAgent
 
authTokenIntrospectionServiceUrl - Variable in class com.wavefront.agent.AbstractAgent
 
avgHistogramDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
 
avgHistogramKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
 

B

Batch - Class in org.logstash.beats
 
Batch() - Constructor for class org.logstash.beats.Batch
 
BeatsHandler - Class in org.logstash.beats
 
BeatsHandler(IMessageListener) - Constructor for class org.logstash.beats.BeatsHandler
 
BeatsParser - Class in org.logstash.beats
 
BeatsParser() - Constructor for class org.logstash.beats.BeatsParser
 
BeatsParser.InvalidFrameProtocolException - Exception in org.logstash.beats
 
bindErrors - Variable in class com.wavefront.agent.PushAgent
 
blacklistRegex - Variable in class com.wavefront.agent.AbstractAgent
 
block(T) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
Handle the input object as blocked.
block(T, String) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
Handle the input object as blocked.
blockedPointsPerBatch - Variable in class com.wavefront.agent.PointHandlerImpl
 
bufferSpaceLeft - Variable in class com.wavefront.agent.AbstractAgent
 
build() - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
build(ByteBufAllocator) - Method in class org.logstash.netty.SslSimpleBuilder
 
byteSize() - Method in class com.tdunning.math.stats.AgentDigest
 

C

CachingGraphiteHostAnnotator - Class in com.wavefront.agent.channel
Given a raw Graphite/Wavefront line, look for any host tag, and add it if implicit.
CachingGraphiteHostAnnotator(List<String>, boolean) - Constructor for class com.wavefront.agent.channel.CachingGraphiteHostAnnotator
 
cdf(double) - Method in class com.tdunning.math.stats.AgentDigest
 
centroidCount() - Method in class com.tdunning.math.stats.AgentDigest
Number of centroids of this AgentDigest (does compress if necessary)
centroids() - Method in class com.tdunning.math.stats.AgentDigest
Not clear to me that this is a good idea, maybe just add the temp points and existing centroids rather then merging first?
ChangeableGauge<T> - Class in com.wavefront.agent.logsharvesting
 
ChangeableGauge() - Constructor for class com.wavefront.agent.logsharvesting.ChangeableGauge
 
channelActive(ChannelHandlerContext) - Method in class com.wavefront.agent.channel.ConnectionTrackingHandler
 
ChannelByteArrayHandler - Class in com.wavefront.agent.listeners
Channel handler for byte array data.
ChannelByteArrayHandler(Decoder<byte[]>, PointHandler, ReportableEntityPreprocessor) - Constructor for class com.wavefront.agent.listeners.ChannelByteArrayHandler
Constructor.
channelInactive(ChannelHandlerContext) - Method in class com.wavefront.agent.channel.ConnectionTrackingHandler
 
channelRead0(ChannelHandlerContext, Object) - Method in class com.wavefront.agent.histogram.QueuingChannelHandler
 
channelRead0(ChannelHandlerContext, byte[]) - Method in class com.wavefront.agent.listeners.ChannelByteArrayHandler
 
channelRead0(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.ChannelStringHandler
Deprecated.
 
channelRead0(ChannelHandlerContext, Object) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
 
channelRead0(ChannelHandlerContext, Batch) - Method in class org.logstash.beats.BeatsHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
 
ChannelStringHandler - Class in com.wavefront.agent.listeners
Deprecated.
ChannelStringHandler(Decoder<String>, PointHandler, ReportableEntityPreprocessor) - Constructor for class com.wavefront.agent.listeners.ChannelStringHandler
Deprecated.
 
checkin(UUID, String, String, String, Long, Boolean, JsonNode, Boolean, Boolean) - Method in class com.wavefront.agent.QueuedAgentService
 
childChannelOptions - Variable in class com.wavefront.agent.PushAgent
 
ClassNameSerializer() - Constructor for class com.wavefront.agent.histogram.MapSettings.ClassNameSerializer
 
close() - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
close() - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
close() - Method in class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
 
close() - Method in class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
 
CODE_COMPRESSED_FRAME - Static variable in class org.logstash.beats.Protocol
 
CODE_FRAME - Static variable in class org.logstash.beats.Protocol
 
CODE_JSON_FRAME - Static variable in class org.logstash.beats.Protocol
 
CODE_WINDOW_SIZE - Static variable in class org.logstash.beats.Protocol
 
com.google.common.util.concurrent - package com.google.common.util.concurrent
 
com.tdunning.math.stats - package com.tdunning.math.stats
 
com.wavefront.agent - package com.wavefront.agent
 
com.wavefront.agent.api - package com.wavefront.agent.api
 
com.wavefront.agent.auth - package com.wavefront.agent.auth
 
com.wavefront.agent.channel - package com.wavefront.agent.channel
 
com.wavefront.agent.config - package com.wavefront.agent.config
 
com.wavefront.agent.formatter - package com.wavefront.agent.formatter
 
com.wavefront.agent.handlers - package com.wavefront.agent.handlers
 
com.wavefront.agent.histogram - package com.wavefront.agent.histogram
 
com.wavefront.agent.histogram.accumulator - package com.wavefront.agent.histogram.accumulator
 
com.wavefront.agent.histogram.tape - package com.wavefront.agent.histogram.tape
 
com.wavefront.agent.listeners - package com.wavefront.agent.listeners
 
com.wavefront.agent.listeners.tracing - package com.wavefront.agent.listeners.tracing
 
com.wavefront.agent.logsharvesting - package com.wavefront.agent.logsharvesting
Classes for harvesting metric data from logs and sending them to Wavefront.
com.wavefront.agent.preprocessor - package com.wavefront.agent.preprocessor
 
com.wavefront.agent.sampler - package com.wavefront.agent.sampler
 
commitHeaders(ClientInvocation, HttpURLConnection) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
compareTo(Message) - Method in class org.logstash.beats.Message
 
compiledMatchPattern - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
compiledMatchPattern - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
compiledSearchPattern - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
compiledSearchPattern - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
complete() - Method in class org.logstash.beats.Batch
 
compress() - Method in class com.tdunning.math.stats.AgentDigest
 
compression() - Method in class com.tdunning.math.stats.AgentDigest
 
compute(Utils.HistogramKey, BiFunction<? super Utils.HistogramKey, ? super AgentDigest, ? extends AgentDigest>) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
configReloadIntervalSeconds - Variable in class com.wavefront.agent.config.LogsIngestionConfig
How often to check this config file for updates.
Configuration - Class in com.wavefront.agent.config
 
Configuration() - Constructor for class com.wavefront.agent.config.Configuration
 
ConfigurationException - Exception in com.wavefront.agent.config
 
ConfigurationException(String) - Constructor for exception com.wavefront.agent.config.ConfigurationException
 
configureTokenAuthenticator() - Method in class com.wavefront.agent.AbstractAgent
 
ConnectionTrackingHandler - Class in com.wavefront.agent.channel
Track the number of currently active connections and total count of accepted incoming connections.
ConnectionTrackingHandler(Counter, Counter) - Constructor for class com.wavefront.agent.channel.ConnectionTrackingHandler
 
connectSocket(int, Socket, HttpHost, InetSocketAddress, InetSocketAddress, HttpContext) - Method in class com.wavefront.agent.SSLConnectionSocketFactoryImpl
 
convert(String) - Method in class com.wavefront.agent.auth.TokenValidationMethod.TokenValidationMethodConverter
 
convertToUuidString(String) - Static method in class com.wavefront.agent.Utils
Method converts a string Id to UUID.
countCpuNanos(long) - Method in class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
Deprecated.
counters - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Counters to ingest from incoming log data.
create(double, double) - Static method in class com.google.common.util.concurrent.RecyclableRateLimiter
 
create() - Static method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
createAgentService() - Method in class com.wavefront.agent.AbstractAgent
Create RESTeasy proxies for remote calls via HTTP.
createConnection(ClientInvocation) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
createLayeredSocket(Socket, String, int, HttpContext) - Method in class com.wavefront.agent.SSLConnectionSocketFactoryImpl
 
createSenderTasks(HandlerKey, int) - Method in interface com.wavefront.agent.handlers.SenderTaskFactory
Create a collection of objects for a specified handler key.
createSenderTasks(HandlerKey, int) - Method in class com.wavefront.agent.handlers.SenderTaskFactoryImpl
 
createSocket(HttpContext) - Method in class com.wavefront.agent.SSLConnectionSocketFactoryImpl
 
createSocket(Socket, String, int, boolean) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
createSocket() - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
createSocket(InetAddress, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
createSocket(InetAddress, int, InetAddress, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
createSocket(String, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
createSocket(String, int, InetAddress, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
currentAgentId - Variable in class com.wavefront.agent.ResubmissionTask
To be injected.
customSourceTags - Variable in class com.wavefront.agent.AbstractAgent
 
customSourceTagsProperty - Variable in class com.wavefront.agent.AbstractAgent
 

D

dataBackfillCutoffHours - Variable in class com.wavefront.agent.AbstractAgent
 
dataDogJsonPorts - Variable in class com.wavefront.agent.AbstractAgent
 
DataDogPortUnificationHandler - Class in com.wavefront.agent.listeners
This class handles an incoming message of either String or FullHttpRequest type.
DataDogPortUnificationHandler(String, ReportableEntityHandlerFactory, boolean, boolean, HttpClient, String, ReportableEntityPreprocessor) - Constructor for class com.wavefront.agent.listeners.DataDogPortUnificationHandler
 
DataDogPortUnificationHandler(String, ReportableEntityHandler<ReportPoint>, boolean, boolean, HttpClient, String, ReportableEntityPreprocessor) - Constructor for class com.wavefront.agent.listeners.DataDogPortUnificationHandler
 
dataDogProcessServiceChecks - Variable in class com.wavefront.agent.AbstractAgent
 
dataDogProcessSystemMetrics - Variable in class com.wavefront.agent.AbstractAgent
 
dataDogRequestRelayTarget - Variable in class com.wavefront.agent.AbstractAgent
 
dataPrefillCutoffHours - Variable in class com.wavefront.agent.AbstractAgent
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.wavefront.agent.channel.PlainTextOrHttpFrameDecoder
Dynamically adds the appropriate encoder/decoder(s) to the pipeline based on the detected protocol.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.logstash.beats.BeatsParser
 
DEFAULT_CIPHERS - Static variable in class org.logstash.netty.SslSimpleBuilder
 
delete(Utils.HistogramKey, AgentDigest, RemovalCause) - Method in class com.wavefront.agent.histogram.accumulator.Layering
 
deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class com.wavefront.agent.histogram.MapSettings.ClassNameSerializer
 
deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class com.wavefront.agent.ResubmissionTaskDeserializer
 
destroy() - Method in class com.wavefront.agent.PushAgentDaemon
 
DisableGZIPEncodingInterceptor - Class in com.wavefront.agent.channel
This RESTEasy interceptor allows disabling GZIP compression even for methods annotated with @GZIP by removing the Content-Encoding header.
DisableGZIPEncodingInterceptor() - Constructor for class com.wavefront.agent.channel.DisableGZIPEncodingInterceptor
 
disableRdnsLookup - Variable in class com.wavefront.agent.AbstractAgent
 
drainBuffersToQueue() - Method in interface com.wavefront.agent.handlers.SenderTask
Force memory buffer flush.
drainBuffersToQueue() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
DroppingSender - Class in com.wavefront.agent.histogram
Dummy sender.
DroppingSender(ObjectQueue<ReportPoint>) - Constructor for class com.wavefront.agent.histogram.DroppingSender
 

E

enableSSL(SslSimpleBuilder) - Method in class org.logstash.beats.Server
 
encode(ChannelHandlerContext, Ack, ByteBuf) - Method in class org.logstash.beats.AckEncoder
 
enforceBufferLimits() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
ensure(boolean, String) - Method in class com.wavefront.agent.config.Configuration
 
ephemeral - Variable in class com.wavefront.agent.AbstractAgent
 
equals(Object) - Method in class com.wavefront.agent.config.Configuration
 
equals(Object) - Method in class com.wavefront.agent.handlers.HandlerKey
 
equals(Object) - Method in class com.wavefront.agent.histogram.MapSettings
 
equals(Object) - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
equals(Object) - Method in class com.wavefront.agent.listeners.tracing.HeartbeatMetricKey
 
ERROR_SPAN_TAG_KEY - Static variable in class com.wavefront.agent.listeners.tracing.SpanDerivedMetricsUtils
 
ERROR_SPAN_TAG_VAL - Static variable in class com.wavefront.agent.listeners.tracing.SpanDerivedMetricsUtils
 
evict(MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
EvictingMetricsRegistry - Class in com.wavefront.agent.logsharvesting
Wrapper for a Yammer MetricsRegistry, but has extra features regarding automatic removal of metrics.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.listeners.ChannelByteArrayHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.listeners.ChannelStringHandler
Deprecated.
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.logstash.beats.BeatsHandler
 
execute(Object) - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
execute(Object) - Method in class com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask
 
executeRequest(ClientInvocation, HttpURLConnection) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
expandPlaceholders(String, ReportPoint) - Static method in class com.wavefront.agent.preprocessor.PreprocessorUtil
Substitute {{...}} placeholders with corresponding components of the point {{metricName}} {{sourceName}} are replaced with the metric name and source respectively {{anyTagK}} is replaced with the value of the anyTagK point tag
expandPlaceholders(String, Span) - Static method in class com.wavefront.agent.preprocessor.PreprocessorUtil
Substitute {{...}} placeholders with corresponding components of a Span {{spanName}} {{sourceName}} are replaced with the span name and source respectively {{anyKey}} is replaced with the value of an annotation with anyKey key
expiryMillis - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Metrics are cleared from memory (and so their aggregation state is lost) if a metric is not updated within this many milliseconds.
extractAnnotation(Span, String) - Method in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
extractTag(ReportPoint, String) - Method in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
extractToken(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
 

F

FilebeatIngester - Class in com.wavefront.agent.logsharvesting
 
FilebeatIngester(LogsIngester, Supplier<Long>) - Constructor for class com.wavefront.agent.logsharvesting.FilebeatIngester
 
FilebeatMessage - Class in com.wavefront.agent.logsharvesting
Abstraction for Message
FilebeatMessage(Message) - Constructor for class com.wavefront.agent.logsharvesting.FilebeatMessage
 
filebeatPort - Variable in class com.wavefront.agent.AbstractAgent
 
filter(T) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Apply all filter predicates sequentially, stop at the first "false" result
firstMatchOnly - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
flush() - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
flush() - Method in class com.wavefront.agent.logsharvesting.LogsIngester
 
FlushProcessorContext - Class in com.wavefront.agent.logsharvesting
 
flushThreads - Variable in class com.wavefront.agent.AbstractAgent
 
forceConfigReload() - Method in class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
Forces the next call to LogsIngestionConfigManager.getConfig() to call the config supplier.
ForceQueueEnabledAgentAPI - Interface in com.wavefront.agent.api
 
formatErrorMessage(String, Throwable, ChannelHandlerContext) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
Create a detailed error message from an exception.
forPointLine() - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
 
forPort(String) - Method in class com.wavefront.agent.preprocessor.AgentPreprocessorConfiguration
 
forReportPoint() - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
 
forSpan() - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
 
from(byte[]) - Method in class com.wavefront.agent.histogram.tape.TapeReportPointConverter
 
from(byte[]) - Method in class com.wavefront.agent.histogram.tape.TapeStringListConverter
 
fromMetricName(MetricName) - Static method in class com.wavefront.agent.logsharvesting.TimeSeriesUtils
 
fromMillis(long) - Static method in enum com.wavefront.agent.histogram.Utils.Granularity
 
fromSamplers(Sampler...) - Static method in class com.wavefront.agent.sampler.SpanSamplerUtils
 
fromString(String) - Static method in enum com.wavefront.agent.auth.TokenValidationMethod
 
fromString(String) - Static method in enum com.wavefront.agent.histogram.Utils.Granularity
 
fromString(String) - Static method in enum com.wavefront.agent.preprocessor.LengthLimitActionType
 

G

gauges - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Gauges to ingest from incoming log data.
get() - Static method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
get(File) - Method in class com.wavefront.agent.histogram.MapLoader
 
get() - Static method in class com.wavefront.agent.histogram.tape.TapeReportPointConverter
 
get() - Static method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
getAgentId() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
getApplication() - Method in class com.wavefront.agent.listeners.tracing.HeartbeatMetricKey
 
getAttemptedPoints() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getAvailablePermits() - Method in class com.google.common.util.concurrent.RecyclableRateLimiter
Get the number of accumulated permits
getAvgKeySize() - Method in class com.wavefront.agent.histogram.MapSettings
 
getAvgValueSize() - Method in class com.wavefront.agent.histogram.MapSettings
 
getBatch() - Method in class org.logstash.beats.Message
 
getBatchSize() - Method in class org.logstash.beats.Batch
 
getBinDurationInMillis() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getBinId(long) - Method in enum com.wavefront.agent.histogram.Utils.Granularity
Bin id for an epoch time is the epoch time in the corresponding granularity.
getBinId() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getBinTimeMillis() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getBlockedSampleSize() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getBoolean(String, Boolean) - Method in class com.wavefront.agent.config.ReportableConfig
 
getBufferFlushTask() - Method in class com.wavefront.agent.histogram.QueuingChannelHandler
 
getBytesPerMinute() - Method in class com.wavefront.agent.QueuedAgentService
 
getCluster() - Method in class com.wavefront.agent.listeners.tracing.HeartbeatMetricKey
 
getCompressionEnabledInstance() - Static method in class com.wavefront.agent.histogram.tape.TapeStringListConverter
Returns the TapeStringListConverter object instance with LZ4 compression enabled
getConfig() - Method in class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
 
getConfig(UUID, String, Long, Long, Long, Long, String, String) - Method in class com.wavefront.agent.QueuedAgentService
 
getCounter(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
getCurrentMillis() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
getDaemonId() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getData() - Method in class org.logstash.beats.Message
 
getDecoderInstance() - Method in class com.wavefront.agent.PushAgent
 
getDefaultCipherSuites() - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
getDefaultInstance() - Static method in class com.wavefront.agent.histogram.tape.TapeStringListConverter
Returns the TapeStringListConverter object instance with default settings (no compression)
getDispatchTimeMillis() - Method in class com.tdunning.math.stats.AgentDigest
Time at which this digest should be dispatched to wavefront.
getDurationSampler(int) - Static method in class com.wavefront.agent.sampler.SpanSamplerUtils
 
getEntityType() - Method in class com.wavefront.agent.handlers.HandlerKey
 
getEntries() - Method in class com.wavefront.agent.histogram.MapSettings
 
getFailureCount() - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
getFlushingToQueueFlag() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getFlushTasks(String) - Method in class com.wavefront.agent.AbstractAgent
 
getFlushTasks(String, String) - Method in class com.wavefront.agent.AbstractAgent
 
getFormat() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
getGauge(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
getGranularityOrdinal() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getHandle() - Method in class com.wavefront.agent.handlers.HandlerKey
 
getHandler(HandlerKey) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandlerFactory
Create, or return existing, ReportableEntityHandler.
getHandler(HandlerKey) - Method in class com.wavefront.agent.handlers.ReportableEntityHandlerFactoryImpl
 
getHeaders(HttpURLConnection) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
getHistogram(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
getHostnameVerifier() - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
getIdentityStream() - Method in class org.logstash.beats.Message
 
getInMillis() - Method in enum com.wavefront.agent.histogram.Utils.Granularity
Duration of a corresponding bin in milliseconds.
getInstance() - Static method in class com.wavefront.agent.SharedMetricsRegistry
 
getKeyClass() - Method in class com.wavefront.agent.histogram.MapSettings
 
getKeyMarshaller() - Method in class com.wavefront.agent.histogram.MapSettings
 
getKeySetAccessor() - Method in class com.wavefront.agent.histogram.accumulator.Layering
 
getLastFilterResult() - Method in class com.wavefront.agent.preprocessor.Preprocessor
Get the detailed message, if available, with the result of the last filter() operation
getLogLine() - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
 
getLogLine() - Method in interface com.wavefront.agent.logsharvesting.LogsMessage
 
getMessage(T) - Method in class com.wavefront.agent.preprocessor.AnnotatedPredicate
If special handling is needed based on the result of apply(), override getMessage() to return more details
getMessage(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointTimestampInRangeFilter
 
getMessages() - Method in class org.logstash.beats.Batch
 
getMetric() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getMetricMangler() - Method in class com.wavefront.agent.formatter.GraphiteFormatter
 
getNumApiCalls() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getNumber(String, Number) - Method in class com.wavefront.agent.config.ReportableConfig
 
getNumber(String, Number, Number, Number) - Method in class com.wavefront.agent.config.ReportableConfig
 
getNumPointsQueued() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getNumPointsToSend() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getOps() - Method in class com.wavefront.agent.formatter.GraphiteFormatter
 
getPattern() - Method in class com.wavefront.agent.config.MetricMatcher
 
getProtocol() - Method in class org.logstash.beats.Ack
 
getProtocol() - Method in class org.logstash.beats.Batch
 
getPushData() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
getQueuedSourceTagTasksCount() - Method in class com.wavefront.agent.QueuedAgentService
 
getQueuedTasksCount() - Method in class com.wavefront.agent.QueuedAgentService
 
getRandomPostTask() - Method in class com.wavefront.agent.PointHandlerImpl
 
getRateSampler(double) - Static method in class com.wavefront.agent.sampler.SpanSamplerUtils
 
getRawProperty(String, String) - Method in class com.wavefront.agent.config.ReportableConfig
Returns string value for the property without tracking it as a metric
getRemoteHost(ChannelHandlerContext) - Method in class com.wavefront.agent.channel.CachingGraphiteHostAnnotator
 
getRemoteName(ChannelHandlerContext) - Static method in class com.wavefront.agent.listeners.PortUnificationHandler
Get remote client's address as string (without rDNS lookup) and local port
getResolveTask() - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Task to merge the contents of this cache with the corresponding backing store.
getRipeDigestsIterator(TimeProvider) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Returns an iterator over "ripe" digests ready to be shipped
getSequence() - Method in class org.logstash.beats.Ack
 
getSequence() - Method in class org.logstash.beats.Message
 
getService() - Method in class com.wavefront.agent.listeners.tracing.HeartbeatMetricKey
 
getShard() - Method in class com.wavefront.agent.listeners.tracing.HeartbeatMetricKey
 
getSize(JsonNode, Class<?>, Type, Annotation[], MediaType) - Method in class com.wavefront.agent.JsonNodeWriter
 
getSource() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getSource() - Method in class com.wavefront.agent.listeners.tracing.HeartbeatMetricKey
 
getSslCertificateFile() - Method in class org.logstash.netty.SslSimpleBuilder
 
getSslContext() - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
getSslKeyFile() - Method in class org.logstash.netty.SslSimpleBuilder
 
getString(String, String) - Method in class com.wavefront.agent.config.ReportableConfig
 
getString(String, String, Function<String, String>) - Method in class com.wavefront.agent.config.ReportableConfig
 
getSupportedCipherSuites() - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
getTags() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getTagsAsMap() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
Unpacks tags into a map.
getTape(File) - Method in class com.wavefront.agent.histogram.tape.TapeDeck
 
getTaskRelativeScore() - Method in interface com.wavefront.agent.handlers.SenderTask
Calculate a numeric score (the lower the better) that is intended to help the ReportableEntityHandler to choose the best SenderTask to handle over data to.
getTimestampMillis() - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
 
getValue() - Method in class com.wavefront.agent.logsharvesting.ReadProcessorContext
 
getValueClass() - Method in class com.wavefront.agent.histogram.MapSettings
 
getValueLabel() - Method in class com.wavefront.agent.config.MetricMatcher
 
getValueMarshaller() - Method in class com.wavefront.agent.histogram.MapSettings
 
getWorkUnitId() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
getWriteBackTask() - Method in class com.wavefront.agent.histogram.accumulator.Layering
Returns a runnable for writing back dirty entries to the backing store.
granularityToString(Utils.Granularity) - Static method in enum com.wavefront.agent.histogram.Utils.Granularity
 
graphiteBlacklistRegex - Variable in class com.wavefront.agent.AbstractAgent
 
graphiteDelimiters - Variable in class com.wavefront.agent.AbstractAgent
 
graphiteFieldsToRemove - Variable in class com.wavefront.agent.AbstractAgent
 
graphiteFormat - Variable in class com.wavefront.agent.AbstractAgent
 
GraphiteFormatter - Class in com.wavefront.agent.formatter
Specific formatter for the graphite/collectd world of metric-munged names.
GraphiteFormatter(String, String, String) - Constructor for class com.wavefront.agent.formatter.GraphiteFormatter
 
graphitePorts - Variable in class com.wavefront.agent.AbstractAgent
 
graphiteWhitelistRegex - Variable in class com.wavefront.agent.AbstractAgent
 
gzipCompression - Variable in class com.wavefront.agent.AbstractAgent
 

H

hadSuccessfulCheckin - Variable in class com.wavefront.agent.AbstractAgent
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class com.wavefront.agent.listeners.JsonMetricsEndpoint
 
handle - Variable in class com.wavefront.agent.listeners.PortUnificationHandler
 
handle(String, Request, HttpServletRequest, HttpServletResponse) - Method in class com.wavefront.agent.listeners.WriteHttpJsonMetricsEndpoint
 
handleBlockedPoint(String) - Method in interface com.wavefront.agent.PointHandler
Called when a blocked line is encountered.
handleBlockedPoint(String) - Method in class com.wavefront.agent.PointHandlerImpl
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.DataDogPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.OpenTSDBPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
Handles an incoming HTTP message.
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.RelayPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
 
handleImpl(ThriftRequest<Collector.submitBatches_args>) - Method in class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
 
handlePlainTextMessage(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.DataDogPortUnificationHandler
Handles an incoming plain text (string) message.
handlePlainTextMessage(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.OpenTSDBPortUnificationHandler
Handles an incoming plain text (string) message.
handlePlainTextMessage(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
Handles an incoming plain text (string) message.
handlerAdded(ChannelHandlerContext) - Method in class org.logstash.beats.BeatsHandler
 
handlerFactory - Variable in class com.wavefront.agent.PushAgent
 
HandlerKey - Class in com.wavefront.agent.handlers
An immutable unique identifier for a handler pipeline (type of objects handled + port/handle name)
handlerRemoved(ChannelHandlerContext) - Method in class org.logstash.beats.BeatsHandler
 
hasCapture(String) - Method in class com.wavefront.agent.config.MetricMatcher
 
hasFilters() - Method in class com.wavefront.agent.preprocessor.Preprocessor
Check if any filters are registered
hashCode() - Method in class com.wavefront.agent.config.Configuration
 
hashCode() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
hashCode() - Method in class com.wavefront.agent.listeners.tracing.HeartbeatMetricKey
 
hasTransformers() - Method in class com.wavefront.agent.preprocessor.Preprocessor
Check if any transformation rules are registered
HeartbeatMetricKey - Class in com.wavefront.agent.listeners.tracing
Composition class that makes up the heartbeat metric.
HeartbeatMetricKey(String, String, String, String, String) - Constructor for class com.wavefront.agent.listeners.tracing.HeartbeatMetricKey
 
histogramAccumulatorFlushInterval - Variable in class com.wavefront.agent.AbstractAgent
 
histogramAccumulatorFlushMaxBatchSize - Variable in class com.wavefront.agent.AbstractAgent
 
histogramAccumulatorResolveInterval - Variable in class com.wavefront.agent.AbstractAgent
 
histogramAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
 
histogramCompression - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDayAccumulators - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDayAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDayAvgDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDayAvgKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDayCompression - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDayFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDayListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDayMemoryCache - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDisabled - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistAccumulators - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistAvgDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistAvgKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistCompression - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistMemoryCache - Variable in class com.wavefront.agent.AbstractAgent
 
histogramExecutor - Variable in class com.wavefront.agent.PushAgent
 
histogramFlushExecutor - Variable in class com.wavefront.agent.PushAgent
 
histogramHourAccumulators - Variable in class com.wavefront.agent.AbstractAgent
 
histogramHourAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
 
histogramHourAvgDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
 
histogramHourAvgKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
 
histogramHourCompression - Variable in class com.wavefront.agent.AbstractAgent
 
histogramHourFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
 
histogramHourListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
histogramHourMemoryCache - Variable in class com.wavefront.agent.AbstractAgent
 
HistogramLineIngester - Class in com.wavefront.agent.histogram
A ChannelInitializer for Histogram samples via TCP.
HistogramLineIngester(Collection<ChannelHandler>, int) - Constructor for class com.wavefront.agent.histogram.HistogramLineIngester
 
histogramMaxReceivedLength - Variable in class com.wavefront.agent.AbstractAgent
 
histogramMinuteAccumulators - Variable in class com.wavefront.agent.AbstractAgent
 
histogramMinuteAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
 
histogramMinuteAvgDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
 
histogramMinuteAvgKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
 
histogramMinuteCompression - Variable in class com.wavefront.agent.AbstractAgent
 
histogramMinuteFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
 
histogramMinuteListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
histogramMinuteMemoryCache - Variable in class com.wavefront.agent.AbstractAgent
 
histogramProcessingQueueScanInterval - Variable in class com.wavefront.agent.AbstractAgent
 
histogramReceiveBufferFlushInterval - Variable in class com.wavefront.agent.AbstractAgent
 
histograms - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Histograms to ingest from incoming log data.
histogramScanExecutor - Variable in class com.wavefront.agent.PushAgent
 
histogramStateDirectory - Variable in class com.wavefront.agent.AbstractAgent
 
hostAuthenticated(UUID, UUID) - Method in class com.wavefront.agent.QueuedAgentService
 
hostConnectionEstablished(UUID, UUID) - Method in class com.wavefront.agent.QueuedAgentService
 
hostConnectionFailed(UUID, UUID, String) - Method in class com.wavefront.agent.QueuedAgentService
 
hostname - Variable in class com.wavefront.agent.AbstractAgent
 
hostnameVerifier - Variable in class com.wavefront.agent.JavaNetConnectionEngine
 
hostOrDefault(String) - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
 
hostOrDefault(String) - Method in interface com.wavefront.agent.logsharvesting.LogsMessage
 
httpAutoRetries - Variable in class com.wavefront.agent.AbstractAgent
 
httpConnectTimeout - Variable in class com.wavefront.agent.AbstractAgent
 
httpEnabled - Variable in class com.wavefront.agent.listeners.PortUnificationHandler
 
httpMaxConnPerRoute - Variable in class com.wavefront.agent.AbstractAgent
 
httpMaxConnTotal - Variable in class com.wavefront.agent.AbstractAgent
 
httpRequestHandleDuration - Variable in class com.wavefront.agent.listeners.PortUnificationHandler
 
httpRequestTimeout - Variable in class com.wavefront.agent.AbstractAgent
 
httpUserAgent - Variable in class com.wavefront.agent.AbstractAgent
 

I

idFile - Variable in class com.wavefront.agent.AbstractAgent
 
IdleStateEventHandler - Class in com.wavefront.agent.channel
Disconnect idle clients (handle READER_IDLE events triggered by IdleStateHandler)
IdleStateEventHandler(Counter) - Constructor for class com.wavefront.agent.channel.IdleStateEventHandler
 
IMessageListener - Interface in org.logstash.beats
This class is implemented in ruby in `lib/logstash/inputs/beats/message_listener`, this class is used to link the events triggered from the different connection to the actual work inside the plugin.
incrementBlockedPoints() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
incrementRuleAppliedCounter() - Method in class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
Increment ruleAppliedCounter (if available) by 1
ingestLog(LogsMessage) - Method in class com.wavefront.agent.logsharvesting.LogsIngester
 
ingestLog(ChannelHandlerContext, String) - Method in class com.wavefront.agent.logsharvesting.RawLogsIngester
 
init(DaemonContext) - Method in class com.wavefront.agent.PushAgentDaemon
 
initChannel(Channel) - Method in class com.wavefront.agent.histogram.HistogramLineIngester
 
input - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
InteractiveLogsTester - Class in com.wavefront.agent.logsharvesting
 
InteractiveLogsTester(Supplier<LogsIngestionConfig>, String) - Constructor for class com.wavefront.agent.logsharvesting.InteractiveLogsTester
 
interactiveTest() - Method in class com.wavefront.agent.logsharvesting.InteractiveLogsTester
Read one line of stdin and print a message to stdout.
internalApply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
internalApply(Span) - Method in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
InternalProxyWavefrontClient - Class in com.wavefront.agent.handlers
 
InternalProxyWavefrontClient(ReportableEntityHandlerFactory) - Constructor for class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
InternalProxyWavefrontClient(ReportableEntityHandlerFactory, String) - Constructor for class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
invoke(ClientInvocation) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
isDefined(String) - Method in class com.wavefront.agent.config.ReportableConfig
 
isEmpty() - Method in class org.logstash.beats.Batch
 
isSslEnable() - Method in class org.logstash.beats.Server
 
isVersion2(byte) - Static method in class org.logstash.beats.Protocol
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.wavefront.agent.JsonNodeWriter
 

J

JaegerThriftCollectorHandler - Class in com.wavefront.agent.listeners.tracing
Handler that processes trace data in Jaeger Thrift compact format and converts them to Wavefront format
JaegerThriftCollectorHandler(String, ReportableEntityHandlerFactory, WavefrontSender, AtomicBoolean, ReportableEntityPreprocessor, Sampler, boolean) - Constructor for class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
 
JaegerThriftCollectorHandler(String, ReportableEntityHandler<Span>, WavefrontSender, AtomicBoolean, ReportableEntityPreprocessor, Sampler, boolean) - Constructor for class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
 
javaNetConnection - Variable in class com.wavefront.agent.AbstractAgent
 
JavaNetConnectionEngine - Class in com.wavefront.agent
ClientHttpEngine that uses HttpURLConnection to connect to an Http endpoint.
JavaNetConnectionEngine() - Constructor for class com.wavefront.agent.JavaNetConnectionEngine
 
jsonListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
JsonMetricsEndpoint - Class in com.wavefront.agent.listeners
Agent-side JSON metrics endpoint.
JsonMetricsEndpoint(String, String, String, String, int, PostPushDataTimedTask[], ReportableEntityPreprocessor) - Constructor for class com.wavefront.agent.listeners.JsonMetricsEndpoint
 
JsonNodeWriter - Class in com.wavefront.agent
Writer that serializes JsonNodes.
JsonNodeWriter() - Constructor for class com.wavefront.agent.JsonNodeWriter
 

K

key - Variable in class com.wavefront.agent.preprocessor.SpanAddAnnotationTransformer
 
key - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
keySet() - Method in interface com.wavefront.agent.histogram.accumulator.Layering.KeySetAccessor
Keys in the combined set.

L

Layering - Class in com.wavefront.agent.histogram.accumulator
Basic layering between Caffeine and some backing store.
Layering(ConcurrentMap<Utils.HistogramKey, AgentDigest>) - Constructor for class com.wavefront.agent.histogram.accumulator.Layering
 
Layering.KeySetAccessor - Interface in com.wavefront.agent.histogram.accumulator
 
lazySupplier(Supplier<T>) - Static method in class com.wavefront.agent.Utils
A lazy initialization wrapper for Supplier
LengthLimitActionType - Enum in com.wavefront.agent.preprocessor
 
listen() - Method in class com.wavefront.agent.logsharvesting.RawLogsIngester
 
listen() - Method in class org.logstash.beats.Server
 
listenerIdleConnectionTimeout - Variable in class com.wavefront.agent.AbstractAgent
 
load(Utils.HistogramKey) - Method in class com.wavefront.agent.histogram.accumulator.Layering
 
loadFromStream(InputStream) - Method in class com.wavefront.agent.preprocessor.AgentPreprocessorConfiguration
 
loadLogsIngestionConfig() - Method in class com.wavefront.agent.AbstractAgent
 
localAgent - Variable in class com.wavefront.agent.AbstractAgent
 
logger - Static variable in class com.wavefront.agent.AbstractAgent
 
logger - Static variable in class com.wavefront.agent.channel.PlainTextOrHttpFrameDecoder
 
logger - Static variable in class com.wavefront.agent.config.MetricMatcher
 
logger - Static variable in class com.wavefront.agent.histogram.QueuingChannelHandler
 
logger - Static variable in class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
 
logger - Static variable in class com.wavefront.agent.listeners.WriteHttpJsonMetricsEndpoint
 
logger - Static variable in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
logger - Static variable in class com.wavefront.agent.logsharvesting.FilebeatIngester
 
logger - Static variable in class com.wavefront.agent.logsharvesting.LogsIngester
 
logger - Static variable in class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
 
logger - Static variable in class com.wavefront.agent.logsharvesting.MetricsReporter
 
LogsIngester - Class in com.wavefront.agent.logsharvesting
Consumes log messages sent to LogsIngester.ingestLog(LogsMessage).
LogsIngester(PointHandler, Supplier<LogsIngestionConfig>, String, Supplier<Long>) - Constructor for class com.wavefront.agent.logsharvesting.LogsIngester
 
LogsIngestionConfig - Class in com.wavefront.agent.config
Top level configuration object for ingesting log data into the Wavefront Proxy.
LogsIngestionConfig() - Constructor for class com.wavefront.agent.config.LogsIngestionConfig
 
logsIngestionConfigFile - Variable in class com.wavefront.agent.AbstractAgent
 
LogsIngestionConfigManager - Class in com.wavefront.agent.logsharvesting
Wrapper for a LogsIngestionConfig that supports hot-loading and removal notifications.
LogsIngestionConfigManager(Supplier<LogsIngestionConfig>, Consumer<MetricMatcher>) - Constructor for class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
 
LogsMessage - Interface in com.wavefront.agent.logsharvesting
 
logWarning(String, Throwable, ChannelHandlerContext) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
Log a detailed error message with remote IP address

M

main(String[]) - Static method in class com.wavefront.agent.PushAgent
 
main(String[]) - Static method in class org.logstash.beats.Runner
 
makeKey(ReportPoint, Utils.Granularity) - Static method in class com.wavefront.agent.histogram.Utils
Generates a Utils.HistogramKey according a prototype ReportPoint and Utils.Granularity.
MalformedMessageException - Exception in com.wavefront.agent.logsharvesting
 
managedExecutors - Variable in class com.wavefront.agent.AbstractAgent
 
managedTasks - Variable in class com.wavefront.agent.AbstractAgent
 
managedThreads - Variable in class com.wavefront.agent.PushAgent
 
MapLoader<K,V,KM extends net.openhft.chronicle.hash.serialization.BytesReader<K> & net.openhft.chronicle.hash.serialization.BytesWriter<K>,VM extends net.openhft.chronicle.hash.serialization.SizedReader<V> & net.openhft.chronicle.hash.serialization.SizedWriter<V>> - Class in com.wavefront.agent.histogram
Loader for ChronicleMap.
MapLoader(Class<K>, Class<V>, long, double, double, KM, VM, boolean) - Constructor for class com.wavefront.agent.histogram.MapLoader
Creates a new MapLoader
MAPPER - Static variable in class org.logstash.beats.BeatsParser
 
MapSettings - Class in com.wavefront.agent.histogram
Stores settings ChronicleMap has been initialized with to trigger map re-creation when settings change (since ChronicleMap doesn't persist init values for entries/avgKeySize/avgValueSize)
MapSettings(Class, Class, Class, Class, long, double, double) - Constructor for class com.wavefront.agent.histogram.MapSettings
 
MapSettings.ClassNameSerializer - Class in com.wavefront.agent.histogram
 
memGuardFlushThreshold - Variable in class com.wavefront.agent.AbstractAgent
 
Message - Class in org.logstash.beats
 
Message(int, Map) - Constructor for class org.logstash.beats.Message
 
MessageListener - Class in org.logstash.beats
This class is implemented in ruby in `lib/logstash/inputs/beats/message_listener`, this class is used to link the events triggered from the different connection to the actual work inside the plugin.
MessageListener() - Constructor for class org.logstash.beats.MessageListener
 
MetricMatcher - Class in com.wavefront.agent.config
Object defining transformation between a log line into structured telemetry data.
MetricMatcher() - Constructor for class com.wavefront.agent.config.MetricMatcher
 
metricsRegistry() - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
MetricsReporter - Class in com.wavefront.agent.logsharvesting
 
MetricsReporter(MetricsRegistry, FlushProcessor, String, PointHandler, String) - Constructor for class com.wavefront.agent.logsharvesting.MetricsReporter
 
millisSinceEpoch() - Method in interface com.wavefront.agent.histogram.TimeProvider
 

O

of(ReportableEntityType, String) - Static method in class com.wavefront.agent.handlers.HandlerKey
 
onChannelInitializeException(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.logsharvesting.FilebeatIngester
 
onChannelInitializeException(ChannelHandlerContext, Throwable) - Method in interface org.logstash.beats.IMessageListener
Called when a error occur in the channel initialize, usually ssl handshake error.
onChannelInitializeException(ChannelHandlerContext, Throwable) - Method in class org.logstash.beats.MessageListener
Called when a error occur in the channel initialize, usually ssl handshake error.
onConnectionClose(ChannelHandlerContext) - Method in class com.wavefront.agent.logsharvesting.FilebeatIngester
 
onConnectionClose(ChannelHandlerContext) - Method in interface org.logstash.beats.IMessageListener
Triggered when a connection is close on the remote end and we need to flush buffered events to the queue.
onConnectionClose(ChannelHandlerContext) - Method in class org.logstash.beats.MessageListener
Triggered when a connection is close on the remote end and we need to flush buffered events to the queue.
onException(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.logsharvesting.FilebeatIngester
 
onException(ChannelHandlerContext, Throwable) - Method in interface org.logstash.beats.IMessageListener
Called went something bad occur in the pipeline, allow to clear buffered codec went somethign goes wrong.
onException(ChannelHandlerContext, Throwable) - Method in class org.logstash.beats.MessageListener
Called went something bad occur in the pipeline, allow to clear buffered codec went somethign goes wrong.
onNewConnection(ChannelHandlerContext) - Method in class com.wavefront.agent.logsharvesting.FilebeatIngester
 
onNewConnection(ChannelHandlerContext) - Method in interface org.logstash.beats.IMessageListener
Triggered when a new client connect to the input, this is used to link a connection to a codec in the ruby world.
onNewConnection(ChannelHandlerContext) - Method in class org.logstash.beats.MessageListener
Triggered when a new client connect to the input, this is used to link a connection to a codec in the ruby world.
onNewMessage(ChannelHandlerContext, Message) - Method in class com.wavefront.agent.logsharvesting.FilebeatIngester
 
onNewMessage(ChannelHandlerContext, Message) - Method in interface org.logstash.beats.IMessageListener
This is triggered on every new message parsed by the beats handler and should be executed in the ruby world.
onNewMessage(ChannelHandlerContext, Message) - Method in class org.logstash.beats.MessageListener
This is triggered on every new message parsed by the beats handler and should be executed in the ruby world.
opentsdbBlacklistRegex - Variable in class com.wavefront.agent.AbstractAgent
 
opentsdbPorts - Variable in class com.wavefront.agent.AbstractAgent
 
OpenTSDBPortUnificationHandler - Class in com.wavefront.agent.listeners
This class handles an incoming message of either String or FullHttpRequest type.
OpenTSDBPortUnificationHandler(String, TokenAuthenticator, ReportableEntityDecoder<String, ReportPoint>, ReportableEntityHandlerFactory, ReportableEntityPreprocessor, CachingGraphiteHostAnnotator) - Constructor for class com.wavefront.agent.listeners.OpenTSDBPortUnificationHandler
 
opentsdbWhitelistRegex - Variable in class com.wavefront.agent.AbstractAgent
 
org.logstash.beats - package org.logstash.beats
 
org.logstash.netty - package org.logstash.netty
 

P

PARAMETERS_TO_HIDE - Static variable in class com.wavefront.agent.AbstractAgent
A set of commandline parameters to hide when echoing command line arguments
parseUri(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
 
patternReplace - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
patternReplace - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
patternReplaceInput - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
patternReplaceSource - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
patternsFile() - Method in class com.wavefront.agent.config.LogsIngestionConfig
 
peek() - Method in class com.wavefront.agent.ResubmissionTaskQueue
 
persistAccumulator - Variable in class com.wavefront.agent.AbstractAgent
 
persistMessages - Variable in class com.wavefront.agent.AbstractAgent
 
persistMessagesCompression - Variable in class com.wavefront.agent.AbstractAgent
 
picklePorts - Variable in class com.wavefront.agent.AbstractAgent
 
plaintextEnabled - Variable in class com.wavefront.agent.listeners.PortUnificationHandler
 
PlainTextOrHttpFrameDecoder - Class in com.wavefront.agent.channel
This class handles 2 different protocols on a single port.
PlainTextOrHttpFrameDecoder(ChannelHandler) - Constructor for class com.wavefront.agent.channel.PlainTextOrHttpFrameDecoder
Constructor with default input buffer limits (4KB for plaintext, 16MB for HTTP).
PlainTextOrHttpFrameDecoder(ChannelHandler, int, int) - Constructor for class com.wavefront.agent.channel.PlainTextOrHttpFrameDecoder
Constructor.
pointFromKeyAndDigest(Utils.HistogramKey, AgentDigest) - Static method in class com.wavefront.agent.histogram.Utils
PointHandler - Interface in com.wavefront.agent
Interface for a handler of Report Points.
PointHandlerDispatcher - Class in com.wavefront.agent.histogram
Dispatch task for marshalling "ripe" digests for shipment to the agent to a point handler.
PointHandlerDispatcher(AccumulationCache, PointHandler, Integer, Utils.Granularity) - Constructor for class com.wavefront.agent.histogram.PointHandlerDispatcher
 
PointHandlerImpl - Class in com.wavefront.agent
Adds all graphite strings to a working list, and batches them up on a set schedule (100ms) to be sent (through the daemon's logic) up to the collector on the server side.
PointHandlerImpl(String, String, int, PostPushDataTimedTask[]) - Constructor for class com.wavefront.agent.PointHandlerImpl
 
PointHandlerImpl(String, String, int, String, PostPushDataTimedTask[]) - Constructor for class com.wavefront.agent.PointHandlerImpl
 
PointLineBlacklistRegexFilter - Class in com.wavefront.agent.preprocessor
Blacklist regex filter.
PointLineBlacklistRegexFilter(String, Counter) - Constructor for class com.wavefront.agent.preprocessor.PointLineBlacklistRegexFilter
Deprecated.
PointLineBlacklistRegexFilter(String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.PointLineBlacklistRegexFilter
 
PointLineReplaceRegexTransformer - Class in com.wavefront.agent.preprocessor
Replace regex transformer.
PointLineReplaceRegexTransformer(String, String, String, Integer, Counter) - Constructor for class com.wavefront.agent.preprocessor.PointLineReplaceRegexTransformer
Deprecated.
PointLineReplaceRegexTransformer(String, String, String, Integer, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.PointLineReplaceRegexTransformer
 
PointLineWhitelistRegexFilter - Class in com.wavefront.agent.preprocessor
Whitelist regex filter.
PointLineWhitelistRegexFilter(String, Counter) - Constructor for class com.wavefront.agent.preprocessor.PointLineWhitelistRegexFilter
Deprecated.
PointLineWhitelistRegexFilter(String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.PointLineWhitelistRegexFilter
 
pointsDiscarded - Variable in class com.wavefront.agent.listeners.PortUnificationHandler
 
pointToString(ReportPoint) - Static method in class com.wavefront.agent.PointHandlerImpl
 
PortUnificationHandler - Class in com.wavefront.agent.listeners
This class handles an incoming message of either String or FullHttpRequest type.
PortUnificationHandler(TokenAuthenticator, String, boolean, boolean) - Constructor for class com.wavefront.agent.listeners.PortUnificationHandler
Create new instance.
postPushData(UUID, UUID, Long, String, String, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledAgentAPI
 
postPushData(UUID, UUID, Long, String, String) - Method in class com.wavefront.agent.QueuedAgentService
 
postPushData(UUID, UUID, Long, String, String, boolean) - Method in class com.wavefront.agent.QueuedAgentService
 
PostPushDataResultTask(UUID, UUID, Long, String, String) - Constructor for class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
PostPushDataTimedTask - Class in com.wavefront.agent
 
PostPushDataTimedTask(String, ForceQueueEnabledAgentAPI, String, UUID, String, int, RecyclableRateLimiter, long) - Constructor for class com.wavefront.agent.PostPushDataTimedTask
Deprecated.
PostPushDataTimedTask(String, ForceQueueEnabledAgentAPI, UUID, String, int, RecyclableRateLimiter, long) - Constructor for class com.wavefront.agent.PostPushDataTimedTask
 
PostSourceTagResultTask(String, String, QueuedAgentService.PostSourceTagResultTask.ActionType, QueuedAgentService.PostSourceTagResultTask.MessageType, String) - Constructor for class com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask
 
PostSourceTagResultTask(String, List<String>, QueuedAgentService.PostSourceTagResultTask.ActionType, QueuedAgentService.PostSourceTagResultTask.MessageType, String) - Constructor for class com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask
 
postWorkUnitResult(UUID, UUID, UUID, ShellOutputDTO, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledAgentAPI
 
postWorkUnitResult(UUID, UUID, UUID, ShellOutputDTO) - Method in class com.wavefront.agent.QueuedAgentService
 
postWorkUnitResult(UUID, UUID, UUID, ShellOutputDTO, boolean) - Method in class com.wavefront.agent.QueuedAgentService
 
prefix - Variable in class com.wavefront.agent.AbstractAgent
 
Preprocessor<T> - Class in com.wavefront.agent.preprocessor
Generic container class for storing transformation and filter rules Created by Vasily on 9/13/16.
Preprocessor() - Constructor for class com.wavefront.agent.preprocessor.Preprocessor
 
preprocessorConfigFile - Variable in class com.wavefront.agent.AbstractAgent
 
PreprocessorRuleMetrics - Class in com.wavefront.agent.preprocessor
A helper class for instrumenting preprocessor rules.
PreprocessorRuleMetrics(Counter, Counter, Counter) - Constructor for class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
 
PreprocessorRuleMetrics(Counter, Counter) - Constructor for class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
Deprecated.
PreprocessorRuleMetrics(Counter) - Constructor for class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
Deprecated.
preprocessors - Variable in class com.wavefront.agent.AbstractAgent
 
PreprocessorUtil - Class in com.wavefront.agent.preprocessor
Utility class for methods used by preprocessors.
PreprocessorUtil() - Constructor for class com.wavefront.agent.preprocessor.PreprocessorUtil
 
preprocessPointLine(String, ReportableEntityHandler) - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
 
processConfiguration(AgentConfiguration) - Method in class com.wavefront.agent.AbstractAgent
Actual agents can do additional configuration.
processConfiguration(AgentConfiguration) - Method in class com.wavefront.agent.PushAgent
Push agent configuration during check-in by the collector.
processCounter(MetricName, Counter, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processGauge(MetricName, Gauge<?>, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processHistogram(MetricName, Histogram, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processId - Variable in class com.wavefront.agent.AbstractAgent
A unique process ID value (PID, when available, or a random hexadecimal string), assigned at proxy start-up, to be reported with all ~proxy metrics as a "processId" point tag to prevent potential ~proxy metrics collisions caused by users spinning up multiple proxies with duplicate names.
processLine(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.DataDogPortUnificationHandler
 
processLine(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.OpenTSDBPortUnificationHandler
 
processLine(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
 
processLine(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
processLine(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
 
processLine(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.WavefrontPortUnificationHandler
 
processMeter(MetricName, Metered, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processPointLine(String, Decoder<String>, PointHandler, ReportableEntityPreprocessor, ChannelHandlerContext) - Static method in class com.wavefront.agent.listeners.ChannelStringHandler
Deprecated.
This probably belongs in a base class.
processTimer(MetricName, Timer, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
props - Variable in class com.wavefront.agent.AbstractAgent
 
Protocol - Class in org.logstash.beats
Created by ph on 2016-05-16.
Protocol() - Constructor for class org.logstash.beats.Protocol
 
proxyHost - Variable in class com.wavefront.agent.AbstractAgent
 
proxyPassword - Variable in class com.wavefront.agent.AbstractAgent
 
proxyPort - Variable in class com.wavefront.agent.AbstractAgent
 
proxyUser - Variable in class com.wavefront.agent.AbstractAgent
 
pushAgent - Variable in class com.wavefront.agent.AbstractAgent
 
PushAgent - Class in com.wavefront.agent
Push-only Agent.
PushAgent() - Constructor for class com.wavefront.agent.PushAgent
 
PushAgent(boolean) - Constructor for class com.wavefront.agent.PushAgent
Deprecated.
PushAgentDaemon - Class in com.wavefront.agent
 
PushAgentDaemon() - Constructor for class com.wavefront.agent.PushAgentDaemon
 
pushBlockedSamples - Variable in class com.wavefront.agent.AbstractAgent
 
pushFlushInterval - Variable in class com.wavefront.agent.AbstractAgent
 
pushFlushIntervalInitialValue - Variable in class com.wavefront.agent.AbstractAgent
 
pushFlushMaxPoints - Variable in class com.wavefront.agent.AbstractAgent
 
pushFlushMaxPointsInitialValue - Variable in class com.wavefront.agent.AbstractAgent
 
pushListenerHttpBufferSize - Variable in class com.wavefront.agent.AbstractAgent
 
pushListenerMaxReceivedLength - Variable in class com.wavefront.agent.AbstractAgent
 
pushListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
pushLogLevel - Variable in class com.wavefront.agent.AbstractAgent
 
pushMemoryBufferLimit - Variable in class com.wavefront.agent.AbstractAgent
 
pushRateLimit - Variable in class com.wavefront.agent.AbstractAgent
 
pushRateLimiter - Variable in class com.wavefront.agent.AbstractAgent
 
pushRateLimitMaxBurstSeconds - Variable in class com.wavefront.agent.AbstractAgent
 
pushRelayListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
pushValidationLevel - Variable in class com.wavefront.agent.AbstractAgent
 
put(Utils.HistogramKey, AgentDigest) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Update AgentDigest in the cache with another AgentDigest.
put(Utils.HistogramKey, double, short, long) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Update AgentDigest in the cache with a double value.
put(Utils.HistogramKey, Histogram, short, long) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Update AgentDigest in the cache with a Histogram value.

Q

quantile(double) - Method in class com.tdunning.math.stats.AgentDigest
 
QueuedAgentService - Class in com.wavefront.agent
A wrapper for any WavefrontAPI that queues up any result posting if the backend is not available.
QueuedAgentService(WavefrontAPI, String, int, ScheduledExecutorService, boolean, UUID, boolean, RecyclableRateLimiter, String) - Constructor for class com.wavefront.agent.QueuedAgentService
 
QueuedAgentService.PostPushDataResultTask - Class in com.wavefront.agent
 
QueuedAgentService.PostSourceTagResultTask - Class in com.wavefront.agent
 
QueuedAgentService.PostSourceTagResultTask.ActionType - Enum in com.wavefront.agent
 
QueuedAgentService.PostSourceTagResultTask.MessageType - Enum in com.wavefront.agent
 
QueuedPushTooLargeException - Exception in com.wavefront.agent
 
QueuedPushTooLargeException(String) - Constructor for exception com.wavefront.agent.QueuedPushTooLargeException
 
QueuingChannelHandler<T> - Class in com.wavefront.agent.histogram
Inbound handler streaming a netty channel out to a square tape.
QueuingChannelHandler(ObjectQueue<List<T>>, int, AtomicBoolean) - Constructor for class com.wavefront.agent.histogram.QueuingChannelHandler
 

R

RawLogsIngester - Class in com.wavefront.agent.logsharvesting
 
RawLogsIngester(LogsIngester, int, Supplier<Long>) - Constructor for class com.wavefront.agent.logsharvesting.RawLogsIngester
 
rawLogsMaxReceivedLength - Variable in class com.wavefront.agent.AbstractAgent
 
rawLogsPort - Variable in class com.wavefront.agent.AbstractAgent
 
read(Bytes, long, AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
read(Bytes, Utils.HistogramKey) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
readMarshallable(WireIn) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
readMarshallable(WireIn) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
ReadProcessor - Class in com.wavefront.agent.logsharvesting
 
ReadProcessor() - Constructor for class com.wavefront.agent.logsharvesting.ReadProcessor
 
ReadProcessorContext - Class in com.wavefront.agent.logsharvesting
 
ReadProcessorContext(Double) - Constructor for class com.wavefront.agent.logsharvesting.ReadProcessorContext
 
readResolve() - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
readResolve() - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
recordAllData() - Method in class com.tdunning.math.stats.AgentDigest
Turns on internal data recording.
RecyclableRateLimiter - Class in com.google.common.util.concurrent
An alternative RateLimiter implementation that allows to "return" unused permits back to the pool to handle retries gracefully and allow precise control over outgoing rate, plus allows accumulating "credits" for unused permits over a time window other than 1 second.
recyclePermits(int) - Method in class com.google.common.util.concurrent.RecyclableRateLimiter
Return the specified number of permits back to the pool
reject(T) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
Reject the input object as invalid, i.e.
reject(T, String) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
Reject the input object as invalid, i.e.
reject(String, String) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
Reject the input object as invalid, i.e.
RelayPortUnificationHandler - Class in com.wavefront.agent.listeners
Process incoming HTTP requests from other proxies (i.e.
RelayPortUnificationHandler(String, TokenAuthenticator, Map<ReportableEntityType, ReportableEntityDecoder>, ReportableEntityHandlerFactory, ReportableEntityPreprocessor) - Constructor for class com.wavefront.agent.listeners.RelayPortUnificationHandler
 
remoteHostAnnotator - Variable in class com.wavefront.agent.PushAgent
 
remove() - Method in class com.wavefront.agent.ResubmissionTaskQueue
 
removeDescription(String, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledAgentAPI
 
removeDescription(String, String) - Method in class com.wavefront.agent.QueuedAgentService
 
removeDescription(String, boolean) - Method in class com.wavefront.agent.QueuedAgentService
 
removeTag(String, String, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledAgentAPI
 
removeTag(String, String, String) - Method in class com.wavefront.agent.QueuedAgentService
 
removeTag(String, String, boolean) - Method in class com.wavefront.agent.QueuedAgentService
 
report(T) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
Validate and accept the input object.
report(T, Object, Function<Object, String>) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
Validate and accept the input object.
ReportableConfig - Class in com.wavefront.agent.config
Wrapper class to simplify access to .properties file + track values as metrics as they are retrieved
ReportableConfig(InputStream) - Constructor for class com.wavefront.agent.config.ReportableConfig
 
ReportableConfig(String) - Constructor for class com.wavefront.agent.config.ReportableConfig
 
ReportableConfig() - Constructor for class com.wavefront.agent.config.ReportableConfig
 
ReportableEntityHandler<T> - Interface in com.wavefront.agent.handlers
Handler that processes incoming objects of a single entity type, validates them and hands them over to one of the SenderTask threads.
ReportableEntityHandlerFactory - Interface in com.wavefront.agent.handlers
Factory for ReportableEntityHandler objects.
ReportableEntityHandlerFactoryImpl - Class in com.wavefront.agent.handlers
Caching factory for ReportableEntityHandler objects.
ReportableEntityHandlerFactoryImpl(SenderTaskFactory, int, int) - Constructor for class com.wavefront.agent.handlers.ReportableEntityHandlerFactoryImpl
Create new instance.
ReportableEntityPreprocessor - Class in com.wavefront.agent.preprocessor
A container class for multiple types of rules (point line-specific and parsed entity-specific) Created by Vasily on 9/15/16.
ReportableEntityPreprocessor() - Constructor for class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
 
reportEmptyHistogramStats - Variable in class com.wavefront.agent.config.LogsIngestionConfig
If true (default), simulate Yammer histogram behavior (report all stats as zeroes when histogram is empty).
reportGauge(Number, MetricName) - Method in class com.wavefront.agent.config.ReportableConfig
 
reportInternal(ReportSourceTag) - Method in class com.wavefront.agent.handlers.ReportSourceTagHandlerImpl
 
reportInternal(Span) - Method in class com.wavefront.agent.handlers.SpanHandlerImpl
 
reportPoint(ReportPoint, String) - Method in interface com.wavefront.agent.PointHandler
Send a point for reporting.
reportPoint(ReportPoint, String) - Method in class com.wavefront.agent.PointHandlerImpl
 
ReportPointAddPrefixTransformer - Class in com.wavefront.agent.preprocessor
Add prefix transformer.
ReportPointAddPrefixTransformer(String) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddPrefixTransformer
 
ReportPointAddTagIfNotExistsTransformer - Class in com.wavefront.agent.preprocessor
Creates a new point tag with a specified value.
ReportPointAddTagIfNotExistsTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagIfNotExistsTransformer
Deprecated.
ReportPointAddTagIfNotExistsTransformer(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagIfNotExistsTransformer
 
ReportPointAddTagTransformer - Class in com.wavefront.agent.preprocessor
Creates a new point tag with a specified value, or overwrite an existing one.
ReportPointAddTagTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
Deprecated.
ReportPointAddTagTransformer(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
ReportPointBlacklistRegexFilter - Class in com.wavefront.agent.preprocessor
Blacklist regex filter.
ReportPointBlacklistRegexFilter(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointBlacklistRegexFilter
Deprecated.
ReportPointBlacklistRegexFilter(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointBlacklistRegexFilter
 
ReportPointDropTagTransformer - Class in com.wavefront.agent.preprocessor
Removes a point tag if its value matches an optional regex pattern (always remove if null) Created by Vasily on 9/13/16.
ReportPointDropTagTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointDropTagTransformer
Deprecated.
ReportPointDropTagTransformer(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointDropTagTransformer
 
ReportPointExtractTagIfNotExistsTransformer - Class in com.wavefront.agent.preprocessor
Create a point tag by extracting a portion of a metric name, source name or another point tag.
ReportPointExtractTagIfNotExistsTransformer(String, String, String, String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointExtractTagIfNotExistsTransformer
Deprecated.
ReportPointExtractTagIfNotExistsTransformer(String, String, String, String, String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointExtractTagIfNotExistsTransformer
 
ReportPointExtractTagTransformer - Class in com.wavefront.agent.preprocessor
Create a point tag by extracting a portion of a metric name, source name or another point tag Created by Vasily on 11/15/16.
ReportPointExtractTagTransformer(String, String, String, String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
Deprecated.
ReportPointExtractTagTransformer(String, String, String, String, String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
ReportPointForceLowercaseTransformer - Class in com.wavefront.agent.preprocessor
Force lowercase transformer.
ReportPointForceLowercaseTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointForceLowercaseTransformer
Deprecated.
ReportPointForceLowercaseTransformer(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointForceLowercaseTransformer
 
ReportPointLimitLengthTransformer - Class in com.wavefront.agent.preprocessor
 
ReportPointLimitLengthTransformer(String, int, LengthLimitActionType, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointLimitLengthTransformer
 
ReportPointRenameTagTransformer - Class in com.wavefront.agent.preprocessor
Rename a point tag (optional: if its value matches a regex pattern) Created by Vasily on 9/13/16.
ReportPointRenameTagTransformer(String, String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointRenameTagTransformer
Deprecated.
ReportPointRenameTagTransformer(String, String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointRenameTagTransformer
 
ReportPointReplaceRegexTransformer - Class in com.wavefront.agent.preprocessor
Replace regex transformer.
ReportPointReplaceRegexTransformer(String, String, String, String, Integer, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointReplaceRegexTransformer
Deprecated.
ReportPointReplaceRegexTransformer(String, String, String, String, Integer, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointReplaceRegexTransformer
 
reportPoints(List<ReportPoint>) - Method in interface com.wavefront.agent.PointHandler
Send a collection of points for reporting.
reportPoints(List<ReportPoint>) - Method in class com.wavefront.agent.PointHandlerImpl
 
ReportPointTimestampInRangeFilter - Class in com.wavefront.agent.preprocessor
Filter condition for valid timestamp - should be no more than 1 day in the future and no more than X hours (usually 8760, or 1 year) in the past Created by Vasily on 9/16/16.
ReportPointTimestampInRangeFilter(int, int) - Constructor for class com.wavefront.agent.preprocessor.ReportPointTimestampInRangeFilter
 
ReportPointWhitelistRegexFilter - Class in com.wavefront.agent.preprocessor
Whitelist regex filter.
ReportPointWhitelistRegexFilter(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointWhitelistRegexFilter
Deprecated.
ReportPointWhitelistRegexFilter(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointWhitelistRegexFilter
 
reportSettingAsGauge(Number, String) - Method in class com.wavefront.agent.config.ReportableConfig
 
ReportSourceTagHandlerImpl - Class in com.wavefront.agent.handlers
This class will validate parsed source tags and distribute them among SenderTask threads.
ReportSourceTagHandlerImpl(String, int, Collection<SenderTask>) - Constructor for class com.wavefront.agent.handlers.ReportSourceTagHandlerImpl
 
requestsDiscarded - Variable in class com.wavefront.agent.listeners.PortUnificationHandler
 
ResubmissionTask<T extends ResubmissionTask<T>> - Class in com.wavefront.agent
A task for resubmission.
ResubmissionTask() - Constructor for class com.wavefront.agent.ResubmissionTask
 
ResubmissionTaskDeserializer - Class in com.wavefront.agent
Deserializer of ResubmissionTasks from JSON.
ResubmissionTaskDeserializer() - Constructor for class com.wavefront.agent.ResubmissionTaskDeserializer
 
ResubmissionTaskQueue - Class in com.wavefront.agent
Thread-safe TaskQueue for holding ResubmissionTask objects
ResubmissionTaskQueue(ObjectQueue<ResubmissionTask>, TaskInjector<ResubmissionTask>) - Constructor for class com.wavefront.agent.ResubmissionTaskQueue
 
retryBackoffBaseSeconds - Variable in class com.wavefront.agent.AbstractAgent
 
retryBackoffBaseSecondsInitialValue - Variable in class com.wavefront.agent.AbstractAgent
 
retryThreads - Variable in class com.wavefront.agent.AbstractAgent
 
ruleEnd(long) - Method in class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
Measure rule execution time and add it to ruleCpuTimeNanosCounter (if available)
ruleMetrics - Variable in class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
ruleMetrics - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
ruleMetrics - Variable in class com.wavefront.agent.preprocessor.SpanAddAnnotationTransformer
 
ruleMetrics - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
ruleStart() - Method in class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
Mark rule start time, increment ruleCheckedCounter (if available) by 1
run() - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache.AccumulationCacheMonitor
 
run() - Method in class com.wavefront.agent.histogram.accumulator.AccumulationTask
 
run() - Method in class com.wavefront.agent.histogram.DroppingSender
 
run() - Method in class com.wavefront.agent.histogram.HistogramLineIngester
 
run() - Method in class com.wavefront.agent.histogram.PointHandlerDispatcher
 
run() - Method in class com.wavefront.agent.histogram.TapeDispatcher
 
run() - Method in class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
 
run() - Method in class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
 
run() - Method in class com.wavefront.agent.logsharvesting.MetricsReporter
 
run() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
Runner - Class in org.logstash.beats
 
Runner() - Constructor for class org.logstash.beats.Runner
 

S

sendDataTasks - Variable in class com.wavefront.agent.PointHandlerImpl
 
sendDistribution(String, List<Pair<Double, Integer>>, Set<HistogramGranularity>, Long, String, Map<String, String>) - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
SenderTask<T> - Interface in com.wavefront.agent.handlers
Batch and ship valid items to Wavefront servers
SenderTaskFactory - Interface in com.wavefront.agent.handlers
Factory for SenderTask objects.
senderTaskFactory - Variable in class com.wavefront.agent.PushAgent
 
SenderTaskFactoryImpl - Class in com.wavefront.agent.handlers
Factory for SenderTask objects.
SenderTaskFactoryImpl(ForceQueueEnabledAgentAPI, UUID, RecyclableRateLimiter, AtomicInteger, AtomicInteger, AtomicInteger) - Constructor for class com.wavefront.agent.handlers.SenderTaskFactoryImpl
Create new instance.
sendMetric(String, double, Long, String, Map<String, String>) - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
sendSpan(String, long, long, String, UUID, UUID, List<UUID>, List<UUID>, List<Pair<String, String>>, List<SpanLog>) - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
serialize(Class, Type, JsonSerializationContext) - Method in class com.wavefront.agent.histogram.MapSettings.ClassNameSerializer
 
serialize(Object, Type, JsonSerializationContext) - Method in class com.wavefront.agent.ResubmissionTaskDeserializer
 
server - Variable in class com.wavefront.agent.AbstractAgent
 
Server - Class in org.logstash.beats
 
Server(int) - Constructor for class org.logstash.beats.Server
 
Server(int, int) - Constructor for class org.logstash.beats.Server
 
service - Variable in class com.wavefront.agent.ResubmissionTask
To be injected.
setAuthResponseMaxTtl(int) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
setAuthResponseRefreshInterval(int) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
setBatch(Batch) - Method in class org.logstash.beats.Message
 
setBatchSize(int) - Method in class org.logstash.beats.Batch
 
setCertificateAuthorities(String[]) - Method in class org.logstash.netty.SslSimpleBuilder
 
setCipherSuites(String[]) - Method in class org.logstash.netty.SslSimpleBuilder
 
setDescription(String, String, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledAgentAPI
 
setDescription(String, String, String) - Method in class com.wavefront.agent.QueuedAgentService
 
setDescription(String, String, boolean) - Method in class com.wavefront.agent.QueuedAgentService
 
setHandshakeTimeoutMilliseconds(int) - Method in class org.logstash.netty.SslSimpleBuilder
 
setHostnameVerifier(HostnameVerifier) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
setHttpClient(HttpClient) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
setMessageListener(IMessageListener) - Method in class org.logstash.beats.Server
 
setPatternsFile(String) - Method in class com.wavefront.agent.config.MetricMatcher
 
setProtocol(byte) - Method in class org.logstash.beats.Batch
 
setProtocols(String[]) - Method in class org.logstash.netty.SslSimpleBuilder
 
setRetryBackoffBaseSeconds(AtomicDouble) - Static method in class com.wavefront.agent.QueuedAgentService
 
setSplitBatchSize(AtomicInteger) - Static method in class com.wavefront.agent.QueuedAgentService
 
setSslContext(SSLContext) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
setStaticToken(String) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
setTags(String, List<String>, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledAgentAPI
 
setTags(String, String, List<String>) - Method in class com.wavefront.agent.QueuedAgentService
 
setTags(String, List<String>, boolean) - Method in class com.wavefront.agent.QueuedAgentService
 
setTokenIntrospectionAuthorizationHeader(String) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
setTokenIntrospectionServiceUrl(String) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
setTokenValidationMethod(TokenValidationMethod) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
setValue(T) - Method in class com.wavefront.agent.logsharvesting.ChangeableGauge
 
setVerifyMode(SslSimpleBuilder.SslClientVerifyMode) - Method in class org.logstash.netty.SslSimpleBuilder
 
SharedMetricsRegistry - Class in com.wavefront.agent
 
SharedMetricsRegistry() - Constructor for class com.wavefront.agent.SharedMetricsRegistry
 
shutdown() - Method in class com.wavefront.agent.AbstractAgent
 
shutdown() - Method in interface com.wavefront.agent.handlers.ReportableEntityHandlerFactory
Perform finalizing tasks on handlers.
shutdown() - Method in class com.wavefront.agent.handlers.ReportableEntityHandlerFactoryImpl
 
shutdown() - Method in interface com.wavefront.agent.handlers.SenderTask
Shut down the scheduler for this task (prevent future scheduled runs).
shutdown() - Method in interface com.wavefront.agent.handlers.SenderTaskFactory
Shut down all tasks.
shutdown() - Method in class com.wavefront.agent.handlers.SenderTaskFactoryImpl
 
shutdown() - Method in class com.wavefront.agent.PostPushDataTimedTask
Shut down the scheduler for this task (prevent future scheduled runs)
shutdown() - Method in class com.wavefront.agent.QueuedAgentService
 
shutdownTasks - Variable in class com.wavefront.agent.AbstractAgent
 
shuttingDown - Variable in class com.wavefront.agent.AbstractAgent
 
size(AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
size() - Method in class com.tdunning.math.stats.AgentDigest
 
size() - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Returns the number of items in the storage behind the cache
size() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
size() - Method in class com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask
 
size() - Method in class com.wavefront.agent.ResubmissionTask
 
size() - Method in class org.logstash.beats.Batch
 
smallByteSize() - Method in class com.tdunning.math.stats.AgentDigest
 
soLingerTime - Variable in class com.wavefront.agent.AbstractAgent
 
source - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
SpanAddAnnotationIfNotExistsTransformer - Class in com.wavefront.agent.preprocessor
Creates a new annotation with a specified key/value pair.
SpanAddAnnotationIfNotExistsTransformer(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanAddAnnotationIfNotExistsTransformer
 
SpanAddAnnotationTransformer - Class in com.wavefront.agent.preprocessor
Creates a new annotation with a specified key/value pair.
SpanAddAnnotationTransformer(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanAddAnnotationTransformer
 
SpanBlacklistRegexFilter - Class in com.wavefront.agent.preprocessor
Blacklist regex filter.
SpanBlacklistRegexFilter(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanBlacklistRegexFilter
 
SpanDerivedMetricsUtils - Class in com.wavefront.agent.listeners.tracing
Util methods to generate data (metrics/histograms/heartbeats) from tracing spans
SpanDerivedMetricsUtils() - Constructor for class com.wavefront.agent.listeners.tracing.SpanDerivedMetricsUtils
 
SpanDropAnnotationTransformer - Class in com.wavefront.agent.preprocessor
Removes a span annotation with a specific key if its value matches an optional regex pattern (always remove if null)
SpanDropAnnotationTransformer(String, String, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanDropAnnotationTransformer
 
SpanExtractAnnotationIfNotExistsTransformer - Class in com.wavefront.agent.preprocessor
Create a new span annotation by extracting a portion of a span name, source name or another annotation
SpanExtractAnnotationIfNotExistsTransformer(String, String, String, String, String, String, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanExtractAnnotationIfNotExistsTransformer
 
SpanExtractAnnotationTransformer - Class in com.wavefront.agent.preprocessor
Create a point tag by extracting a portion of a metric name, source name or another point tag
SpanExtractAnnotationTransformer(String, String, String, String, String, String, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
SpanForceLowercaseTransformer - Class in com.wavefront.agent.preprocessor
Force lowercase transformer.
SpanForceLowercaseTransformer(String, String, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanForceLowercaseTransformer
 
SpanHandlerImpl - Class in com.wavefront.agent.handlers
Handler that processes incoming Span objects, validates them and hands them over to one of the SenderTask threads.
SpanLimitLengthTransformer - Class in com.wavefront.agent.preprocessor
 
SpanLimitLengthTransformer(String, int, LengthLimitActionType, String, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanLimitLengthTransformer
 
SpanReplaceRegexTransformer - Class in com.wavefront.agent.preprocessor
Replace regex transformer.
SpanReplaceRegexTransformer(String, String, String, String, Integer, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanReplaceRegexTransformer
 
SpanSamplerUtils - Class in com.wavefront.agent.sampler
Helper class for creating span samplers.
SpanSamplerUtils() - Constructor for class com.wavefront.agent.sampler.SpanSamplerUtils
 
SpanWhitelistRegexFilter - Class in com.wavefront.agent.preprocessor
Whitelist regex filter.
SpanWhitelistRegexFilter(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanWhitelistRegexFilter
 
splitPushWhenRateLimited - Variable in class com.wavefront.agent.AbstractAgent
 
splitTask() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
splitTask() - Method in class com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask
 
splitTask() - Method in class com.wavefront.agent.ResubmissionTask
 
SSLConnectionSocketFactoryImpl - Class in com.wavefront.agent
Delegated SSLConnectionSocketFactory that sets SoTimeout explicitly (for Apache HttpClient).
SSLConnectionSocketFactoryImpl(SSLConnectionSocketFactory, int) - Constructor for class com.wavefront.agent.SSLConnectionSocketFactoryImpl
 
sslContext - Variable in class com.wavefront.agent.JavaNetConnectionEngine
 
SslSimpleBuilder - Class in org.logstash.netty
Created by ph on 2016-05-27.
SslSimpleBuilder(String, String, String) - Constructor for class org.logstash.netty.SslSimpleBuilder
 
SslSimpleBuilder.SslClientVerifyMode - Enum in org.logstash.netty
 
SSLSocketFactoryImpl - Class in com.wavefront.agent
Delegated SSLSocketFactory that sets SoTimeout explicitly.
SSLSocketFactoryImpl(SSLSocketFactory, int) - Constructor for class com.wavefront.agent.SSLSocketFactoryImpl
 
start(String[]) - Method in class com.wavefront.agent.AbstractAgent
Entry-point for the application.
start() - Method in class com.wavefront.agent.logsharvesting.LogsIngester
 
start() - Method in class com.wavefront.agent.PushAgentDaemon
 
startAsManagedThread(Runnable, String) - Method in class com.wavefront.agent.PushAgent
 
startDataDogListener(String, ReportableEntityHandlerFactory, HttpClient) - Method in class com.wavefront.agent.PushAgent
 
startGraphiteListener(String, ReportableEntityHandlerFactory, CachingGraphiteHostAnnotator) - Method in class com.wavefront.agent.PushAgent
 
startHistogramListeners(Iterator<String>, Decoder<String>, PointHandler, TapeDeck<List<String>>, Utils.Granularity, int, int, boolean, File, Long, int, int, short) - Method in class com.wavefront.agent.PushAgent
 
startJsonListener(String) - Method in class com.wavefront.agent.PushAgent
 
startListeners() - Method in class com.wavefront.agent.AbstractAgent
 
startListeners() - Method in class com.wavefront.agent.PushAgent
 
startLogsIngestionListeners(int, int, PointHandler) - Method in class com.wavefront.agent.PushAgent
 
startOpenTsdbListener(String, ReportableEntityHandlerFactory) - Method in class com.wavefront.agent.PushAgent
 
startPickleListener(String, PointHandler, GraphiteFormatter) - Method in class com.wavefront.agent.PushAgent
 
startRelayListener(String, ReportableEntityHandlerFactory) - Method in class com.wavefront.agent.PushAgent
 
startTraceJaegerListener(String, ReportableEntityHandlerFactory, WavefrontSender, Sampler) - Method in class com.wavefront.agent.PushAgent
 
startTraceListener(String, ReportableEntityHandlerFactory, Sampler) - Method in class com.wavefront.agent.PushAgent
 
startTraceZipkinListener(String, ReportableEntityHandlerFactory, WavefrontSender, Sampler) - Method in class com.wavefront.agent.PushAgent
 
startWriteHttpJsonListener(String) - Method in class com.wavefront.agent.PushAgent
 
stop() - Method in class com.wavefront.agent.PushAgentDaemon
 
stop() - Method in class org.logstash.beats.Server
 
stopListeners() - Method in class com.wavefront.agent.AbstractAgent
 
stopListeners() - Method in class com.wavefront.agent.PushAgent
 

T

tag - Variable in class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
tag - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
TapeDeck<T> - Class in com.wavefront.agent.histogram.tape
Factory for Square Tape ObjectQueue instances for this agent.
TapeDeck(FileObjectQueue.Converter<T>, boolean) - Constructor for class com.wavefront.agent.histogram.tape.TapeDeck
 
TapeDispatcher - Class in com.wavefront.agent.histogram
Dispatch task for marshalling "ripe" digests for shipment to the agent into a (Tape) ObjectQueue
TapeDispatcher(ConcurrentMap<Utils.HistogramKey, AgentDigest>, ObjectQueue<ReportPoint>) - Constructor for class com.wavefront.agent.histogram.TapeDispatcher
 
TapeReportPointConverter - Class in com.wavefront.agent.histogram.tape
Adapter exposing the Avro's SpecificRecord encoding/decoding to Square tape's FileObjectQueue.Converter interface.
TapeStringListConverter - Class in com.wavefront.agent.histogram.tape
[Square] Tape converter for Lists of strings with LZ4 compression support.
tenuredGenPool - Variable in class com.wavefront.agent.AbstractAgent
 
TimeProvider - Interface in com.wavefront.agent.histogram
 
timeSeries(LogsMessage, Double[]) - Method in class com.wavefront.agent.config.MetricMatcher
Convert the given message to a timeSeries and a telemetry datum.
TimeSeriesUtils - Class in com.wavefront.agent.logsharvesting
 
TimeSeriesUtils() - Constructor for class com.wavefront.agent.logsharvesting.TimeSeriesUtils
 
toHistogram(int) - Method in class com.tdunning.math.stats.AgentDigest
Creates a reporting Histogram from this AgentDigest (marked with the supplied duration).
token - Variable in class com.wavefront.agent.AbstractAgent
 
token - Variable in class com.wavefront.agent.ResubmissionTask
To be injected.
tokenAuthenticator - Variable in class com.wavefront.agent.AbstractAgent
 
TokenAuthenticator - Interface in com.wavefront.agent.auth
Token validator for processing incoming requests.
tokenAuthenticator - Variable in class com.wavefront.agent.listeners.PortUnificationHandler
 
TokenAuthenticatorBuilder - Class in com.wavefront.agent.auth
Builder for TokenAuthenticator instances.
TokenValidationMethod - Enum in com.wavefront.agent.auth
Auth validation methods supported.
TokenValidationMethod.TokenValidationMethodConverter - Class in com.wavefront.agent.auth
 
TokenValidationMethodConverter() - Constructor for class com.wavefront.agent.auth.TokenValidationMethod.TokenValidationMethodConverter
 
toMetricName(TimeSeries) - Static method in class com.wavefront.agent.logsharvesting.TimeSeriesUtils
 
toStream(ReportPoint, OutputStream) - Method in class com.wavefront.agent.histogram.tape.TapeReportPointConverter
 
toStream(List<String>, OutputStream) - Method in class com.wavefront.agent.histogram.tape.TapeStringListConverter
 
toString() - Method in class com.wavefront.agent.config.Configuration
 
toString() - Method in class com.wavefront.agent.histogram.accumulator.AccumulationTask
 
toString() - Method in class com.wavefront.agent.histogram.MapLoader
 
toString() - Method in class com.wavefront.agent.histogram.MapSettings
 
toString() - Method in class com.wavefront.agent.histogram.tape.TapeDeck
 
toString() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
traceAlwaysSampleErrors - Variable in class com.wavefront.agent.AbstractAgent
 
traceDisabled - Variable in class com.wavefront.agent.AbstractAgent
 
traceJaegerListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
traceListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
TracePortUnificationHandler - Class in com.wavefront.agent.listeners.tracing
Process incoming trace-formatted data.
TracePortUnificationHandler(String, TokenAuthenticator, ReportableEntityDecoder<String, Span>, ReportableEntityPreprocessor, ReportableEntityHandlerFactory, Sampler, boolean) - Constructor for class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
TracePortUnificationHandler(String, TokenAuthenticator, ReportableEntityDecoder<String, Span>, ReportableEntityPreprocessor, ReportableEntityHandler<Span>, Sampler, boolean) - Constructor for class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
traceSamplingDuration - Variable in class com.wavefront.agent.AbstractAgent
 
traceSamplingRate - Variable in class com.wavefront.agent.AbstractAgent
 
traceZipkinListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
TRACING_DERIVED_PREFIX - Static variable in class com.wavefront.agent.listeners.tracing.SpanDerivedMetricsUtils
 
transform(T) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Apply all transformation rules sequentially

U

unparsed_params - Variable in class com.wavefront.agent.AbstractAgent
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.wavefront.agent.channel.IdleStateEventHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class org.logstash.beats.BeatsHandler
 
useWavefrontHistograms - Variable in class com.wavefront.agent.config.LogsIngestionConfig
If true, use WavefrontHistograms rather than Histograms.
Utils - Class in com.wavefront.agent.histogram
Helpers around histograms
Utils - Class in com.wavefront.agent
A placeholder class for miscellaneous utility methods.
Utils() - Constructor for class com.wavefront.agent.Utils
 
Utils.Granularity - Enum in com.wavefront.agent.histogram
Standard supported aggregation Granularities.
Utils.HistogramKey - Class in com.wavefront.agent.histogram
Uniquely identifies a time-series - time-interval pair.
Utils.HistogramKeyMarshaller - Class in com.wavefront.agent.histogram
(For now, a rather trivial) encoding of Utils.HistogramKey the form short length and bytes Consider using chronicle-values or making this stateful with a local byte[] / Stringbuffers to be a little more efficient about encodings.

V

value() - Method in class com.wavefront.agent.logsharvesting.ChangeableGauge
 
value - Variable in class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
value - Variable in class com.wavefront.agent.preprocessor.SpanAddAnnotationTransformer
 
valueOf(String) - Static method in enum com.wavefront.agent.auth.TokenValidationMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.wavefront.agent.histogram.Utils.Granularity
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.wavefront.agent.preprocessor.LengthLimitActionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.ActionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.MessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.logstash.netty.SslSimpleBuilder.SslClientVerifyMode
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.wavefront.agent.auth.TokenValidationMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.wavefront.agent.histogram.Utils.Granularity
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.wavefront.agent.preprocessor.LengthLimitActionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.ActionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.MessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.logstash.netty.SslSimpleBuilder.SslClientVerifyMode
Returns an array containing the constants of this enum type, in the order they are declared.
verifyAndInit() - Method in class com.wavefront.agent.config.Configuration
 
verifyAndInit() - Method in class com.wavefront.agent.config.LogsIngestionConfig
 
verifyAndInit() - Method in class com.wavefront.agent.config.MetricMatcher
 
VERSION_1 - Static variable in class org.logstash.beats.Protocol
 
VERSION_2 - Static variable in class org.logstash.beats.Protocol
 

W

WavefrontPortUnificationHandler - Class in com.wavefront.agent.listeners
Process incoming Wavefront-formatted data.
WavefrontPortUnificationHandler(String, TokenAuthenticator, Map<ReportableEntityType, ReportableEntityDecoder>, ReportableEntityHandlerFactory, CachingGraphiteHostAnnotator, ReportableEntityPreprocessor) - Constructor for class com.wavefront.agent.listeners.WavefrontPortUnificationHandler
Create new instance with lazy initialization for handlers.
whitelistRegex - Variable in class com.wavefront.agent.AbstractAgent
 
withChannelIdleTimeout(int) - Method in class com.wavefront.agent.histogram.HistogramLineIngester
 
withChannelIdleTimeout(int) - Method in class com.wavefront.agent.logsharvesting.RawLogsIngester
 
withMaxLength(int) - Method in class com.wavefront.agent.histogram.HistogramLineIngester
 
withMaxLength(int) - Method in class com.wavefront.agent.logsharvesting.RawLogsIngester
 
write(Bytes, long, AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
write(Utils.HistogramKey, AgentDigest) - Method in class com.wavefront.agent.histogram.accumulator.Layering
 
write(Bytes, Utils.HistogramKey) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
writeExceptionText(Throwable, StringBuilder) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
Create a error message from an exception.
writeHttpJsonListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
WriteHttpJsonMetricsEndpoint - Class in com.wavefront.agent.listeners
Agent-side JSON metrics endpoint for parsing JSON from write_http collectd plugin.
WriteHttpJsonMetricsEndpoint(String, String, String, String, int, PostPushDataTimedTask[], ReportableEntityPreprocessor) - Constructor for class com.wavefront.agent.listeners.WriteHttpJsonMetricsEndpoint
 
writeHttpResponse(ChannelHandlerContext, HttpResponseStatus, Object) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
 
writeHttpResponse(ChannelHandlerContext, HttpResponseStatus, Object, FullHttpRequest) - Method in class com.wavefront.agent.listeners.PortUnificationHandler
 
writeMarshallable(WireOut) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
writeMarshallable(WireOut) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
writeTo(JsonNode, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.wavefront.agent.JsonNodeWriter
 

Z

ZipkinPortUnificationHandler - Class in com.wavefront.agent.listeners.tracing
Handler that processes Zipkin trace data over HTTP and converts them to Wavefront format.
ZipkinPortUnificationHandler(String, ReportableEntityHandlerFactory, WavefrontSender, AtomicBoolean, ReportableEntityPreprocessor, Sampler, boolean) - Constructor for class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
 
ZipkinPortUnificationHandler(String, ReportableEntityHandler<Span>, WavefrontSender, AtomicBoolean, ReportableEntityPreprocessor, Sampler, boolean) - Constructor for class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
 
A B C D E F G H I J K L M O P Q R S T U V W Z 
Skip navigation links

Copyright © 2019. All rights reserved.