A B C D E F G H I J K L M N O P Q R S T U V W Z 
All Classes All Packages

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
Deprecated.
AbstractHttpOnlyHandler - Class in com.wavefront.agent.listeners
Base class for HTTP-only listeners.
AbstractHttpOnlyHandler(TokenAuthenticator, HealthCheckManager, String) - Constructor for class com.wavefront.agent.listeners.AbstractHttpOnlyHandler
Create new instance.
AbstractLineDelimitedHandler - Class in com.wavefront.agent.listeners
Base class for all line-based protocols.
AbstractLineDelimitedHandler(TokenAuthenticator, HealthCheckManager, String) - Constructor for class com.wavefront.agent.listeners.AbstractLineDelimitedHandler
 
AbstractPortUnificationHandler - Class in com.wavefront.agent.listeners
This is a base class for the majority of proxy's listeners.
AbstractPortUnificationHandler(TokenAuthenticator, HealthCheckManager, String) - Constructor for class com.wavefront.agent.listeners.AbstractPortUnificationHandler
Create new instance.
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<HistogramKey, AgentDigest>, AgentDigestFactory, long, String, 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 the backingStore.
AccumulationCache(ConcurrentMap<HistogramKey, AgentDigest>, AgentDigestFactory, long, String, 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 the backingStore.
Accumulator - Interface in com.wavefront.agent.histogram.accumulator
Caching wrapper around the backing store.
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(List<? extends TDigest>) - 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(T) - Method in class com.wavefront.agent.queueing.FileBasedTaskQueue
 
add(T) - Method in class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
add(T) - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
add(T) - Method in class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 
add(T) - Method in interface com.wavefront.agent.queueing.TaskQueue
Add a task to the end of the queue
add(T) - Method in class com.wavefront.agent.queueing.TaskQueueStub
 
addFilter(int, AnnotatedPredicate<T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a filter rule and place it at a specific index
addFilter(AnnotatedPredicate<T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a filter rule
addHyphensToUuid(String) - Static method in class com.wavefront.common.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.
addTransformer(int, Function<T, T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a transformation rule and place it at a specific index
addTransformer(Function<T, T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a transformation rule
AdminPortUnificationHandler - Class in com.wavefront.agent.listeners
Admin API for managing proxy-wide healthchecks.
AdminPortUnificationHandler(TokenAuthenticator, HealthCheckManager, String, String) - Constructor for class com.wavefront.agent.listeners.AdminPortUnificationHandler
Create new instance.
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
AgentDigestFactory - Class in com.wavefront.agent.histogram.accumulator
A simple factory for creating AgentDigest objects with a specific compression level and expiration TTL.
AgentDigestFactory(Supplier<Short>, long, TimeProvider) - Constructor for class com.wavefront.agent.histogram.accumulator.AgentDigestFactory
 
agentId - Variable in class com.wavefront.agent.AbstractAgent
 
aggregationIntervalSeconds - Variable in class com.wavefront.agent.config.LogsIngestionConfig
How often metrics are aggregated and sent to wavefront.
ALWAYS - com.wavefront.agent.data.TaskQueueLevel
 
AnnotatedPredicate<T> - Interface in com.wavefront.agent.preprocessor
Base for all "filter"-type rules.
ANY_ERROR - com.wavefront.agent.data.TaskQueueLevel
 
apiContainer - Variable in class com.wavefront.agent.AbstractAgent
 
APIContainer - Class in com.wavefront.agent.api
Container for all Wavefront back-end API objects (proxy, source tag, event)
APIContainer(ProxyConfig, boolean) - Constructor for class com.wavefront.agent.api.APIContainer
 
APIContainer(ProxyV2API, SourceTagAPI, EventAPI) - Constructor for class com.wavefront.agent.api.APIContainer
This is for testing only, as it loses ability to invoke updateServerEndpointURL().
appendTag(String, String) - Method in class com.wavefront.agent.api.NoopSourceTagAPI
 
apply(ChannelHandlerContext, String) - Method in class com.wavefront.agent.channel.SharedGraphiteHostAnnotator
 
apply(String) - Method in class com.wavefront.agent.formatter.GraphiteFormatter
 
apply(String) - Method in class com.wavefront.agent.preprocessor.LineBasedReplaceRegexTransformer
 
apply(InetAddress) - Method in class com.wavefront.agent.channel.CachingHostnameLookupResolver
 
apply(Histogram) - Method in class com.wavefront.agent.histogram.HistogramRecompressor
 
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.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(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.SpanAllowAnnotationTransformer
 
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.SpanRenameAnnotationTransformer
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanReplaceRegexTransformer
 
apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanSanitizeTransformer
 
aroundWriteTo(WriterInterceptorContext) - Method in class com.wavefront.agent.channel.DisableGZIPEncodingInterceptor
 
aroundWriteTo(WriterInterceptorContext) - Method in class com.wavefront.agent.channel.GZIPEncodingInterceptorWithVariableCompression
 
asBytes(ByteBuffer) - Method in class com.tdunning.math.stats.AgentDigest
 
asSmallBytes(ByteBuffer) - Method in class com.tdunning.math.stats.AgentDigest
 
AUTH - com.wavefront.agent.data.QueueingReason
 
authorize(String) - Method in interface com.wavefront.agent.auth.TokenAuthenticator
Validate a token.
authorized(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 
authRequired() - Method in interface com.wavefront.agent.auth.TokenAuthenticator
Check whether authentication is required (i.e.
autodetect(String) - Static method in enum com.wavefront.agent.formatter.DataFormat
 

B

Batch - Interface in org.logstash.beats
Interface representing a Batch of Message.
BatchIdentity - Class in org.logstash.beats
Identity of a filebeat batch, based on the first message.
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
 
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.
BUFFER_SIZE - com.wavefront.agent.data.QueueingReason
 
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

CachingHostnameLookupResolver - Class in com.wavefront.agent.channel
Convert InetAddress to String, either by performing reverse DNS lookups (cached, as the name implies), or by converting IP addresses into their string representation.
CachingHostnameLookupResolver(boolean, MetricName) - Constructor for class com.wavefront.agent.channel.CachingHostnameLookupResolver
Create a new instance with default cache settings: - max 5000 elements in the cache - 5 minutes refresh TTL - 1 hour expiry TTL
CachingHostnameLookupResolver(boolean, MetricName, int, Duration, Duration) - Constructor for class com.wavefront.agent.channel.CachingHostnameLookupResolver
Create a new instance with specific cache settings:
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
 
CHANNEL_SEND_KEEP_ALIVE - Static variable in class org.logstash.beats.ConnectionHandler
 
channelActive(ChannelHandlerContext) - Method in class com.wavefront.agent.channel.ConnectionTrackingHandler
 
channelActive(ChannelHandlerContext) - Method in class org.logstash.beats.BeatsHandler
 
channelActive(ChannelHandlerContext) - Method in class org.logstash.beats.ConnectionHandler
 
ChannelByteArrayHandler - Class in com.wavefront.agent.listeners
Channel handler for byte array data.
ChannelByteArrayHandler(ReportableEntityDecoder<byte[], ReportPoint>, ReportableEntityHandler<ReportPoint, String>, Supplier<ReportableEntityPreprocessor>, Logger) - Constructor for class com.wavefront.agent.listeners.ChannelByteArrayHandler
Constructor.
channelInactive(ChannelHandlerContext) - Method in class com.wavefront.agent.channel.ConnectionTrackingHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.logstash.beats.BeatsHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.logstash.beats.ConnectionHandler
Sets the flag that the keep alive should be sent.
channelRead0(ChannelHandlerContext, byte[]) - Method in class com.wavefront.agent.listeners.ChannelByteArrayHandler
 
channelRead0(ChannelHandlerContext, Object) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 
channelRead0(ChannelHandlerContext, Batch) - Method in class org.logstash.beats.BeatsHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 
ChannelUtils - Class in com.wavefront.agent.channel
A collection of helper methods around Netty channels.
ChannelUtils() - Constructor for class com.wavefront.agent.channel.ChannelUtils
 
childChannelOptions - Variable in class com.wavefront.agent.PushAgent
 
cleanUp() - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
clear() - Method in class com.wavefront.agent.queueing.FileBasedTaskQueue
 
clear() - Method in class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
clear() - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
clear() - Method in class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 
clear() - Method in interface com.wavefront.agent.queueing.TaskQueue
Empty and re-initialize the queue.
clear() - Method in class com.wavefront.agent.queueing.TaskQueueStub
 
close() - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
close() - Method in class com.wavefront.agent.listeners.tracing.JaegerGrpcCollectorHandler
 
close() - Method in class com.wavefront.agent.listeners.tracing.JaegerPortUnificationHandler
 
close() - Method in class com.wavefront.agent.listeners.tracing.JaegerTChannelCollectorHandler
 
close() - Method in class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
 
close() - Method in class com.wavefront.agent.queueing.FileBasedTaskQueue
 
close() - Method in class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
close() - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
close() - Method in class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 
close() - Method in interface com.wavefront.agent.queueing.TaskQueue
Close the queue.
close() - Method in class com.wavefront.agent.queueing.TaskQueueStub
 
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.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.data - package com.wavefront.agent.data
 
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.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.queueing - package com.wavefront.agent.queueing
 
com.wavefront.agent.sampler - package com.wavefront.agent.sampler
 
com.wavefront.common - package com.wavefront.common
 
commit() - Method in class com.wavefront.agent.channel.GZIPEncodingInterceptorWithVariableCompression.CommittedGZIPOutputStream
 
CommittedGZIPOutputStream(OutputStream, int) - Constructor for class com.wavefront.agent.channel.GZIPEncodingInterceptorWithVariableCompression.CommittedGZIPOutputStream
 
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
 
compress() - Method in class com.tdunning.math.stats.AgentDigest
 
compression() - Method in class com.tdunning.math.stats.AgentDigest
 
compute(HistogramKey, BiFunction<? super 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).
compute(HistogramKey, BiFunction<? super HistogramKey, ? super AgentDigest, ? extends AgentDigest>) - Method in interface com.wavefront.agent.histogram.accumulator.Accumulator
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.PushAgent
 
ConnectionHandler - Class in org.logstash.beats
Manages the connection state to the beats client.
ConnectionHandler() - Constructor for class org.logstash.beats.ConnectionHandler
 
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.ProxyConfig.TaskQueueLevelConverter
 
convert(String) - Method in class com.wavefront.agent.ProxyConfig.TokenValidationMethodConverter
 
convertToUuidString(String) - Static method in class com.wavefront.common.Utils
Method converts a string Id to UUID.
counters - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Counters to ingest from incoming log data.
create() - Static method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
create(Map<String, Object>, Predicate<Span>, PreprocessorRuleMetrics) - Static method in class com.wavefront.agent.preprocessor.SpanAllowAnnotationTransformer
Create an instance based on loaded yaml fragment.
createLayeredSocket(Socket, String, int, HttpContext) - Method in class com.wavefront.agent.SSLConnectionSocketFactoryImpl
 
createSenderTasks(HandlerKey) - Method in interface com.wavefront.agent.handlers.SenderTaskFactory
Create a collection of objects for a specified handler key.
createSenderTasks(HandlerKey) - Method in class com.wavefront.agent.handlers.SenderTaskFactoryImpl
 
createSocket(HttpContext) - Method in class com.wavefront.agent.SSLConnectionSocketFactoryImpl
 
csvToList(String) - Static method in class com.wavefront.common.Utils
Creates an iterator over values a comma-delimited string.
CustomTracingPortUnificationHandler - Class in com.wavefront.agent.listeners.tracing
Handler that process trace data sent from tier 1 SDK.
CustomTracingPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityDecoder<String, Span>, ReportableEntityDecoder<JsonNode, SpanLogs>, Supplier<ReportableEntityPreprocessor>, ReportableEntityHandler<Span, String>, ReportableEntityHandler<SpanLogs, String>, SpanSampler, Supplier<Boolean>, Supplier<Boolean>, WavefrontSender, WavefrontInternalReporter, Set<String>, String, String) - Constructor for class com.wavefront.agent.listeners.tracing.CustomTracingPortUnificationHandler
 
CustomTracingPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityDecoder<String, Span>, ReportableEntityDecoder<JsonNode, SpanLogs>, Supplier<ReportableEntityPreprocessor>, ReportableEntityHandlerFactory, SpanSampler, Supplier<Boolean>, Supplier<Boolean>, WavefrontSender, WavefrontInternalReporter, Set<String>, String, String) - Constructor for class com.wavefront.agent.listeners.tracing.CustomTracingPortUnificationHandler
 

D

DataDogPortUnificationHandler - Class in com.wavefront.agent.listeners
Accepts incoming HTTP requests in DataDog JSON format.
DataDogPortUnificationHandler(String, HealthCheckManager, ReportableEntityHandler<ReportPoint, String>, int, boolean, boolean, boolean, HttpClient, String, Supplier<ReportableEntityPreprocessor>) - Constructor for class com.wavefront.agent.listeners.DataDogPortUnificationHandler
 
DataDogPortUnificationHandler(String, HealthCheckManager, ReportableEntityHandlerFactory, int, boolean, boolean, boolean, HttpClient, String, Supplier<ReportableEntityPreprocessor>) - Constructor for class com.wavefront.agent.listeners.DataDogPortUnificationHandler
 
DataFormat - Enum in com.wavefront.agent.formatter
Best-effort data format auto-detection.
DataSubmissionException - Exception in com.wavefront.agent.data
Exception to bypass standard handling for response status codes.
DataSubmissionException(String) - Constructor for exception com.wavefront.agent.data.DataSubmissionException
 
DataSubmissionTask<T extends DataSubmissionTask<T>> - Interface in com.wavefront.agent.data
A serializable data submission task.
DAY - com.wavefront.agent.histogram.Granularity
 
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
 
decodeLast(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.wavefront.agent.channel.IncompleteLineDetectingLineBasedFrameDecoder
 
decoderSupplier - Variable in class com.wavefront.agent.PushAgent
 
DEFAULT - com.wavefront.agent.formatter.DataFormat
 
DEFAULT_BATCH_SIZE - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_BATCH_SIZE_EVENTS - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_BATCH_SIZE_HISTOGRAMS - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_BATCH_SIZE_SOURCE_TAGS - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_BATCH_SIZE_SPAN_LOGS - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_BATCH_SIZE_SPANS - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_CIPHERS - Static variable in class org.logstash.netty.SslSimpleBuilder
 
DEFAULT_FLUSH_INTERVAL - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_FLUSH_THREADS_EVENTS - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_FLUSH_THREADS_SOURCE_TAGS - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_MAX_BURST_SECONDS - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_MIN_SPLIT_BATCH_SIZE - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_RETRY_BACKOFF_BASE_SECONDS - Static variable in interface com.wavefront.agent.data.EntityProperties
 
DEFAULT_SPLIT_PUSH_WHEN_RATE_LIMITED - Static variable in interface com.wavefront.agent.data.EntityProperties
 
delegate - Variable in class com.wavefront.agent.handlers.DelegatingReportableEntityHandlerFactoryImpl
 
delegate - Variable in class com.wavefront.common.DelegatingLogger
 
DelegatingLogger - Class in com.wavefront.common
Base class for delegating loggers.
DelegatingLogger(Logger) - Constructor for class com.wavefront.common.DelegatingLogger
 
DelegatingReportableEntityHandlerFactoryImpl - Class in com.wavefront.agent.handlers
Wrapper for ReportableEntityHandlerFactory to allow partial overrides for the getHandler method.
DelegatingReportableEntityHandlerFactoryImpl(ReportableEntityHandlerFactory) - Constructor for class com.wavefront.agent.handlers.DelegatingReportableEntityHandlerFactoryImpl
 
DELIVERED - com.wavefront.agent.data.TaskResult
 
DeltaCounterAccumulationHandlerImpl - Class in com.wavefront.agent.handlers
Handler that processes incoming DeltaCounter objects, aggregates them and hands it over to one of the SenderTask threads according to deltaCountersAggregationIntervalSeconds or before cache expires.
DeltaCounterAccumulationHandlerImpl(HandlerKey, int, Collection<SenderTask<String>>, ValidationConfiguration, long, Consumer<Long>, Logger, Logger) - Constructor for class com.wavefront.agent.handlers.DeltaCounterAccumulationHandlerImpl
 
deltaCounterHandlerFactory - Variable in class com.wavefront.agent.PushAgent
 
destroy() - Method in class com.wavefront.agent.WavefrontProxyService
 
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
 
discardedSpanLogs - Variable in class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
discardedSpans - Variable in class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
doExecute() - Method in class com.wavefront.agent.data.EventDataSubmissionTask
 
drainBuffersToQueue(QueueingReason) - Method in interface com.wavefront.agent.handlers.SenderTask
Force memory buffer flush.
drainBuffersToQueue(QueueingReason) - Method in interface com.wavefront.agent.handlers.SenderTaskFactory
Drain memory buffers to queue for all tasks.
drainBuffersToQueue(QueueingReason) - Method in class com.wavefront.agent.handlers.SenderTaskFactoryImpl
 
DROP - com.wavefront.agent.preprocessor.LengthLimitActionType
 
DUMMY_AUTHENTICATOR - Static variable in interface com.wavefront.agent.auth.TokenAuthenticator
Shared dummy authenticator.
DURABILITY - com.wavefront.agent.data.QueueingReason
 

E

enableHealthcheck(int) - Method in interface com.wavefront.agent.channel.HealthCheckManager
 
enableHealthcheck(int) - Method in class com.wavefront.agent.channel.HealthCheckManagerImpl
 
enableHealthcheck(int) - Method in class com.wavefront.agent.channel.NoopHealthCheckManager
 
enableSSL(SslSimpleBuilder) - Method in class org.logstash.beats.Server
 
encode(ChannelHandlerContext, Ack, ByteBuf) - Method in class org.logstash.beats.AckEncoder
 
encodeMessageForDelivery(T) - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
EndableGZIPOutputStream(OutputStream, int) - Constructor for class com.wavefront.agent.channel.GZIPEncodingInterceptorWithVariableCompression.EndableGZIPOutputStream
 
enqueue(QueueingReason) - Method in interface com.wavefront.agent.data.DataSubmissionTask
Persist task in the queue
ensure(boolean, String) - Method in class com.wavefront.agent.config.Configuration
 
EntityProperties - Interface in com.wavefront.agent.data
Unified interface for dynamic entity-specific dynamic properties, that may change at runtime
EntityProperties.GlobalProperties - Interface in com.wavefront.agent.data
 
EntityPropertiesFactory - Interface in com.wavefront.agent.data
Generates entity-specific wrappers for dynamic proxy settings.
EntityPropertiesFactoryImpl - Class in com.wavefront.agent.data
Generates entity-specific wrappers for dynamic proxy settings.
EntityPropertiesFactoryImpl(ProxyConfig) - Constructor for class com.wavefront.agent.data.EntityPropertiesFactoryImpl
 
entityProps - 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.HistogramKey
 
equals(Object) - Method in class com.wavefront.agent.histogram.MapSettings
 
equals(Object) - Method in class com.wavefront.common.HostMetricTagsPair
 
equals(Object) - Method in class org.logstash.beats.BatchIdentity
 
errorMessageWithRootCause(Throwable) - Static method in class com.wavefront.agent.channel.ChannelUtils
Write detailed exception text.
EVENT - com.wavefront.agent.formatter.DataFormat
 
EventDataSubmissionTask - Class in com.wavefront.agent.data
A DataSubmissionTask that handles event payloads.
EventDataSubmissionTask(EventAPI, UUID, EntityProperties, TaskQueue<EventDataSubmissionTask>, String, List<Event>, Supplier<Long>) - Constructor for class com.wavefront.agent.data.EventDataSubmissionTask
 
EventHandlerImpl - Class in com.wavefront.agent.handlers
This class will validate parsed events and distribute them among SenderTask threads.
EventHandlerImpl(HandlerKey, int, Collection<SenderTask<Event>>, Consumer<Long>, Logger, Logger) - Constructor for class com.wavefront.agent.handlers.EventHandlerImpl
 
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.AbstractPortUnificationHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.listeners.ChannelByteArrayHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.listeners.RawLogsIngesterPortUnificationHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.logstash.beats.BeatsHandler
 
execute() - Method in interface com.wavefront.agent.data.DataSubmissionTask
Execute this task
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.
export() - Method in class com.wavefront.agent.queueing.QueueExporter
Starts data exporting process.
extractAnnotation(Span, String, List<Annotation>) - Method in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
extractTag(ReportPoint, String) - Method in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
extractToken(FullHttpRequest) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 

F

FeatureCheckUtils - Class in com.wavefront.agent.listeners
Constants and utility methods for validating feature subscriptions.
FeatureCheckUtils() - Constructor for class com.wavefront.agent.listeners.FeatureCheckUtils
 
FileBasedTaskQueue<T extends DataSubmissionTask<T>> - Class in com.wavefront.agent.queueing
Implements proxy-specific TaskQueue interface as a wrapper over QueueFile.
FileBasedTaskQueue(QueueFile, TaskConverter<T>) - Constructor for class com.wavefront.agent.queueing.FileBasedTaskQueue
 
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
 
filter(T) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Apply all filter predicates sequentially, stop at the first "false" result
filter(T, String[]) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Apply all filter predicates sequentially, stop at the first "false" result
finish() - Method in class com.wavefront.agent.channel.GZIPEncodingInterceptorWithVariableCompression.EndableGZIPOutputStream
 
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.histogram.accumulator.AccumulationCache
Merge the contents of this cache with the corresponding backing store.
flush() - Method in interface com.wavefront.agent.histogram.accumulator.Accumulator
Merge the contents of this cache with the corresponding backing store.
flush() - Method in class com.wavefront.agent.logsharvesting.LogsIngester
 
flushDeltaCounters() - Method in class com.wavefront.agent.handlers.DeltaCounterAccumulationHandlerImpl
 
flushNow(HandlerKey) - Method in class com.wavefront.agent.handlers.SenderTaskFactoryImpl
 
flushNow(HandlerKey) - Method in class com.wavefront.agent.queueing.QueueingFactoryImpl
 
FlushProcessor - Class in com.wavefront.agent.logsharvesting
Wrapper for MetricProcessor.
FlushProcessorContext - Class in com.wavefront.agent.logsharvesting
 
FORCE_PEER - org.logstash.netty.SslSimpleBuilder.SslClientVerifyMode
 
forceConfigReload() - Method in class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
Forces the next call to LogsIngestionConfigManager.getConfig() to call the config supplier.
formatErrorMessage(String, Throwable, ChannelHandlerContext) - Static method in class com.wavefront.agent.channel.ChannelUtils
Create a detailed error message from an exception, including current handle (port).
forPointLine() - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
 
forReportPoint() - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
 
forSpan() - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
 
fromBytes(byte[]) - Method in class com.wavefront.agent.queueing.RetryTaskConverter
 
fromBytes(byte[]) - Method in interface com.wavefront.agent.queueing.TaskConverter
De-serializes an object from a byte array.
fromMetricName(MetricName) - Static method in class com.wavefront.agent.logsharvesting.TimeSeriesUtils
 
fromMillis(long) - Static method in enum com.wavefront.agent.histogram.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.data.TaskQueueLevel
 
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() - Static method in class com.wavefront.agent.histogram.HistogramUtils.HistogramKeyMarshaller
 
get(ReportableEntityType) - Method in interface com.wavefront.agent.data.EntityPropertiesFactory
Get an entity-specific wrapper for proxy runtime properties.
get(ReportableEntityType) - Method in class com.wavefront.agent.data.EntityPropertiesFactoryImpl
 
get(File) - Method in class com.wavefront.agent.histogram.MapLoader
 
get(String) - Method in class com.wavefront.agent.preprocessor.PreprocessorConfigManager
 
getAdminApiListenerPort() - Method in class com.wavefront.agent.ProxyConfig
 
getAdminApiRemoteIpAllowRegex() - Method in class com.wavefront.agent.ProxyConfig
 
getAgentMetricsPointTags() - Method in class com.wavefront.agent.ProxyConfig
 
getAllowRegex() - Method in class com.wavefront.agent.ProxyConfig
 
getAuthMethod() - Method in class com.wavefront.agent.ProxyConfig
 
getAuthResponseMaxTtl() - Method in class com.wavefront.agent.ProxyConfig
 
getAuthResponseRefreshInterval() - Method in class com.wavefront.agent.ProxyConfig
 
getAuthStaticToken() - Method in class com.wavefront.agent.ProxyConfig
 
getAuthTokenIntrospectionAuthorizationHeader() - Method in class com.wavefront.agent.ProxyConfig
 
getAuthTokenIntrospectionServiceUrl() - Method in class com.wavefront.agent.ProxyConfig
 
getAvailableBytes() - Method in class com.wavefront.agent.queueing.FileBasedTaskQueue
 
getAvailableBytes() - Method in class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
getAvailableBytes() - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
getAvailableBytes() - Method in class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 
getAvailableBytes() - Method in interface com.wavefront.agent.queueing.TaskQueue
Returns the total number of pre-allocated but unused bytes in the backing file.
getAvailableBytes() - Method in class com.wavefront.agent.queueing.TaskQueueStub
 
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 interface org.logstash.beats.Batch
Number of messages that the batch is expected to contain.
getBatchSize() - Method in class org.logstash.beats.V1Batch
 
getBatchSize() - Method in class org.logstash.beats.V2Batch
 
getBinDurationInMillis() - Method in class com.wavefront.agent.histogram.HistogramKey
 
getBinId() - Method in class com.wavefront.agent.histogram.HistogramKey
 
getBinId(long) - Method in enum com.wavefront.agent.histogram.Granularity
Bin id for an epoch time is the epoch time in the corresponding granularity.
getBinTimeMillis() - Method in class com.wavefront.agent.histogram.HistogramKey
 
getBlockedHistogramsLoggerName() - Method in class com.wavefront.agent.ProxyConfig
 
getBlockedPointsLoggerName() - Method in class com.wavefront.agent.ProxyConfig
 
getBlockedSpansLoggerName() - Method in class com.wavefront.agent.ProxyConfig
 
getBlockRegex() - Method in class com.wavefront.agent.ProxyConfig
 
getBoolean(String, Boolean) - Method in class com.wavefront.agent.config.ReportableConfig
 
getBoolean(Map<String, Object>, String, boolean) - Static method in class com.wavefront.agent.preprocessor.PreprocessorUtil
 
getBufferFile() - Method in class com.wavefront.agent.ProxyConfig
 
getBuildVersion() - Static method in class com.wavefront.common.Utils
Attempts to retrieve build.version from system build properties.
getBytesPerMinute() - Method in class com.wavefront.agent.queueing.TaskSizeEstimator
Calculates the bytes per minute buffer usage rate.
getClientId() - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
getConfig() - Method in class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
 
getCounter(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
getCustomSourceTags() - Method in class com.wavefront.agent.ProxyConfig
 
getCustomTracingApplicationName() - Method in class com.wavefront.agent.ProxyConfig
 
getCustomTracingListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getCustomTracingServiceName() - Method in class com.wavefront.agent.ProxyConfig
 
getData() - Method in class org.logstash.beats.Message
Returns a list of key/value pairs representing the contents of the message.
getDataBackfillCutoffHours() - Method in class com.wavefront.agent.ProxyConfig
 
getDataDogJsonPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getDataDogRequestRelayAsyncThreads() - Method in class com.wavefront.agent.ProxyConfig
 
getDataDogRequestRelayTarget() - Method in class com.wavefront.agent.ProxyConfig
 
getDataPrefillCutoffHours() - Method in class com.wavefront.agent.ProxyConfig
 
getDeltaCountersAggregationIntervalSeconds() - Method in class com.wavefront.agent.ProxyConfig
 
getDeltaCountersAggregationListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getDispatchTimeMillis() - Method in class com.tdunning.math.stats.AgentDigest
Time at which this digest should be dispatched to wavefront.
getDouble(String, Number) - Method in class com.wavefront.agent.config.ReportableConfig
 
getDropSpansDelayedMinutes() - Method in interface com.wavefront.agent.data.EntityProperties.GlobalProperties
Get the maximum acceptable duration between now and the end of a span to be accepted for reporting to Wavefront, beyond which they are dropped.
getDurationSampler(int) - Static method in class com.wavefront.agent.sampler.SpanSamplerUtils
 
getEnqueuedMillis() - Method in interface com.wavefront.agent.data.DataSubmissionTask
Returns task enqueue time in milliseconds.
getEntityType() - Method in interface com.wavefront.agent.data.DataSubmissionTask
Returns entity type handled.
getEntityType() - Method in class com.wavefront.agent.handlers.HandlerKey
 
getEntries() - Method in class com.wavefront.agent.histogram.MapSettings
 
getEventAPI() - Method in class com.wavefront.agent.api.APIContainer
Get RESTeasy proxy for EventAPI.
getExportQueueOutputFile() - Method in class com.wavefront.agent.ProxyConfig
 
getExportQueuePorts() - Method in class com.wavefront.agent.ProxyConfig
 
getFailureCount() - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
getFilebeatPort() - Method in class com.wavefront.agent.ProxyConfig
 
getFilters() - Method in class com.wavefront.agent.preprocessor.Preprocessor
Check all filter rules as an immutable list
getFlushThreads() - Method in interface com.wavefront.agent.data.EntityProperties
Get the number of worker threads.
getFlushThreads() - Method in class com.wavefront.agent.ProxyConfig
 
getFlushThreadsEvents() - Method in class com.wavefront.agent.ProxyConfig
 
getFlushThreadsSourceTags() - Method in class com.wavefront.agent.ProxyConfig
 
getFormat(FullHttpRequest) - Method in class com.wavefront.agent.listeners.AbstractLineDelimitedHandler
Detect data format for an incoming HTTP request, if possible.
getFormat(FullHttpRequest) - Method in class com.wavefront.agent.listeners.RawLogsIngesterPortUnificationHandler
 
getFormat(FullHttpRequest) - Method in class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
getFormat(FullHttpRequest) - Method in class com.wavefront.agent.listeners.WavefrontPortUnificationHandler
 
getGauge(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
getGlobalProperties() - Method in interface com.wavefront.agent.data.EntityProperties
Accesses a container with properties shared across all entity types
getGlobalProperties() - Method in interface com.wavefront.agent.data.EntityPropertiesFactory
Returns a container with properties shared across all entity types
getGlobalProperties() - Method in class com.wavefront.agent.data.EntityPropertiesFactoryImpl
 
getGranularityOrdinal() - Method in class com.wavefront.agent.histogram.HistogramKey
 
getGraphiteDelimiters() - Method in class com.wavefront.agent.ProxyConfig
 
getGraphiteFieldsToRemove() - Method in class com.wavefront.agent.ProxyConfig
 
getGraphiteFormat() - Method in class com.wavefront.agent.ProxyConfig
 
getGraphitePorts() - Method in class com.wavefront.agent.ProxyConfig
 
getGzip() - Method in class com.wavefront.agent.channel.GZIPEncodingInterceptorWithVariableCompression.CommittedGZIPOutputStream
 
getGzipCompressionLevel() - Method in class com.wavefront.agent.ProxyConfig
 
getHandle() - Method in class com.wavefront.agent.handlers.HandlerKey
 
getHandler(HandlerKey) - Method in class com.wavefront.agent.handlers.DelegatingReportableEntityHandlerFactoryImpl
 
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
 
getHandler(ReportableEntityType, String) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandlerFactory
Create, or return existing, ReportableEntityHandler.
getHealthCheckResponse(ChannelHandlerContext, FullHttpRequest) - Method in interface com.wavefront.agent.channel.HealthCheckManager
 
getHealthCheckResponse(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.channel.HealthCheckManagerImpl
 
getHealthCheckResponse(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.channel.NoopHealthCheckManager
 
getHighestSequence() - Method in interface org.logstash.beats.Batch
Returns the highest sequence number of the batch.
getHighestSequence() - Method in class org.logstash.beats.V1Batch
 
getHighestSequence() - Method in class org.logstash.beats.V2Batch
 
getHistogram(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
getHistogramAccumulatorFlushInterval() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramAccumulatorFlushMaxBatchSize() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramAccumulatorResolveInterval() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDayAccumulatorSize() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDayAvgDigestBytes() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDayAvgKeyBytes() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDayCompression() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDayFlushSecs() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDayListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDistAccumulatorSize() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDistAvgDigestBytes() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDistAvgKeyBytes() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDistCompression() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDistFlushSecs() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramDistListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramHourAccumulatorSize() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramHourAvgDigestBytes() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramHourAvgKeyBytes() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramHourCompression() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramHourFlushSecs() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramHourListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramHttpBufferSize() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramMaxReceivedLength() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramMinuteAccumulatorSize() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramMinuteAvgDigestBytes() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramMinuteAvgKeyBytes() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramMinuteCompression() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramMinuteFlushSecs() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramMinuteListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramStateDirectory() - Method in class com.wavefront.agent.ProxyConfig
 
getHistogramStorageAccuracy() - Method in interface com.wavefront.agent.data.EntityProperties.GlobalProperties
Get histogram storage accuracy, as specified by the back-end.
getHost() - Method in class com.wavefront.common.HostMetricTagsPair
 
getHostname() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpAutoRetries() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpConnectTimeout() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpEnabled() - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
Checks whether HTTP protocol is enabled on this port
getHttpHealthCheckFailResponseBody() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpHealthCheckFailStatusCode() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpHealthCheckPassResponseBody() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpHealthCheckPassStatusCode() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpHealthCheckPath() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpHealthCheckPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpHealthCheckResponseContentType() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpMaxConnPerRoute() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpMaxConnTotal() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpRequestTimeout() - Method in class com.wavefront.agent.ProxyConfig
 
getHttpStatusCounter(ChannelHandlerContext, int) - Static method in class com.wavefront.agent.channel.ChannelUtils
Get a counter for ~proxy.listeners.http-requests.status.###.count metric for a specific status code, with port= point tag for added context.
getHttpUserAgent() - Method in class com.wavefront.agent.ProxyConfig
 
getIdentityStream() - Method in class org.logstash.beats.Message
 
getIdFile() - Method in class com.wavefront.agent.ProxyConfig
 
getInMillis() - Method in enum com.wavefront.agent.histogram.Granularity
Duration of a corresponding bin in milliseconds.
getInstance() - Static method in class com.wavefront.agent.SharedMetricsRegistry
 
getInteger(String, Number) - Method in class com.wavefront.agent.config.ReportableConfig
 
getInteger(Map<String, Object>, String, int) - Static method in class com.wavefront.agent.preprocessor.PreprocessorUtil
 
getItemsPerBatch() - Method in interface com.wavefront.agent.data.EntityProperties
Get the maximum allowed number of items per single flush.
getItemsPerBatchOriginal() - Method in interface com.wavefront.agent.data.EntityProperties
Get initially configured batch size.
getJavaVersion() - Static method in class com.wavefront.common.Utils
Returns current java runtime version information (name/vendor/version) as a string.
getJsonListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getListenerIdleConnectionTimeout() - Method in class com.wavefront.agent.ProxyConfig
 
getLocalHostName() - Static method in class com.wavefront.common.Utils
Makes a best-effort attempt to resolve the hostname for the local host.
getLogLine() - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
 
getLogLine() - Method in interface com.wavefront.agent.logsharvesting.LogsMessage
 
getLogsIngestionConfigFile() - Method in class com.wavefront.agent.ProxyConfig
 
getLong(String, Number) - Method in class com.wavefront.agent.config.ReportableConfig
 
getMemGuardFlushThreshold() - Method in class com.wavefront.agent.ProxyConfig
 
getMemoryBufferLimit() - Method in interface com.wavefront.agent.data.EntityProperties
Max number of items that can stay in memory buffers before spooling to disk.
getMetric() - Method in class com.wavefront.agent.histogram.HistogramKey
 
getMetric() - Method in class com.wavefront.common.HostMetricTagsPair
 
getMetricMangler() - Method in class com.wavefront.agent.formatter.GraphiteFormatter
 
getMinBatchSplitSize() - Method in interface com.wavefront.agent.data.EntityProperties
Do not split the batch if its size is less than this value.
getName() - Method in class com.wavefront.agent.queueing.FileBasedTaskQueue
 
getName() - Method in class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
getName() - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
getName() - Method in class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 
getName() - Method in interface com.wavefront.agent.queueing.TaskQueue
Returns the unique queue name/identifier, can be anything, like file path name for file-based queues.
getName() - Method in class com.wavefront.agent.queueing.TaskQueueStub
 
getNumber(String, Number) - Method in class com.wavefront.agent.config.ReportableConfig
 
getNumber(String, Number, Number, Number) - Method in class com.wavefront.agent.config.ReportableConfig
 
getOpentsdbAllowRegex() - Method in class com.wavefront.agent.ProxyConfig
 
getOpentsdbBlockRegex() - Method in class com.wavefront.agent.ProxyConfig
 
getOpentsdbPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getOps() - Method in class com.wavefront.agent.formatter.GraphiteFormatter
 
getPattern() - Method in class com.wavefront.agent.config.MetricMatcher
 
getPicklePorts() - Method in class com.wavefront.agent.ProxyConfig
 
getPredicate(Map<String, Object>) - Static method in class com.wavefront.agent.preprocessor.Predicates
 
getPrefix() - Method in class com.wavefront.agent.ProxyConfig
 
getPreprocessorConfigFile() - Method in class com.wavefront.agent.ProxyConfig
 
getPrivateCertPath() - Method in class com.wavefront.agent.ProxyConfig
 
getPrivateKeyPath() - Method in class com.wavefront.agent.ProxyConfig
 
getProtocol() - Method in class org.logstash.beats.Ack
 
getProtocol() - Method in interface org.logstash.beats.Batch
Returns the protocol of the sent messages that this batch was constructed from
getProtocol() - Method in class org.logstash.beats.V1Batch
 
getProtocol() - Method in class org.logstash.beats.V2Batch
 
getProxyHost() - Method in class com.wavefront.agent.ProxyConfig
 
getProxyPassword() - Method in class com.wavefront.agent.ProxyConfig
 
getProxyPort() - Method in class com.wavefront.agent.ProxyConfig
 
getProxyUser() - Method in class com.wavefront.agent.ProxyConfig
 
getProxyV2API() - Method in class com.wavefront.agent.api.APIContainer
Get RESTeasy proxy for ProxyV2API.
getPushBlockedSamples() - Method in class com.wavefront.agent.ProxyConfig
 
getPushFlushInterval() - Method in interface com.wavefront.agent.data.EntityProperties
Get interval between batches (in milliseconds)
getPushFlushInterval() - Method in class com.wavefront.agent.ProxyConfig
 
getPushFlushMaxEvents() - Method in class com.wavefront.agent.ProxyConfig
 
getPushFlushMaxHistograms() - Method in class com.wavefront.agent.ProxyConfig
 
getPushFlushMaxPoints() - Method in class com.wavefront.agent.ProxyConfig
 
getPushFlushMaxSourceTags() - Method in class com.wavefront.agent.ProxyConfig
 
getPushFlushMaxSpanLogs() - Method in class com.wavefront.agent.ProxyConfig
 
getPushFlushMaxSpans() - Method in class com.wavefront.agent.ProxyConfig
 
getPushListenerHttpBufferSize() - Method in class com.wavefront.agent.ProxyConfig
 
getPushListenerMaxReceivedLength() - Method in class com.wavefront.agent.ProxyConfig
 
getPushListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getPushMemoryBufferLimit() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRateLimit() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRateLimitEvents() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRateLimitHistograms() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRateLimitMaxBurstSeconds() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRateLimitSourceTags() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRateLimitSpanLogs() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRateLimitSpans() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRelayHistogramAggregatorAccumulatorSize() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRelayHistogramAggregatorCompression() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRelayHistogramAggregatorFlushSecs() - Method in class com.wavefront.agent.ProxyConfig
 
getPushRelayListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getQueueController(HandlerKey, int) - Method in interface com.wavefront.agent.queueing.QueueingFactory
Create a new QueueController instance for the specified handler key.
getQueueController(HandlerKey, int) - Method in class com.wavefront.agent.queueing.QueueingFactoryImpl
 
getQueueName(HandlerKey) - Method in class com.wavefront.agent.queueing.SQSQueueFactoryImpl
 
getRateLimit() - Method in interface com.wavefront.agent.data.EntityProperties
Get initially configured rate limit (per second).
getRateLimiter() - Method in interface com.wavefront.agent.data.EntityProperties
Get specific RecyclableRateLimiter instance.
getRateLimitMaxBurstSeconds() - Method in interface com.wavefront.agent.data.EntityProperties
Get max number of burst seconds to allow when rate limiting to smooth out uneven traffic.
getRateSampler(double) - Static method in class com.wavefront.agent.sampler.SpanSamplerUtils
 
getRawLogsHttpBufferSize() - Method in class com.wavefront.agent.ProxyConfig
 
getRawLogsMaxReceivedLength() - Method in class com.wavefront.agent.ProxyConfig
 
getRawLogsPort() - Method in class com.wavefront.agent.ProxyConfig
 
getRawProperty(String, String) - Method in class com.wavefront.agent.config.ReportableConfig
Returns string value for the property without tracking it as a metric
getRemoteAddress(ChannelHandlerContext) - Static method in class com.wavefront.agent.channel.ChannelUtils
Get InetAddress for the current channel.
getRemoteName(ChannelHandlerContext) - Static method in class com.wavefront.agent.channel.ChannelUtils
Get remote client's address as string (without rDNS lookup) and local port
getRetryBackoffBaseSeconds() - Method in interface com.wavefront.agent.data.EntityProperties.GlobalProperties
Get base in seconds for retry thread exponential backoff.
getRetryBackoffBaseSeconds() - Method in class com.wavefront.agent.ProxyConfig
 
getRipeDigestsIterator(TimeProvider) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Returns an iterator over "ripe" digests ready to be shipped
getRipeDigestsIterator(TimeProvider) - Method in interface com.wavefront.agent.histogram.accumulator.Accumulator
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
Returns the sequence number of this messsage
getServer() - Method in class com.wavefront.agent.ProxyConfig
 
getSize(JsonNode, Class<?>, Type, Annotation[], MediaType) - Method in class com.wavefront.agent.JsonNodeWriter
 
getSoLingerTime() - Method in class com.wavefront.agent.ProxyConfig
 
getSource() - Method in class com.wavefront.agent.histogram.HistogramKey
 
getSourceTagAPI() - Method in class com.wavefront.agent.api.APIContainer
Get RESTeasy proxy for SourceTagAPI.
getSqsQueueIdentifier() - Method in class com.wavefront.agent.ProxyConfig
 
getSqsQueueNameTemplate() - Method in class com.wavefront.agent.ProxyConfig
 
getSqsQueueRegion() - Method in class com.wavefront.agent.ProxyConfig
 
getSslCertificateFile() - Method in class org.logstash.netty.SslSimpleBuilder
 
getSslContext(String) - Method in class com.wavefront.agent.PushAgent
 
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
 
getString(Map<String, Object>, String) - Static method in class com.wavefront.agent.preprocessor.PreprocessorUtil
 
getSuccessfulCheckinCount() - Method in class com.wavefront.agent.ProxyCheckInScheduler
Returns the number of successful check-ins.
getSystemPreprocessor(String) - Method in class com.wavefront.agent.preprocessor.PreprocessorConfigManager
 
getTags() - Method in class com.wavefront.agent.histogram.HistogramKey
 
getTags() - Method in class com.wavefront.common.HostMetricTagsPair
 
getTagsAsMap() - Method in class com.wavefront.agent.histogram.HistogramKey
Unpacks tags into a map.
getTaskQueue(HandlerKey, int) - Method in class com.wavefront.agent.queueing.SQSQueueFactoryImpl
 
getTaskQueue(HandlerKey, int) - Method in interface com.wavefront.agent.queueing.TaskQueueFactory
Create a task queue for a specified HandlerKey and thread number.
getTaskQueue(HandlerKey, int) - Method in class com.wavefront.agent.queueing.TaskQueueFactoryImpl
 
getTaskQueueLevel() - Method in interface com.wavefront.agent.data.EntityProperties
Get current queueing behavior - defines conditions that trigger queueing.
getTaskQueueLevel() - Method in class com.wavefront.agent.ProxyConfig
 
getTaskRelativeScore() - Method in interface com.wavefront.agent.handlers.SenderTask
Calculate a numeric score (the lower the better) that is intended to help the ReportableEntityHandler choose the best SenderTask to handle over data to.
getTestPreprocessorForPort() - Method in class com.wavefront.agent.ProxyConfig
 
getTestSpanPreprocessorForPort() - Method in class com.wavefront.agent.ProxyConfig
 
getTimeProvider() - Method in class com.wavefront.agent.ProxyConfig
 
getTimestampMillis() - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
 
getTlsPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getToken() - Method in class com.wavefront.agent.ProxyConfig
 
getTotalBacklogSize() - Method in interface com.wavefront.agent.data.EntityProperties
Get aggregated backlog size across all ports for this entity type.
getTotalReceivedRate() - Method in interface com.wavefront.agent.data.EntityProperties
Get aggregated received rate across all ports for this entity type.
getTraceDerivedCustomTagKeys() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceJaegerApplicationName() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceJaegerGrpcListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceJaegerHttpListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceJaegerListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceListenerHttpBufferSize() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceListenerMaxReceivedLength() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceSamplingDuration() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceSamplingRate() - Method in interface com.wavefront.agent.data.EntityProperties.GlobalProperties
Get the sampling rate for tracing spans.
getTraceSamplingRate() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceZipkinApplicationName() - Method in class com.wavefront.agent.ProxyConfig
 
getTraceZipkinListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
getTrafficShapingHeadroom() - Method in class com.wavefront.agent.ProxyConfig
 
getTrafficShapingWindowSeconds() - Method in class com.wavefront.agent.ProxyConfig
 
getTransformers() - Method in class com.wavefront.agent.preprocessor.Preprocessor
Get all transformer rules as an immutable list
getValue() - Method in class com.wavefront.agent.logsharvesting.ReadProcessorContext
 
getValueLabel() - Method in class com.wavefront.agent.config.MetricMatcher
 
getWeight(byte[]) - Method in class com.wavefront.agent.queueing.RetryTaskConverter
 
getWeight(byte[]) - Method in interface com.wavefront.agent.queueing.TaskConverter
Attempts to retrieve task weight from a byte[], without de-serializing the object, if at all possible.
getWriteHttpJsonListenerPorts() - Method in class com.wavefront.agent.ProxyConfig
 
Granularity - Enum in com.wavefront.agent.histogram
Standard supported aggregation Granularities.
granularityToString(Granularity) - Static method in class com.wavefront.agent.histogram.HistogramUtils
Convert granularity to string.
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
 
gzip - Variable in class com.wavefront.agent.channel.GZIPEncodingInterceptorWithVariableCompression.CommittedGZIPOutputStream
 
GZIP - com.wavefront.agent.queueing.TaskConverter.CompressionType
 
GZIPEncodingInterceptorWithVariableCompression - Class in com.wavefront.agent.channel
An alternative to GZIPEncodingInterceptor that allows changing the GZIP deflater's compression level.
GZIPEncodingInterceptorWithVariableCompression(int) - Constructor for class com.wavefront.agent.channel.GZIPEncodingInterceptorWithVariableCompression
 
GZIPEncodingInterceptorWithVariableCompression.CommittedGZIPOutputStream - Class in com.wavefront.agent.channel
 
GZIPEncodingInterceptorWithVariableCompression.EndableGZIPOutputStream - Class in com.wavefront.agent.channel
 

H

handle - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.AbstractHttpOnlyHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.AbstractLineDelimitedHandler
Handles an incoming HTTP message.
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
Process incoming HTTP request.
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.AdminPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.DataDogPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.HttpHealthCheckEndpointHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.JsonMetricsPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.OpenTSDBPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.RelayPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.tracing.JaegerPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.WavefrontPortUnificationHandler
 
handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.WriteHttpJsonPortUnificationHandler
 
handleImpl(ThriftRequest<Collector.submitBatches_args>) - Method in class com.wavefront.agent.listeners.tracing.JaegerTChannelCollectorHandler
 
handleOversizedMessage(ChannelHandlerContext, HttpMessage) - Method in class com.wavefront.agent.channel.StatusTrackingHttpObjectAggregator
 
handlePlainTextMessage(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.AbstractHttpOnlyHandler
Discards plaintext content.
handlePlainTextMessage(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.AbstractLineDelimitedHandler
Handles an incoming plain text (string) message.
handlePlainTextMessage(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
Process incoming plaintext string.
handlePlainTextMessage(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.OpenTSDBPortUnificationHandler
Handles an incoming plain text (string) message.
handler - Variable in class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
handlerFactory - Variable in class com.wavefront.agent.PushAgent
 
handlerKey - Variable in class com.wavefront.agent.queueing.QueueController
 
handlerKey - Variable in class com.wavefront.agent.queueing.QueueProcessor
 
HandlerKey - Class in com.wavefront.agent.handlers
An immutable unique identifier for a handler pipeline (type of objects handled + port/handle name)
handlers - Variable in class com.wavefront.agent.handlers.ReportableEntityHandlerFactoryImpl
 
handleSpanLogs(String, ReportableEntityDecoder<JsonNode, SpanLogs>, ReportableEntityDecoder<String, Span>, ReportableEntityHandler<SpanLogs, String>, Supplier<ReportableEntityPreprocessor>, ChannelHandlerContext, Function<Span, Boolean>) - Static method in class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
hasCapture(String) - Method in class com.wavefront.agent.config.MetricMatcher
 
hashCode() - Method in class com.wavefront.agent.config.Configuration
 
hashCode() - Method in class com.wavefront.agent.handlers.HandlerKey
 
hashCode() - Method in class com.wavefront.agent.histogram.HistogramKey
 
hashCode() - Method in class com.wavefront.common.HostMetricTagsPair
 
hashCode() - Method in class org.logstash.beats.BatchIdentity
 
healthCheck - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 
healthCheckManager - Variable in class com.wavefront.agent.PushAgent
 
HealthCheckManager - Interface in com.wavefront.agent.channel
Centrally manages healthcheck statuses (for controlling load balancers).
HealthCheckManagerImpl - Class in com.wavefront.agent.channel
Centrally manages healthcheck statuses (for controlling load balancers).
HealthCheckManagerImpl(ProxyConfig) - Constructor for class com.wavefront.agent.channel.HealthCheckManagerImpl
 
HISTO_DISABLED - Static variable in class com.wavefront.agent.listeners.FeatureCheckUtils
 
HISTOGRAM - com.wavefront.agent.formatter.DataFormat
 
HistogramAccumulationHandlerImpl - Class in com.wavefront.agent.handlers
A ReportPointHandler that ships parsed points to a histogram accumulator instead of forwarding them to SenderTask.
HistogramAccumulationHandlerImpl(HandlerKey, Accumulator, int, Granularity, ValidationConfiguration, boolean, Consumer<Long>, Logger, Logger) - Constructor for class com.wavefront.agent.handlers.HistogramAccumulationHandlerImpl
Creates a new instance
histogramExecutor - Variable in class com.wavefront.agent.PushAgent
 
histogramFlushExecutor - Variable in class com.wavefront.agent.PushAgent
 
histogramFlushRunnables - Variable in class com.wavefront.agent.PushAgent
 
HistogramKey - Class in com.wavefront.agent.histogram
Uniquely identifies a time-series - time-interval pair.
histogramRecompressor - Variable in class com.wavefront.agent.PushAgent
 
HistogramRecompressor - Class in com.wavefront.agent.histogram
Recompresses histograms to reduce their size.
HistogramRecompressor(Supplier<Short>) - Constructor for class com.wavefront.agent.histogram.HistogramRecompressor
 
histograms - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Histograms to ingest from incoming log data.
HistogramUtils - Class in com.wavefront.agent.histogram
Helpers around histograms
HistogramUtils.HistogramKeyMarshaller - Class in com.wavefront.agent.histogram
(For now, a rather trivial) encoding of 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.
host - Variable in class com.wavefront.common.HostMetricTagsPair
 
HostMetricTagsPair - Class in com.wavefront.common
Tuple class to store combination of { host, metric, tags } Two or more tuples with the same value of { host, metric and tags } are considered equal and will have the same hashcode.
HostMetricTagsPair(String, String, Map<String, String>) - Constructor for class com.wavefront.common.HostMetricTagsPair
 
hostnameResolver - Variable in class com.wavefront.agent.PushAgent
 
hostOrDefault(String) - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
 
hostOrDefault(String) - Method in interface com.wavefront.agent.logsharvesting.LogsMessage
 
HOUR - com.wavefront.agent.histogram.Granularity
 
HTTP_GET - com.wavefront.agent.auth.TokenValidationMethod
 
HttpHealthCheckEndpointHandler - Class in com.wavefront.agent.listeners
A simple healthcheck-only endpoint handler.
HttpHealthCheckEndpointHandler(HealthCheckManager, int) - Constructor for class com.wavefront.agent.listeners.HttpHealthCheckEndpointHandler
 
httpRequestHandleDuration - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 
httpRequestsInFlight - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 
httpRequestsInFlightGauge - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 

I

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
 
IgnoreStatusCodeException - Exception in com.wavefront.agent.data
Exception used to ignore 404s for DELETE API calls for sourceTags.
IgnoreStatusCodeException(String) - Constructor for exception com.wavefront.agent.data.IgnoreStatusCodeException
 
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.
IncompleteLineDetectingLineBasedFrameDecoder - Class in com.wavefront.agent.channel
Line-delimited decoder that has the ability of detecting when clients have disconnected while leaving some data in the buffer.
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
 
init(DaemonContext) - Method in class com.wavefront.agent.WavefrontProxyService
 
inject(T) - Method in interface com.wavefront.agent.data.TaskInjector
Inject members into specified task.
injectMembers(EventAPI, UUID, EntityProperties, TaskQueue<EventDataSubmissionTask>) - Method in class com.wavefront.agent.data.EventDataSubmissionTask
 
injectMembers(ProxyV2API, UUID, EntityProperties, TaskQueue<LineDelimitedDataSubmissionTask>) - Method in class com.wavefront.agent.data.LineDelimitedDataSubmissionTask
 
injectMembers(SourceTagAPI, EntityProperties, TaskQueue<SourceTagSubmissionTask>) - Method in class com.wavefront.agent.data.SourceTagSubmissionTask
 
InMemorySubmissionQueue<T extends DataSubmissionTask<T>> - Class in com.wavefront.agent.queueing
Implements proxy-specific in-memory-queue interface as a wrapper over tape ObjectQueue
InMemorySubmissionQueue() - Constructor for class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
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
 
InteractivePreprocessorTester - Class in com.wavefront.agent.preprocessor
Interactive tester for preprocessor rules.
InteractivePreprocessorTester(Supplier<ReportableEntityPreprocessor>, ReportableEntityType, String, List<String>) - Constructor for class com.wavefront.agent.preprocessor.InteractivePreprocessorTester
 
interactiveTest() - Method in interface com.wavefront.agent.InteractiveTester
Read line from stdin and process it.
interactiveTest() - Method in class com.wavefront.agent.logsharvesting.InteractiveLogsTester
Read one line of stdin and print a message to stdout.
interactiveTest() - Method in class com.wavefront.agent.preprocessor.InteractivePreprocessorTester
 
InteractiveTester - Interface in com.wavefront.agent
Base interface for all interactive testers (logs and preprocessor at the moment).
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, String) - Constructor for class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
isComplete() - Method in interface org.logstash.beats.Batch
Is the batch complete?
isComplete() - Method in class org.logstash.beats.V1Batch
 
isComplete() - Method in class org.logstash.beats.V2Batch
 
isDataDogProcessServiceChecks() - Method in class com.wavefront.agent.ProxyConfig
 
isDataDogProcessSystemMetrics() - Method in class com.wavefront.agent.ProxyConfig
 
isDataDogRequestRelaySyncMode() - Method in class com.wavefront.agent.ProxyConfig
 
isDefined(String) - Method in class com.wavefront.agent.config.ReportableConfig
 
isDisableRdnsLookup() - Method in class com.wavefront.agent.ProxyConfig
 
isEmpty() - Method in interface org.logstash.beats.Batch
Is the batch currently empty?
isEmpty() - Method in class org.logstash.beats.V1Batch
 
isEmpty() - Method in class org.logstash.beats.V2Batch
 
isEphemeral() - Method in class com.wavefront.agent.ProxyConfig
 
isExportQueueRetainData() - Method in class com.wavefront.agent.ProxyConfig
 
isFeatureDisabled() - Method in interface com.wavefront.agent.data.EntityProperties
Checks whether data flow for this entity type is disabled.
isFeatureDisabled(Supplier<Boolean>, String, Counter) - Static method in class com.wavefront.agent.listeners.FeatureCheckUtils
Check whether feature disabled flag is set, log a warning message, increment the counter by 1.
isFeatureDisabled(Supplier<Boolean>, String, Counter, StringBuilder) - Static method in class com.wavefront.agent.listeners.FeatureCheckUtils
Check whether feature disabled flag is set, log a warning message, increment the counter by 1.
isFeatureDisabled(Supplier<Boolean>, String, Counter, StringBuilder, FullHttpRequest) - Static method in class com.wavefront.agent.listeners.FeatureCheckUtils
Check whether feature disabled flag is set, log a warning message, increment the counter either by 1 or by number of \n characters in request payload, if provided.
isGzipCompression() - Method in class com.wavefront.agent.ProxyConfig
 
isHealthy(int) - Method in interface com.wavefront.agent.channel.HealthCheckManager
 
isHealthy(int) - Method in class com.wavefront.agent.channel.HealthCheckManagerImpl
 
isHealthy(int) - Method in class com.wavefront.agent.channel.NoopHealthCheckManager
 
isHelp() - Method in class com.wavefront.agent.ProxyConfig
 
isHistogramDayAccumulatorPersisted() - Method in class com.wavefront.agent.ProxyConfig
 
isHistogramDayMemoryCache() - Method in class com.wavefront.agent.ProxyConfig
 
isHistogramDistAccumulatorPersisted() - Method in class com.wavefront.agent.ProxyConfig
 
isHistogramDistMemoryCache() - Method in class com.wavefront.agent.ProxyConfig
 
isHistogramHourAccumulatorPersisted() - Method in class com.wavefront.agent.ProxyConfig
 
isHistogramHourMemoryCache() - Method in class com.wavefront.agent.ProxyConfig
 
isHistogramMinuteAccumulatorPersisted() - Method in class com.wavefront.agent.ProxyConfig
 
isHistogramMinuteMemoryCache() - Method in class com.wavefront.agent.ProxyConfig
 
isHistogramPassthroughRecompression() - Method in class com.wavefront.agent.ProxyConfig
 
isHttpHealthCheckAllPorts() - Method in class com.wavefront.agent.ProxyConfig
 
isLessThan(TaskQueueLevel) - Method in enum com.wavefront.agent.data.TaskQueueLevel
 
isLoggable(Level) - Method in class com.wavefront.common.SamplingLogger
 
isPurgeBuffer() - Method in class com.wavefront.agent.ProxyConfig
 
isPushRelayHistogramAggregator() - Method in class com.wavefront.agent.ProxyConfig
 
isSplitPushWhenRateLimited() - Method in interface com.wavefront.agent.data.EntityProperties
Whether we should split batches into smaller ones after getting HTTP 406 response from server.
isSplitPushWhenRateLimited() - Method in class com.wavefront.agent.ProxyConfig
 
isSqsQueueBuffer() - Method in class com.wavefront.agent.ProxyConfig
 
isSslEnable() - Method in class org.logstash.beats.Server
 
isTestLogs() - Method in class com.wavefront.agent.ProxyConfig
 
isTraceAlwaysSampleErrors() - Method in class com.wavefront.agent.ProxyConfig
 
isTrafficShaping() - Method in class com.wavefront.agent.ProxyConfig
 
isUseNoopSender() - Method in class com.wavefront.agent.ProxyConfig
 
isValidSQSTemplate(String) - Static method in class com.wavefront.agent.queueing.SQSQueueFactoryImpl
 
isVersion() - Method in class com.wavefront.agent.ProxyConfig
 
isVersion2(byte) - Static method in class org.logstash.beats.Protocol
 
isWavefrontResponse(Response) - Static method in class com.wavefront.common.Utils
Check if the HTTP 407/408 response was actually received from Wavefront - if it's a JSON object containing "code" key, with value equal to the HTTP response code, it's most likely from us.
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.wavefront.agent.JsonNodeWriter
 
iterator() - Method in class com.wavefront.agent.queueing.FileBasedTaskQueue
 
iterator() - Method in class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
iterator() - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
iterator() - Method in class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 
iterator() - Method in class com.wavefront.agent.queueing.TaskQueueStub
 
iterator() - Method in class org.logstash.beats.V1Batch
 
iterator() - Method in class org.logstash.beats.V2Batch
 

J

JaegerGrpcCollectorHandler - Class in com.wavefront.agent.listeners.tracing
Handler that processes trace data in Jaeger ProtoBuf format and converts them to Wavefront format
JaegerGrpcCollectorHandler(String, ReportableEntityHandler<Span, String>, ReportableEntityHandler<SpanLogs, String>, WavefrontSender, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, SpanSampler, String, Set<String>) - Constructor for class com.wavefront.agent.listeners.tracing.JaegerGrpcCollectorHandler
 
JaegerGrpcCollectorHandler(String, ReportableEntityHandlerFactory, WavefrontSender, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, SpanSampler, String, Set<String>) - Constructor for class com.wavefront.agent.listeners.tracing.JaegerGrpcCollectorHandler
 
JaegerPortUnificationHandler - Class in com.wavefront.agent.listeners.tracing
Handler that processes Jaeger Thrift trace data over HTTP and converts them to Wavefront format.
JaegerPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityHandlerFactory, WavefrontSender, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, SpanSampler, String, Set<String>) - Constructor for class com.wavefront.agent.listeners.tracing.JaegerPortUnificationHandler
 
JaegerProtobufUtils - Class in com.wavefront.agent.listeners.tracing
Utility methods for processing Jaeger Protobuf trace data.
JaegerTChannelCollectorHandler - Class in com.wavefront.agent.listeners.tracing
Handler that processes trace data in Jaeger Thrift compact format and converts them to Wavefront format
JaegerTChannelCollectorHandler(String, ReportableEntityHandler<Span, String>, ReportableEntityHandler<SpanLogs, String>, WavefrontSender, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, SpanSampler, String, Set<String>) - Constructor for class com.wavefront.agent.listeners.tracing.JaegerTChannelCollectorHandler
 
JaegerTChannelCollectorHandler(String, ReportableEntityHandlerFactory, WavefrontSender, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, SpanSampler, String, Set<String>) - Constructor for class com.wavefront.agent.listeners.tracing.JaegerTChannelCollectorHandler
 
JaegerThriftUtils - Class in com.wavefront.agent.listeners.tracing
Utility methods for processing Jaeger Thrift trace data.
joinPushData(Collection<String>) - Static method in class com.wavefront.agent.handlers.LineDelimitedUtils
Join a batch of strings into a payload string.
JsonMetricsPortUnificationHandler - Class in com.wavefront.agent.listeners
Agent-side JSON metrics endpoint.
JsonMetricsPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityHandler<ReportPoint, String>, String, String, Supplier<ReportableEntityPreprocessor>) - Constructor for class com.wavefront.agent.listeners.JsonMetricsPortUnificationHandler
 
JsonMetricsPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityHandlerFactory, String, String, Supplier<ReportableEntityPreprocessor>) - Constructor for class com.wavefront.agent.listeners.JsonMetricsPortUnificationHandler
Create a new instance.
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
 
keyFrom(Message) - Static method in class org.logstash.beats.BatchIdentity
 

L

lazySupplier(Supplier<T>) - Static method in class com.wavefront.common.Utils
A lazy initialization wrapper for Supplier
LengthLimitActionType - Enum in com.wavefront.agent.preprocessor
 
LineBasedAllowFilter - Class in com.wavefront.agent.preprocessor
"Allow list" regex filter.
LineBasedAllowFilter(String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.LineBasedAllowFilter
 
LineBasedBlockFilter - Class in com.wavefront.agent.preprocessor
Blocking regex-based filter.
LineBasedBlockFilter(String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.LineBasedBlockFilter
 
LineBasedReplaceRegexTransformer - Class in com.wavefront.agent.preprocessor
Replace regex transformer.
LineBasedReplaceRegexTransformer(String, String, String, Integer, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.LineBasedReplaceRegexTransformer
 
LineDelimitedDataSubmissionTask - Class in com.wavefront.agent.data
A DataSubmissionTask that handles plaintext payloads in the newline-delimited format.
LineDelimitedDataSubmissionTask(ProxyV2API, UUID, EntityProperties, TaskQueue<LineDelimitedDataSubmissionTask>, String, ReportableEntityType, String, List<String>, Supplier<Long>) - Constructor for class com.wavefront.agent.data.LineDelimitedDataSubmissionTask
 
LineDelimitedUtils - Class in com.wavefront.agent.handlers
A collection of helper methods around plaintext newline-delimited payloads.
listen() - Method in class org.logstash.beats.Server
 
listeners - Variable in class com.wavefront.agent.PushAgent
 
loadFile(String) - Method in class com.wavefront.agent.preprocessor.PreprocessorConfigManager
 
loadLogsIngestionConfig() - Method in class com.wavefront.agent.AbstractAgent
 
log(Level, String) - Method in class com.wavefront.common.DelegatingLogger
 
log(Level, String) - Method in class com.wavefront.common.MessageDedupingLogger
 
log(Level, String) - Method in class com.wavefront.common.SamplingLogger
Checks the logger state and writes the message in the log if appropriate.
log(Level, String) - Method in class com.wavefront.common.SharedRateLimitingLogger
 
log(Level, Supplier<String>) - Method in class com.wavefront.common.SharedRateLimitingLogger
 
log(LogRecord) - Method in class com.wavefront.common.DelegatingLogger
 
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.listeners.tracing.JaegerGrpcCollectorHandler
 
logger - Static variable in class com.wavefront.agent.listeners.tracing.JaegerPortUnificationHandler
 
logger - Static variable in class com.wavefront.agent.listeners.tracing.JaegerProtobufUtils
 
logger - Static variable in class com.wavefront.agent.listeners.tracing.JaegerTChannelCollectorHandler
 
logger - Static variable in class com.wavefront.agent.listeners.tracing.JaegerThriftUtils
 
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
 
logger - Static variable in class com.wavefront.agent.queueing.QueueProcessor
 
LogsIngester - Class in com.wavefront.agent.logsharvesting
Consumes log messages sent to LogsIngester.ingestLog(LogsMessage).
LogsIngester(ReportableEntityHandlerFactory, Supplier<LogsIngestionConfig>, String) - Constructor for class com.wavefront.agent.logsharvesting.LogsIngester
Create an instance using system clock.
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
 
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.AbstractPortUnificationHandler
Log a detailed error message with remote IP address
LZ4 - com.wavefront.agent.queueing.TaskConverter.CompressionType
 

M

main(String[]) - Static method in class com.wavefront.agent.PushAgent
 
main(String[]) - Static method in class org.logstash.beats.Runner
 
makeKey(ReportPoint, Granularity) - Static method in class com.wavefront.agent.histogram.HistogramUtils
Generates a HistogramKey according a prototype ReportPoint and Granularity.
makeResponse(HttpResponseStatus, Object) - Static method in class com.wavefront.agent.channel.ChannelUtils
Create FullHttpResponse based on provided status and body contents.
MalformedMessageException - Exception in com.wavefront.agent.logsharvesting
 
Managed - Interface in com.wavefront.common
Background process that can be started and stopped.
managedExecutors - Variable in class com.wavefront.agent.AbstractAgent
 
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.Message
 
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(long, double, double) - Constructor for class com.wavefront.agent.histogram.MapSettings
 
MEMORY - com.wavefront.agent.data.TaskQueueLevel
 
MEMORY_PRESSURE - com.wavefront.agent.data.QueueingReason
 
merge(Preprocessor<T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Create a new preprocessor with rules merged from this and another preprocessor.
merge(ReportableEntityPreprocessor) - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
 
mergeHistogram(TDigest, Histogram) - Static method in class com.wavefront.agent.histogram.HistogramUtils
Merges a histogram into a TDigest
Message - Class in org.logstash.beats
 
Message(int, ByteBuf) - Constructor for class org.logstash.beats.Message
Create a message using a ByteBuf holding a Json object.
Message(int, Map) - Constructor for class org.logstash.beats.Message
Create a message using a map of key, value pairs
MessageDedupingLogger - Class in com.wavefront.common
A logger that suppresses identical messages for a specified period of time.
MessageDedupingLogger(Logger, long, double) - Constructor for class com.wavefront.common.MessageDedupingLogger
 
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
 
metric - Variable in class com.wavefront.common.HostMetricTagsPair
 
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
 
MetricsReporter - Class in com.wavefront.agent.logsharvesting
 
MetricsReporter(MetricsRegistry, FlushProcessor, String, ReportableEntityHandlerFactory, String) - Constructor for class com.wavefront.agent.logsharvesting.MetricsReporter
 
MINUTE - com.wavefront.agent.histogram.Granularity
 

N

NEVER - com.wavefront.agent.data.TaskQueueLevel
 
newDigest() - Method in class com.wavefront.agent.histogram.accumulator.AgentDigestFactory
 
NO_RATE_LIMIT - Static variable in interface com.wavefront.agent.data.EntityProperties
 
NONE - com.wavefront.agent.auth.TokenValidationMethod
 
NONE - com.wavefront.agent.queueing.TaskConverter.CompressionType
 
NoopEventAPI - Class in com.wavefront.agent.api
A no-op SourceTagAPI stub.
NoopEventAPI() - Constructor for class com.wavefront.agent.api.NoopEventAPI
 
NoopHealthCheckManager - Class in com.wavefront.agent.channel
A no-op health check manager.
NoopHealthCheckManager() - Constructor for class com.wavefront.agent.channel.NoopHealthCheckManager
 
NoopProxyV2API - Class in com.wavefront.agent.api
Partial ProxyV2API wrapper stub that passed proxyCheckin/proxyConfigProcessed calls to the delegate and replaces proxyReport/proxyError with a no-op.
NoopProxyV2API(ProxyV2API) - Constructor for class com.wavefront.agent.api.NoopProxyV2API
 
NoopSourceTagAPI - Class in com.wavefront.agent.api
A no-op SourceTagAPI stub.
NoopSourceTagAPI() - Constructor for class com.wavefront.agent.api.NoopSourceTagAPI
 

O

OAUTH2 - com.wavefront.agent.auth.TokenValidationMethod
 
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.
OpenTSDBPortUnificationHandler - Class in com.wavefront.agent.listeners
This class handles both OpenTSDB JSON and OpenTSDB plaintext protocol.
OpenTSDBPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityDecoder<String, ReportPoint>, ReportableEntityHandlerFactory, Supplier<ReportableEntityPreprocessor>, Function<InetAddress, String>) - Constructor for class com.wavefront.agent.listeners.OpenTSDBPortUnificationHandler
 
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
parse(String) - Static method in enum com.wavefront.agent.formatter.DataFormat
 
parseArguments(String[], String) - Method in class com.wavefront.agent.ProxyConfig
Parse commandline arguments into ProxyConfig object.
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
 
payload - Variable in class com.wavefront.agent.data.LineDelimitedDataSubmissionTask
 
payload() - Method in class com.wavefront.agent.data.EventDataSubmissionTask
 
payload() - Method in class com.wavefront.agent.data.LineDelimitedDataSubmissionTask
 
payload() - Method in class com.wavefront.agent.data.SourceTagSubmissionTask
 
peek() - Method in class com.wavefront.agent.queueing.FileBasedTaskQueue
 
peek() - Method in class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
peek() - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
peek() - Method in class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 
peek() - Method in interface com.wavefront.agent.queueing.TaskQueue
Retrieve a task that is currently at the head of the queue.
peek() - Method in class com.wavefront.agent.queueing.TaskQueueStub
 
PERSISTED - com.wavefront.agent.data.TaskResult
 
PERSISTED_RETRY - com.wavefront.agent.data.TaskResult
 
PlainTextOrHttpFrameDecoder - Class in com.wavefront.agent.channel
This class handles 2 different protocols on a single port.
PlainTextOrHttpFrameDecoder(ChannelHandler, int, int) - Constructor for class com.wavefront.agent.channel.PlainTextOrHttpFrameDecoder
 
pointFromKeyAndDigest(HistogramKey, AgentDigest) - Static method in class com.wavefront.agent.histogram.HistogramUtils
Creates a ReportPoint from a HistogramKey - AgentDigest pair
PointHandlerDispatcher - Class in com.wavefront.agent.histogram
Dispatch task for marshalling "ripe" digests for shipment to the agent to a point handler.
PointHandlerDispatcher(Accumulator, ReportableEntityHandler<ReportPoint, String>, TimeProvider, Supplier<Boolean>, Integer, Granularity) - Constructor for class com.wavefront.agent.histogram.PointHandlerDispatcher
 
pointsDiscarded - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 
postSpans(Collector.PostSpansRequest, StreamObserver<Collector.PostSpansResponse>) - Method in class com.wavefront.agent.listeners.tracing.JaegerGrpcCollectorHandler
 
Predicates - Class in com.wavefront.agent.preprocessor
Collection of helper methods Base factory class for predicates; supports both text parsing as well as YAML logic.
preprocessAndHandlePoint(String, ReportableEntityDecoder<String, ReportPoint>, ReportableEntityHandler<ReportPoint, String>, Supplier<ReportableEntityPreprocessor>, ChannelHandlerContext, String) - Static method in class com.wavefront.agent.listeners.WavefrontPortUnificationHandler
 
preprocessAndHandleSpan(String, ReportableEntityDecoder<String, Span>, ReportableEntityHandler<Span, String>, Consumer<Span>, Supplier<ReportableEntityPreprocessor>, ChannelHandlerContext, Function<Span, Boolean>) - Static method in class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
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
 
Preprocessor(List<Function<T, T>>, List<AnnotatedPredicate<T>>) - Constructor for class com.wavefront.agent.preprocessor.Preprocessor
 
PreprocessorConfigManager - Class in com.wavefront.agent.preprocessor
Parses preprocessor rules (organized by listening port) Created by Vasily on 9/15/16.
PreprocessorConfigManager() - Constructor for class com.wavefront.agent.preprocessor.PreprocessorConfigManager
 
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
 
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
 
privateCertPath - Variable in class com.wavefront.agent.ProxyConfig
 
privateKeyPath - Variable in class com.wavefront.agent.ProxyConfig
 
processBatch(Batch, StringBuilder, String, String, ReportableEntityHandler<Span, String>, ReportableEntityHandler<SpanLogs, String>, WavefrontInternalReporter, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, SpanSampler, Set<String>, Counter, Counter, Counter, Set<Pair<Map<String, String>, String>>) - Static method in class com.wavefront.agent.listeners.tracing.JaegerThriftUtils
 
processBatch(Model.Batch, StringBuilder, String, String, ReportableEntityHandler<Span, String>, ReportableEntityHandler<SpanLogs, String>, WavefrontInternalReporter, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, SpanSampler, Set<String>, Counter, Counter, Counter, Set<Pair<Map<String, String>, String>>) - Static method in class com.wavefront.agent.listeners.tracing.JaegerProtobufUtils
 
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, FlushProcessorContext) - Method in class com.wavefront.agent.logsharvesting.FlushProcessor
 
processCounter(MetricName, Counter, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processGauge(MetricName, Gauge<?>, FlushProcessorContext) - Method in class com.wavefront.agent.logsharvesting.FlushProcessor
 
processGauge(MetricName, Gauge<?>, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processHistogram(MetricName, Histogram, FlushProcessorContext) - Method in class com.wavefront.agent.logsharvesting.FlushProcessor
 
processHistogram(MetricName, Histogram, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processLine(ChannelHandlerContext, String, DataFormat) - Method in class com.wavefront.agent.listeners.AbstractLineDelimitedHandler
Process a single line for a line-based stream.
processLine(ChannelHandlerContext, String, DataFormat) - Method in class com.wavefront.agent.listeners.RawLogsIngesterPortUnificationHandler
 
processLine(ChannelHandlerContext, String, DataFormat) - Method in class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
processLine(ChannelHandlerContext, String, DataFormat) - Method in class com.wavefront.agent.listeners.WavefrontPortUnificationHandler
 
processMeter(MetricName, Metered, FlushProcessorContext) - Method in class com.wavefront.agent.logsharvesting.FlushProcessor
 
processMeter(MetricName, Metered, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processorTasks - Variable in class com.wavefront.agent.queueing.QueueController
 
processTimer(MetricName, Timer, FlushProcessorContext) - Method in class com.wavefront.agent.logsharvesting.FlushProcessor
 
processTimer(MetricName, Timer, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
Protocol - Class in org.logstash.beats
Created by ph on 2016-05-16.
Protocol() - Constructor for class org.logstash.beats.Protocol
 
proxyCheckin(UUID, String, String, String, Long, JsonNode, Boolean) - Method in class com.wavefront.agent.api.NoopProxyV2API
 
proxyCheckinScheduler - Variable in class com.wavefront.agent.AbstractAgent
 
ProxyCheckInScheduler - Class in com.wavefront.agent
Registers the proxy with the back-end, sets up regular "check-ins" (every minute), transmits proxy metrics to the back-end.
ProxyCheckInScheduler(UUID, ProxyConfig, APIContainer, Consumer<AgentConfiguration>, Runnable) - Constructor for class com.wavefront.agent.ProxyCheckInScheduler
 
proxyConfig - Variable in class com.wavefront.agent.AbstractAgent
 
ProxyConfig - Class in com.wavefront.agent
Proxy configuration (refactored from AbstractAgent).
ProxyConfig() - Constructor for class com.wavefront.agent.ProxyConfig
 
ProxyConfig.TaskQueueLevelConverter - Class in com.wavefront.agent
 
ProxyConfig.TokenValidationMethodConverter - Class in com.wavefront.agent
 
proxyConfigProcessed(UUID) - Method in class com.wavefront.agent.api.NoopProxyV2API
 
proxyError(UUID, String) - Method in class com.wavefront.agent.api.NoopProxyV2API
 
proxyEvents(UUID, List<Event>) - Method in class com.wavefront.agent.api.NoopEventAPI
 
ProxyMemoryGuard - Class in com.wavefront.agent
Logic around OoM protection logic that drains memory buffers on MEMORY_THRESHOLD_EXCEEDED notifications, extracted from AbstractAgent.
ProxyMemoryGuard(Runnable, double) - Constructor for class com.wavefront.agent.ProxyMemoryGuard
Set up the memory guard.
proxyReport(UUID, String, String) - Method in class com.wavefront.agent.api.NoopProxyV2API
 
PushAgent - Class in com.wavefront.agent
Push-only Agent.
PushAgent() - Constructor for class com.wavefront.agent.PushAgent
 
PUSHBACK - com.wavefront.agent.data.QueueingReason
 
PUSHBACK - com.wavefront.agent.data.TaskQueueLevel
 
put(HistogramKey, double) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Update AgentDigest in the cache with a double value.
put(HistogramKey, double) - Method in interface com.wavefront.agent.histogram.accumulator.Accumulator
Update AgentDigest in the cache with a double value.
put(HistogramKey, AgentDigest) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Update AgentDigest in the cache with another AgentDigest.
put(HistogramKey, AgentDigest) - Method in interface com.wavefront.agent.histogram.accumulator.Accumulator
Update AgentDigest in the cache with another AgentDigest.
put(HistogramKey, Histogram) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Update AgentDigest in the cache with a Histogram value.
put(HistogramKey, Histogram) - Method in interface com.wavefront.agent.histogram.accumulator.Accumulator
Update AgentDigest in the cache with a Histogram value.

Q

quantile(double) - Method in class com.tdunning.math.stats.AgentDigest
 
QueueController<T extends DataSubmissionTask<T>> - Class in com.wavefront.agent.queueing
A queue controller (one per entity/port).
QueueController(HandlerKey, List<QueueProcessor<T>>, Consumer<Integer>) - Constructor for class com.wavefront.agent.queueing.QueueController
 
QueueExporter - Class in com.wavefront.agent.queueing
Supports proxy's ability to export data from buffer files.
QueueExporter(ProxyConfig, TaskQueueFactory, EntityPropertiesFactory) - Constructor for class com.wavefront.agent.queueing.QueueExporter
 
queueingFactory - Variable in class com.wavefront.agent.PushAgent
 
QueueingFactory - Interface in com.wavefront.agent.queueing
Factory for QueueProcessor instances.
QueueingFactoryImpl - Class in com.wavefront.agent.queueing
A caching implementation of QueueingFactory.
QueueingFactoryImpl(APIContainer, UUID, TaskQueueFactory, EntityPropertiesFactory) - Constructor for class com.wavefront.agent.queueing.QueueingFactoryImpl
 
QueueingReason - Enum in com.wavefront.agent.data
Additional context to help understand why a certain batch was queued.
QueueProcessor<T extends DataSubmissionTask<T>> - Class in com.wavefront.agent.queueing
A thread responsible for processing the backlog from a single task queue.
QueueProcessor(HandlerKey, TaskQueue<T>, TaskInjector<T>, ScheduledExecutorService, EntityProperties) - Constructor for class com.wavefront.agent.queueing.QueueProcessor
 

R

rateLimiter - Variable in class com.wavefront.agent.queueing.QueueProcessor
 
rateSampler - Variable in class com.wavefront.agent.PushAgent
 
RawLogsIngesterPortUnificationHandler - Class in com.wavefront.agent.listeners
Process incoming logs in raw plaintext format.
RawLogsIngesterPortUnificationHandler(String, LogsIngester, Function<InetAddress, String>, TokenAuthenticator, HealthCheckManager, Supplier<ReportableEntityPreprocessor>) - Constructor for class com.wavefront.agent.listeners.RawLogsIngesterPortUnificationHandler
Create new instance.
read(Bytes, long, AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
read(Bytes, HistogramKey) - Method in class com.wavefront.agent.histogram.HistogramUtils.HistogramKeyMarshaller
 
readMarshallable(WireIn) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
readMarshallable(WireIn) - Method in class com.wavefront.agent.histogram.HistogramUtils.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.HistogramUtils.HistogramKeyMarshaller
 
recordAllData() - Method in class com.tdunning.math.stats.AgentDigest
Turns on internal data recording.
reject(String, String) - 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.
RelayPortUnificationHandler - Class in com.wavefront.agent.listeners
A unified HTTP endpoint for mixed format data.
RelayPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, Map<ReportableEntityType, ReportableEntityDecoder<?, ?>>, ReportableEntityHandlerFactory, Supplier<ReportableEntityPreprocessor>, SharedGraphiteHostAnnotator, Supplier<Boolean>, Supplier<Boolean>, Supplier<Boolean>) - Constructor for class com.wavefront.agent.listeners.RelayPortUnificationHandler
Create new instance with lazy initialization for handlers.
release() - Method in interface org.logstash.beats.Batch
Release the resources associated with the batch.
release() - Method in class org.logstash.beats.V1Batch
 
release() - Method in class org.logstash.beats.V2Batch
 
remoteHostAnnotator - Variable in class com.wavefront.agent.PushAgent
 
remove() - Method in class com.wavefront.agent.queueing.FileBasedTaskQueue
 
remove() - Method in class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
remove() - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
remove() - Method in class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 
remove() - Method in interface com.wavefront.agent.queueing.TaskQueue
Remove a task from the head of the queue.
remove() - Method in class com.wavefront.agent.queueing.TaskQueueStub
 
removeDescription(String) - Method in class com.wavefront.agent.api.NoopSourceTagAPI
 
removeTag(String, String) - Method in class com.wavefront.agent.api.NoopSourceTagAPI
 
report(T) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
Validate and accept the input object.
report(Span) - Method in class com.wavefront.agent.listeners.tracing.CustomTracingPortUnificationHandler
 
report(Span) - Method in class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
Report span and derived metrics if needed.
ReportableConfig - Class in com.wavefront.agent.config
Wrapper class to simplify access to .properties file + track values as metrics as they are retrieved
ReportableConfig() - Constructor for class com.wavefront.agent.config.ReportableConfig
 
ReportableConfig(String) - Constructor for class com.wavefront.agent.config.ReportableConfig
 
ReportableEntityHandler<T,​U> - 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, ValidationConfiguration, Logger, Logger, Logger, Function<Histogram, Histogram>, EntityPropertiesFactory) - 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
 
reportBacklogSize(String, int) - Method in interface com.wavefront.agent.data.EntityProperties
Updates backlog size for specific port.
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) - Static method in class com.wavefront.agent.config.ReportableConfig
 
reportGauge(Supplier<Number>, MetricName) - Static method in class com.wavefront.agent.config.ReportableConfig
 
reportInternal(ReportEvent) - Method in class com.wavefront.agent.handlers.EventHandlerImpl
 
reportInternal(ReportPoint) - Method in class com.wavefront.agent.handlers.HistogramAccumulationHandlerImpl
 
reportInternal(Span) - Method in class com.wavefront.agent.handlers.SpanHandlerImpl
 
reportInternal(SpanLogs) - Method in class com.wavefront.agent.handlers.SpanLogsHandlerImpl
 
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, Predicate<ReportPoint>, 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, Predicate<ReportPoint>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
ReportPointAllowFilter - Class in com.wavefront.agent.preprocessor
"Allow list" regex filter.
ReportPointAllowFilter(String, String, Predicate<ReportPoint>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAllowFilter
 
ReportPointBlockFilter - Class in com.wavefront.agent.preprocessor
Blocking regex-based filter.
ReportPointBlockFilter(String, String, Predicate<ReportPoint>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointBlockFilter
 
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, Predicate<ReportPoint>, 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, String, Predicate<ReportPoint>, 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, String, Predicate<ReportPoint>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
ReportPointForceLowercaseTransformer - Class in com.wavefront.agent.preprocessor
Force lowercase transformer.
ReportPointForceLowercaseTransformer(String, String, Predicate<ReportPoint>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointForceLowercaseTransformer
 
ReportPointLimitLengthTransformer - Class in com.wavefront.agent.preprocessor
 
ReportPointLimitLengthTransformer(String, int, LengthLimitActionType, String, Predicate<ReportPoint>, 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, Predicate<ReportPoint>, 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, Predicate<ReportPoint>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointReplaceRegexTransformer
 
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
 
reportRateLimiter - Variable in class com.wavefront.agent.queueing.QueueController
 
reportReceivedRate(String, long) - Method in interface com.wavefront.agent.data.EntityProperties
Updates received rate for specific port.
reportSettingAsGauge(Supplier<Number>, String) - Static method in class com.wavefront.agent.config.ReportableConfig
 
requestsDiscarded - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 
RETRY - com.wavefront.agent.data.QueueingReason
 
RETRY_LATER - com.wavefront.agent.data.TaskResult
 
RetryTaskConverter<T extends DataSubmissionTask<T>> - Class in com.wavefront.agent.queueing
A serializer + deserializer of DataSubmissionTask objects for storage.
RetryTaskConverter(String, TaskConverter.CompressionType) - Constructor for class com.wavefront.agent.queueing.RetryTaskConverter
 
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.handlers.TrafficShapingRateLimitAdjuster
 
run() - Method in class com.wavefront.agent.histogram.PointHandlerDispatcher
 
run() - Method in class com.wavefront.agent.listeners.tracing.JaegerGrpcCollectorHandler
 
run() - Method in class com.wavefront.agent.listeners.tracing.JaegerPortUnificationHandler
 
run() - Method in class com.wavefront.agent.listeners.tracing.JaegerTChannelCollectorHandler
 
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.queueing.QueueController
 
run() - Method in class com.wavefront.agent.queueing.QueueProcessor
 
Runner - Class in org.logstash.beats
 
Runner() - Constructor for class org.logstash.beats.Runner
 
runtimeProperties - Variable in class com.wavefront.agent.queueing.QueueProcessor
 

S

sample(Span) - Method in class com.wavefront.agent.sampler.SpanSampler
Evaluates whether a span should be allowed or discarded.
sample(Span, Counter) - Method in class com.wavefront.agent.sampler.SpanSampler
Evaluates whether a span should be allowed or discarded, and increment a counter if it should be discarded.
SamplingLogger - Class in com.wavefront.common
A sampling logger that can be enabled and disabled dynamically by setting its level to Level.FINEST.
SamplingLogger(ReportableEntityType, Logger, double, boolean, Consumer<String>) - Constructor for class com.wavefront.common.SamplingLogger
 
scheduleCheckins() - Method in class com.wavefront.agent.ProxyCheckInScheduler
Set up and schedule regular check-ins.
scheduler - Variable in class com.wavefront.agent.queueing.QueueProcessor
 
scheduleTaskForSizing(T) - Method in class com.wavefront.agent.queueing.TaskSizeEstimator
Submit a candidate task to be sized.
secureAllPorts - Variable in class com.wavefront.agent.AbstractAgent
 
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 - Variable in class com.wavefront.agent.PushAgent
 
SenderTaskFactory - Interface in com.wavefront.agent.handlers
Factory for SenderTask objects.
SenderTaskFactoryImpl - Class in com.wavefront.agent.handlers
Factory for SenderTask objects.
SenderTaskFactoryImpl(APIContainer, UUID, TaskQueueFactory, QueueingFactory, EntityPropertiesFactory) - Constructor for class com.wavefront.agent.handlers.SenderTaskFactoryImpl
Create new instance.
sendFormattedMetric(String) - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
 
sendKeepAlive(ChannelHandlerContext) - Method in class org.logstash.beats.ConnectionHandler
Determine if this channel has finished processing it's payload.
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
 
serializeToStream(T, OutputStream) - Method in class com.wavefront.agent.queueing.RetryTaskConverter
 
serializeToStream(T, OutputStream) - Method in interface com.wavefront.agent.queueing.TaskConverter
Serializes value to bytes written to the specified stream.
Server - Class in org.logstash.beats
 
Server(String, int, int, int) - Constructor for class org.logstash.beats.Server
 
setAdditionalPatterns(Map<String, String>) - Method in class com.wavefront.agent.config.MetricMatcher
 
setAllHealthy() - Method in interface com.wavefront.agent.channel.HealthCheckManager
 
setAllHealthy() - Method in class com.wavefront.agent.channel.HealthCheckManagerImpl
 
setAllHealthy() - Method in class com.wavefront.agent.channel.NoopHealthCheckManager
 
setAllUnhealthy() - Method in interface com.wavefront.agent.channel.HealthCheckManager
 
setAllUnhealthy() - Method in class com.wavefront.agent.channel.HealthCheckManagerImpl
 
setAllUnhealthy() - Method in class com.wavefront.agent.channel.NoopHealthCheckManager
 
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 interface org.logstash.beats.Batch
Set the number of messages that the batch is expected to contain.
setBatchSize(int) - Method in class org.logstash.beats.V1Batch
 
setBatchSize(int) - Method in class org.logstash.beats.V2Batch
 
setCertificateAuthorities(String[]) - Method in class org.logstash.netty.SslSimpleBuilder
 
setCipherSuites(String[]) - Method in class org.logstash.netty.SslSimpleBuilder
 
setDescription(String, String) - Method in class com.wavefront.agent.api.NoopSourceTagAPI
 
setDropSpansDelayedMinutes(Integer) - Method in interface com.wavefront.agent.data.EntityProperties.GlobalProperties
Set the maximum acceptable duration between now and the end of a span to be accepted for reporting to Wavefront, beyond which they are dropped.
setFeatureDisabled(boolean) - Method in interface com.wavefront.agent.data.EntityProperties
Sets the flag value for "feature disabled" flag.
setHandshakeTimeoutMilliseconds(int) - Method in class org.logstash.netty.SslSimpleBuilder
 
setHealthy(int) - Method in interface com.wavefront.agent.channel.HealthCheckManager
 
setHealthy(int) - Method in class com.wavefront.agent.channel.HealthCheckManagerImpl
 
setHealthy(int) - Method in class com.wavefront.agent.channel.NoopHealthCheckManager
 
setHistogramStorageAccuracy(short) - Method in interface com.wavefront.agent.data.EntityProperties.GlobalProperties
Sets histogram storage accuracy.
setHttpClient(HttpClient) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
setItemsPerBatch(Integer) - Method in interface com.wavefront.agent.data.EntityProperties
Sets the maximum allowed number of items per single flush.
setMessageListener(IMessageListener) - Method in class org.logstash.beats.Server
 
setProtocol(byte) - Method in class org.logstash.beats.V1Batch
 
setProtocol(byte) - Method in class org.logstash.beats.V2Batch
 
setProtocols(String[]) - Method in class org.logstash.netty.SslSimpleBuilder
 
setRetryBackoffBaseSeconds(Double) - Method in interface com.wavefront.agent.data.EntityProperties.GlobalProperties
Sets base in seconds for retry thread exponential backoff.
setStaticToken(String) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
 
setTags(String, List<String>) - Method in class com.wavefront.agent.api.NoopSourceTagAPI
 
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
 
setTraceSamplingRate(Double) - Method in interface com.wavefront.agent.data.EntityProperties.GlobalProperties
Sets the sampling rate for tracing spans.
setUnhealthy(int) - Method in interface com.wavefront.agent.channel.HealthCheckManager
 
setUnhealthy(int) - Method in class com.wavefront.agent.channel.HealthCheckManagerImpl
 
setUnhealthy(int) - Method in class com.wavefront.agent.channel.NoopHealthCheckManager
 
setUpConfigFileMonitoring(String, int) - Method in class com.wavefront.agent.preprocessor.PreprocessorConfigManager
Schedules periodic checks for config file modification timestamp and performs hot-reload
setupMemoryGuard() - Method in class com.wavefront.agent.PushAgent
 
setValue(T) - Method in class com.wavefront.agent.logsharvesting.ChangeableGauge
 
setVerifyMode(SslSimpleBuilder.SslClientVerifyMode) - Method in class org.logstash.netty.SslSimpleBuilder
 
SharedGraphiteHostAnnotator - Class in com.wavefront.agent.channel
Given a raw Graphite/Wavefront line, look for any host tag, and add it if implicit.
SharedGraphiteHostAnnotator(List<String>, Function<InetAddress, String>) - Constructor for class com.wavefront.agent.channel.SharedGraphiteHostAnnotator
 
SharedMetricsRegistry - Class in com.wavefront.agent
 
SharedRateLimitingLogger - Class in com.wavefront.common
A rate-limiting logger that can be shared between multiple threads that use the same context key.
SharedRateLimitingLogger(Logger, String, double) - Constructor for class com.wavefront.common.SharedRateLimitingLogger
 
shutdown() - Method in class com.wavefront.agent.AbstractAgent
Best-effort graceful shutdown.
shutdown() - Method in class com.wavefront.agent.handlers.DeltaCounterAccumulationHandlerImpl
 
shutdown() - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
Gracefully shutdown the pipeline.
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.ProxyCheckInScheduler
Stops regular check-ins.
shutdown() - Method in class com.wavefront.agent.queueing.TaskSizeEstimator
 
shutdown(String) - Method in class com.wavefront.agent.handlers.DelegatingReportableEntityHandlerFactoryImpl
 
shutdown(String) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandlerFactory
Shutdown pipeline for a specific handle.
shutdown(String) - Method in class com.wavefront.agent.handlers.ReportableEntityHandlerFactoryImpl
 
shutdown(String) - Method in interface com.wavefront.agent.handlers.SenderTaskFactory
Shut down specific pipeline
shutdown(String) - Method in class com.wavefront.agent.handlers.SenderTaskFactoryImpl
 
shutdownTasks - Variable in class com.wavefront.agent.AbstractAgent
 
shuttingDown - Variable in class com.wavefront.agent.AbstractAgent
 
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 interface com.wavefront.agent.histogram.accumulator.Accumulator
Returns the number of items in the storage behind the cache
size() - Method in class com.wavefront.agent.queueing.FileBasedTaskQueue
 
size() - Method in class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
size() - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
size() - Method in class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 
size() - Method in interface com.wavefront.agent.queueing.TaskQueue
Returns a number of tasks currently in the queue.
size() - Method in class com.wavefront.agent.queueing.TaskQueueStub
 
size() - Method in interface org.logstash.beats.Batch
Current number of messages in the batch
size() - Method in class org.logstash.beats.V1Batch
 
size() - Method in class org.logstash.beats.V2Batch
 
size(AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
smallByteSize() - Method in class com.tdunning.math.stats.AgentDigest
 
source - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
SOURCE_TAG - com.wavefront.agent.formatter.DataFormat
 
SourceTagSubmissionTask - Class in com.wavefront.agent.data
A DataSubmissionTask that handles source tag payloads.
SourceTagSubmissionTask(SourceTagAPI, EntityProperties, TaskQueue<SourceTagSubmissionTask>, String, SourceTag, Supplier<Long>) - Constructor for class com.wavefront.agent.data.SourceTagSubmissionTask
 
SPAN - com.wavefront.agent.formatter.DataFormat
 
SPAN_DISABLED - Static variable in class com.wavefront.agent.listeners.FeatureCheckUtils
 
SPAN_LOG - com.wavefront.agent.formatter.DataFormat
 
SpanAddAnnotationIfNotExistsTransformer - Class in com.wavefront.agent.preprocessor
Creates a new annotation with a specified key/value pair.
SpanAddAnnotationIfNotExistsTransformer(String, String, Predicate<Span>, 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, Predicate<Span>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanAddAnnotationTransformer
 
SpanAllowAnnotationTransformer - Class in com.wavefront.agent.preprocessor
Only allow span annotations that match the allowed list.
SpanAllowFilter - Class in com.wavefront.agent.preprocessor
"Allow list" regex filter.
SpanAllowFilter(String, String, Predicate<Span>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanAllowFilter
 
SpanBlockFilter - Class in com.wavefront.agent.preprocessor
Blocking regex-based filter.
SpanBlockFilter(String, String, Predicate<Span>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanBlockFilter
 
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, Predicate<Span>, 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, Predicate<Span>, 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, Predicate<Span>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
SpanForceLowercaseTransformer - Class in com.wavefront.agent.preprocessor
Force lowercase transformer.
SpanForceLowercaseTransformer(String, String, boolean, Predicate<Span>, 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, Predicate<Span>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanLimitLengthTransformer
 
SPANLOGS_DISABLED - Static variable in class com.wavefront.agent.listeners.FeatureCheckUtils
 
SpanLogsHandlerImpl - Class in com.wavefront.agent.handlers
Handler that processes incoming SpanLogs objects, validates them and hands them over to one of the SenderTask threads.
SpanRenameAnnotationTransformer - Class in com.wavefront.agent.preprocessor
Rename a given span tag's/annotation's (optional: if its value matches a regex pattern) If the tag matches multiple span annotation keys , all keys will be renamed.
SpanRenameAnnotationTransformer(String, String, String, boolean, Predicate<Span>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanRenameAnnotationTransformer
 
SpanReplaceRegexTransformer - Class in com.wavefront.agent.preprocessor
Replace regex transformer.
SpanReplaceRegexTransformer(String, String, String, String, Integer, boolean, Predicate<Span>, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanReplaceRegexTransformer
 
SpanSampler - Class in com.wavefront.agent.sampler
Sampler that takes a Span as input and delegates to a Sampler when evaluating the sampling decision.
SpanSampler(Sampler, boolean) - Constructor for class com.wavefront.agent.sampler.SpanSampler
Creates a new instance from a delegate.
SpanSamplerUtils - Class in com.wavefront.agent.sampler
Helper class for creating span samplers.
SpanSamplerUtils() - Constructor for class com.wavefront.agent.sampler.SpanSamplerUtils
 
SpanSanitizeTransformer - Class in com.wavefront.agent.preprocessor
Sanitize spans (e.g., span source and tag keys) according to the same rules that are applied at the SDK-level.
SpanSanitizeTransformer(PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanSanitizeTransformer
 
SPLIT - com.wavefront.agent.data.QueueingReason
 
splitPushData(String) - Static method in class com.wavefront.agent.handlers.LineDelimitedUtils
Deprecated.
splitTask(int, int) - Method in interface com.wavefront.agent.data.DataSubmissionTask
Split the task into smaller tasks.
splitTask(int, int) - Method in class com.wavefront.agent.data.EventDataSubmissionTask
 
splitTask(int, int) - Method in class com.wavefront.agent.data.LineDelimitedDataSubmissionTask
 
splitTask(int, int) - Method in class com.wavefront.agent.data.SourceTagSubmissionTask
 
SQSQueueFactoryImpl - Class in com.wavefront.agent.queueing
An AmazonSQS implementation of TaskQueueFactory
SQSQueueFactoryImpl(String, String, String, boolean) - Constructor for class com.wavefront.agent.queueing.SQSQueueFactoryImpl
 
SQSSubmissionQueue<T extends DataSubmissionTask<T>> - Class in com.wavefront.agent.queueing
Implements proxy-specific queue interface as a wrapper over AmazonSQS
SQSSubmissionQueue(String, AmazonSQS, TaskConverter<T>) - Constructor for class com.wavefront.agent.queueing.SQSSubmissionQueue
 
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.AbstractAgent
 
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
 
start() - Method in class com.wavefront.agent.handlers.TrafficShapingRateLimitAdjuster
 
start() - Method in class com.wavefront.agent.logsharvesting.LogsIngester
 
start() - Method in class com.wavefront.agent.queueing.QueueController
 
start() - Method in class com.wavefront.agent.queueing.QueueProcessor
 
start() - Method in class com.wavefront.agent.WavefrontProxyService
 
start() - Method in interface com.wavefront.common.Managed
Starts the process.
start(String[]) - Method in class com.wavefront.agent.AbstractAgent
Entry-point for the application.
startAdminListener(int) - Method in class com.wavefront.agent.PushAgent
 
startAsManagedThread(int, Runnable, String) - Method in class com.wavefront.agent.PushAgent
 
startCustomTracingListener(String, ReportableEntityHandlerFactory, WavefrontSender, SpanSampler) - Method in class com.wavefront.agent.PushAgent
 
startDataDogListener(String, ReportableEntityHandlerFactory, HttpClient) - Method in class com.wavefront.agent.PushAgent
 
startDeltaCounterListener(String, SharedGraphiteHostAnnotator, SenderTaskFactory, SpanSampler) - Method in class com.wavefront.agent.PushAgent
 
startGraphiteListener(String, ReportableEntityHandlerFactory, SharedGraphiteHostAnnotator, SpanSampler) - Method in class com.wavefront.agent.PushAgent
 
startHealthCheckListener(int) - Method in class com.wavefront.agent.PushAgent
 
startHistogramListeners(List<String>, ReportableEntityHandler<ReportPoint, String>, SharedGraphiteHostAnnotator, Granularity, int, boolean, File, Long, int, int, short, boolean, SpanSampler) - Method in class com.wavefront.agent.PushAgent
 
startJsonListener(String, ReportableEntityHandlerFactory) - Method in class com.wavefront.agent.PushAgent
 
startListeners() - Method in class com.wavefront.agent.AbstractAgent
Starts all listeners as configured.
startListeners() - Method in class com.wavefront.agent.PushAgent
 
startLogsIngestionListener(int, LogsIngester) - Method in class com.wavefront.agent.PushAgent
 
startOpenTsdbListener(String, ReportableEntityHandlerFactory) - Method in class com.wavefront.agent.PushAgent
 
startPickleListener(String, ReportableEntityHandlerFactory, GraphiteFormatter) - Method in class com.wavefront.agent.PushAgent
 
startRawLogsIngestionListener(int, LogsIngester) - Method in class com.wavefront.agent.PushAgent
 
startRelayListener(String, ReportableEntityHandlerFactory, SharedGraphiteHostAnnotator) - Method in class com.wavefront.agent.PushAgent
 
startTraceJaegerGrpcListener(String, ReportableEntityHandlerFactory, WavefrontSender, SpanSampler) - Method in class com.wavefront.agent.PushAgent
 
startTraceJaegerHttpListener(String, ReportableEntityHandlerFactory, WavefrontSender, SpanSampler) - Method in class com.wavefront.agent.PushAgent
 
startTraceJaegerListener(String, ReportableEntityHandlerFactory, WavefrontSender, SpanSampler) - Method in class com.wavefront.agent.PushAgent
 
startTraceListener(String, ReportableEntityHandlerFactory, SpanSampler) - Method in class com.wavefront.agent.PushAgent
 
startTraceZipkinListener(String, ReportableEntityHandlerFactory, WavefrontSender, SpanSampler) - Method in class com.wavefront.agent.PushAgent
 
startWriteHttpJsonListener(String, ReportableEntityHandlerFactory) - Method in class com.wavefront.agent.PushAgent
 
STATIC_TOKEN - com.wavefront.agent.auth.TokenValidationMethod
 
StatusTrackingHttpObjectAggregator - Class in com.wavefront.agent.channel
A HttpObjectAggregator that correctly tracks HTTP 413 returned for incoming payloads that are too large.
StatusTrackingHttpObjectAggregator(int) - Constructor for class com.wavefront.agent.channel.StatusTrackingHttpObjectAggregator
 
stop() - Method in class com.wavefront.agent.handlers.TrafficShapingRateLimitAdjuster
 
stop() - Method in class com.wavefront.agent.queueing.QueueController
 
stop() - Method in class com.wavefront.agent.queueing.QueueProcessor
 
stop() - Method in class com.wavefront.agent.WavefrontProxyService
 
stop() - Method in interface com.wavefront.common.Managed
Stops the process.
stop() - Method in class org.logstash.beats.Server
 
stopListener(int) - Method in class com.wavefront.agent.AbstractAgent
Shut down specific listener pipeline.
stopListener(int) - Method in class com.wavefront.agent.PushAgent
 
stopListeners() - Method in class com.wavefront.agent.AbstractAgent
Stops all listeners before terminating the process.
stopListeners() - Method in class com.wavefront.agent.PushAgent
 
SynchronizedTaskQueueWithMetrics<T extends DataSubmissionTask<T>> - Class in com.wavefront.agent.queueing
A thread-safe wrapper for TaskQueue that reports queue metrics.
SynchronizedTaskQueueWithMetrics(TaskQueue<T>, String, Map<String, String>, ReportableEntityType) - Constructor for class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 

T

tag - Variable in class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
tag - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
TaskConverter<T> - Interface in com.wavefront.agent.queueing
Proxy-specific interface for converting data into and from queues, this potentially allows us to support other converting mechanisms in the future.
TaskConverter.CompressionType - Enum in com.wavefront.agent.queueing
Supported compression schemas
taskInjector - Variable in class com.wavefront.agent.queueing.QueueProcessor
 
TaskInjector<T extends DataSubmissionTask<T>> - Interface in com.wavefront.agent.data
Class to inject non-serializable members into a DataSubmissionTask before execution
taskQueue - Variable in class com.wavefront.agent.queueing.QueueProcessor
 
TaskQueue<T extends DataSubmissionTask<T>> - Interface in com.wavefront.agent.queueing
Proxy-specific queue interface, which is basically a wrapper for a Tape queue.
taskQueueFactory - Variable in class com.wavefront.agent.PushAgent
 
TaskQueueFactory - Interface in com.wavefront.agent.queueing
A factory for TaskQueue objects.
TaskQueueFactoryImpl - Class in com.wavefront.agent.queueing
A caching implementation of a TaskQueueFactory.
TaskQueueFactoryImpl(String, boolean) - Constructor for class com.wavefront.agent.queueing.TaskQueueFactoryImpl
 
TaskQueueLevel - Enum in com.wavefront.agent.data
Controls conditions under which proxy would actually queue data.
TaskQueueLevelConverter() - Constructor for class com.wavefront.agent.ProxyConfig.TaskQueueLevelConverter
 
TaskQueueStub<T extends DataSubmissionTask<T>> - Class in com.wavefront.agent.queueing
A non-functional empty TaskQueue that throws an error when attempting to add a task.
TaskQueueStub() - Constructor for class com.wavefront.agent.queueing.TaskQueueStub
 
TaskResult - Enum in com.wavefront.agent.data
Possible outcomes of DataSubmissionTask execution
TaskSizeEstimator - Class in com.wavefront.agent.queueing
Calculates approximate task sizes to estimate how quickly we would run out of disk space if we are no longer able to send data to the server endpoint (i.e.
TaskSizeEstimator(String) - Constructor for class com.wavefront.agent.queueing.TaskSizeEstimator
 
test(String, String[]) - Method in class com.wavefront.agent.preprocessor.LineBasedAllowFilter
 
test(String, String[]) - Method in class com.wavefront.agent.preprocessor.LineBasedBlockFilter
 
test(T) - Method in interface com.wavefront.agent.preprocessor.AnnotatedPredicate
 
test(T, String[]) - Method in interface com.wavefront.agent.preprocessor.AnnotatedPredicate
 
test(ReportPoint, String[]) - Method in class com.wavefront.agent.preprocessor.ReportPointAllowFilter
 
test(ReportPoint, String[]) - Method in class com.wavefront.agent.preprocessor.ReportPointBlockFilter
 
test(ReportPoint, String[]) - Method in class com.wavefront.agent.preprocessor.ReportPointTimestampInRangeFilter
 
test(Span, String[]) - Method in class com.wavefront.agent.preprocessor.SpanAllowFilter
 
test(Span, String[]) - Method in class com.wavefront.agent.preprocessor.SpanBlockFilter
 
throwAny(Throwable) - Static method in class com.wavefront.common.Utils
Use this to throw checked exceptions from iterator methods that do not declare that they throw checked exceptions.
timeProvider - Variable in class com.wavefront.agent.queueing.QueueController
 
timer - Variable in class com.wavefront.agent.queueing.QueueController
 
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
 
tlsPorts - Variable in class com.wavefront.agent.AbstractAgent
 
tlsPorts - Variable in class com.wavefront.agent.ProxyConfig
 
toHistogram(int) - Method in class com.tdunning.math.stats.AgentDigest
Creates a reporting Histogram from this AgentDigest (marked with the supplied duration).
tokenAuthenticator - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
 
tokenAuthenticator - Variable in class com.wavefront.agent.PushAgent
 
TokenAuthenticator - Interface in com.wavefront.agent.auth
Token validator for processing incoming requests.
TokenAuthenticatorBuilder - Class in com.wavefront.agent.auth
Builder for TokenAuthenticator instances.
TokenValidationMethod - Enum in com.wavefront.agent.auth
Auth validation methods supported.
TokenValidationMethodConverter() - Constructor for class com.wavefront.agent.ProxyConfig.TokenValidationMethodConverter
 
toMetricName(TimeSeries) - Static method in class com.wavefront.agent.logsharvesting.TimeSeriesUtils
 
toString() - Method in class com.wavefront.agent.config.Configuration
 
toString() - Method in enum com.wavefront.agent.data.QueueingReason
 
toString() - Method in class com.wavefront.agent.handlers.HandlerKey
 
toString() - Method in enum com.wavefront.agent.histogram.Granularity
 
toString() - Method in class com.wavefront.agent.histogram.HistogramKey
 
toString() - Method in class com.wavefront.agent.histogram.MapLoader
 
toString() - Method in class com.wavefront.common.HostMetricTagsPair
 
toString() - Method in class org.logstash.beats.BatchIdentity
 
toStringId(ByteString) - Static method in class com.wavefront.agent.listeners.tracing.JaegerProtobufUtils
 
TracePortUnificationHandler - Class in com.wavefront.agent.listeners.tracing
Process incoming trace-formatted data.
TracePortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityDecoder<String, Span>, ReportableEntityDecoder<JsonNode, SpanLogs>, Supplier<ReportableEntityPreprocessor>, ReportableEntityHandler<Span, String>, ReportableEntityHandler<SpanLogs, String>, SpanSampler, Supplier<Boolean>, Supplier<Boolean>) - Constructor for class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
TracePortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityDecoder<String, Span>, ReportableEntityDecoder<JsonNode, SpanLogs>, Supplier<ReportableEntityPreprocessor>, ReportableEntityHandlerFactory, SpanSampler, Supplier<Boolean>, Supplier<Boolean>) - Constructor for class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
 
trafficShaping - Variable in class com.wavefront.agent.ProxyConfig
 
trafficShapingHeadroom - Variable in class com.wavefront.agent.ProxyConfig
 
TrafficShapingRateLimitAdjuster - Class in com.wavefront.agent.handlers
Experimental: use automatic traffic shaping (set rate limiter based on recently received per second rates, heavily biased towards last 5 minutes)
TrafficShapingRateLimitAdjuster(EntityPropertiesFactory, int, double) - Constructor for class com.wavefront.agent.handlers.TrafficShapingRateLimitAdjuster
 
trafficShapingWindowSeconds - Variable in class com.wavefront.agent.ProxyConfig
 
transform(T) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Apply all transformation rules sequentially
truncate(String, int, LengthLimitActionType) - Static method in class com.wavefront.agent.preprocessor.PreprocessorUtil
Enforce string max length limit - either truncate or truncate with "..." at the end.
TRUNCATE - com.wavefront.agent.preprocessor.LengthLimitActionType
 
TRUNCATE_WITH_ELLIPSIS - com.wavefront.agent.preprocessor.LengthLimitActionType
 

U

updateServerEndpointURL(String) - Method in class com.wavefront.agent.api.APIContainer
Re-create RESTeasy proxies with new server endpoint URL (allows changing URL at runtime).
useDeltaCounters - Variable in class com.wavefront.agent.config.LogsIngestionConfig
If true, use delta counters instead of regular counters to prevent metric collisions when multiple proxies are behind a load balancer.
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.wavefront.agent.channel.IdleStateEventHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class org.logstash.beats.ConnectionHandler

userPreprocessors - Variable in class com.wavefront.agent.preprocessor.PreprocessorConfigManager
 
useWavefrontHistograms - Variable in class com.wavefront.agent.config.LogsIngestionConfig
If true, use WavefrontHistograms rather than Histograms.
Utils - Class in com.wavefront.common
A placeholder class for miscellaneous utility methods.
Utils() - Constructor for class com.wavefront.common.Utils
 

V

V1Batch - Class in org.logstash.beats
Implementation of Batch intended for batches constructed from v1 protocol
V1Batch() - Constructor for class org.logstash.beats.V1Batch
 
V2Batch - Class in org.logstash.beats
Implementation of Batch for the v2 protocol backed by ByteBuf.
V2Batch() - Constructor for class org.logstash.beats.V2Batch
 
v2Predicate - Variable in class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
v2Predicate - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
v2Predicate - Variable in class com.wavefront.agent.preprocessor.SpanAddAnnotationTransformer
 
v2Predicate - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
 
VALID_HISTOGRAMS_LOGGER - Static variable in class com.wavefront.agent.handlers.ReportableEntityHandlerFactoryImpl
 
VALID_POINTS_LOGGER - Static variable in class com.wavefront.agent.handlers.ReportableEntityHandlerFactoryImpl
 
validationConfiguration - Variable in class com.wavefront.agent.AbstractAgent
 
value - Variable in class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
value - Variable in class com.wavefront.agent.preprocessor.SpanAddAnnotationTransformer
 
value() - Method in class com.wavefront.agent.logsharvesting.ChangeableGauge
 
valueFrom(Message) - Static method in class org.logstash.beats.BatchIdentity
 
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.data.QueueingReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.wavefront.agent.data.TaskQueueLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.wavefront.agent.data.TaskResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.wavefront.agent.formatter.DataFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.wavefront.agent.histogram.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.queueing.TaskConverter.CompressionType
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.data.QueueingReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.wavefront.agent.data.TaskQueueLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.wavefront.agent.data.TaskResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.wavefront.agent.formatter.DataFormat
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.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.queueing.TaskConverter.CompressionType
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.
VERIFY_PEER - org.logstash.netty.SslSimpleBuilder.SslClientVerifyMode
 
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
 
verifyAndInit() - Method in class com.wavefront.agent.ProxyConfig
 
VERSION_1 - Static variable in class org.logstash.beats.Protocol
 
VERSION_2 - Static variable in class org.logstash.beats.Protocol
 

W

WAVEFRONT - com.wavefront.agent.formatter.DataFormat
 
WavefrontPortUnificationHandler - Class in com.wavefront.agent.listeners
Process incoming Wavefront-formatted data.
WavefrontPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, Map<ReportableEntityType, ReportableEntityDecoder<?, ?>>, ReportableEntityHandlerFactory, SharedGraphiteHostAnnotator, Supplier<ReportableEntityPreprocessor>, Supplier<Boolean>, Supplier<Boolean>, Supplier<Boolean>, SpanSampler) - Constructor for class com.wavefront.agent.listeners.WavefrontPortUnificationHandler
Create new instance with lazy initialization for handlers.
WavefrontProxyService - Class in com.wavefront.agent
 
WavefrontProxyService() - Constructor for class com.wavefront.agent.WavefrontProxyService
 
weight() - Method in interface com.wavefront.agent.data.DataSubmissionTask
Returns a task weight.
weight() - Method in class com.wavefront.agent.data.EventDataSubmissionTask
 
weight() - Method in class com.wavefront.agent.data.LineDelimitedDataSubmissionTask
 
weight() - Method in class com.wavefront.agent.data.SourceTagSubmissionTask
 
weight() - Method in class com.wavefront.agent.queueing.FileBasedTaskQueue
 
weight() - Method in class com.wavefront.agent.queueing.InMemorySubmissionQueue
 
weight() - Method in class com.wavefront.agent.queueing.SQSSubmissionQueue
 
weight() - Method in class com.wavefront.agent.queueing.SynchronizedTaskQueueWithMetrics
 
weight() - Method in interface com.wavefront.agent.queueing.TaskQueue
Returns the total weight of the queue (sum of weights of all tasks).
weight() - Method in class com.wavefront.agent.queueing.TaskQueueStub
 
write(Bytes, long, AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
write(Bytes, HistogramKey) - Method in class com.wavefront.agent.histogram.HistogramUtils.HistogramKeyMarshaller
 
WriteHttpJsonPortUnificationHandler - Class in com.wavefront.agent.listeners
This class handles incoming messages in write_http format.
WriteHttpJsonPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityHandler<ReportPoint, String>, String, Supplier<ReportableEntityPreprocessor>) - Constructor for class com.wavefront.agent.listeners.WriteHttpJsonPortUnificationHandler
 
WriteHttpJsonPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityHandlerFactory, String, Supplier<ReportableEntityPreprocessor>) - Constructor for class com.wavefront.agent.listeners.WriteHttpJsonPortUnificationHandler
Create a new instance.
writeHttpResponse(ChannelHandlerContext, HttpResponse, boolean) - Static method in class com.wavefront.agent.channel.ChannelUtils
Writes HTTP response back to client.
writeHttpResponse(ChannelHandlerContext, HttpResponse, HttpMessage) - Static method in class com.wavefront.agent.channel.ChannelUtils
Writes HTTP response back to client.
writeHttpResponse(ChannelHandlerContext, HttpResponseStatus, Object, boolean) - Static method in class com.wavefront.agent.channel.ChannelUtils
Writes HTTP response back to client.
writeHttpResponse(ChannelHandlerContext, HttpResponseStatus, Object, HttpMessage) - Static method in class com.wavefront.agent.channel.ChannelUtils
Writes HTTP response back to client.
writeMarshallable(WireOut) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
writeMarshallable(WireOut) - Method in class com.wavefront.agent.histogram.HistogramUtils.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, HealthCheckManager, ReportableEntityHandlerFactory, WavefrontSender, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, SpanSampler, String, Set<String>) - Constructor for class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
 
A B C D E F G H I J K L M N O P Q R S T U V W Z 
All Classes All Packages