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
All Classes All Packages
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
- 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
-
Create new instance.
- 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<Utils.HistogramKey, AgentDigest>, long, Ticker) - Constructor for class com.wavefront.agent.histogram.accumulator.AccumulationCache
-
Constructs a new AccumulationCache instance around
backingStore
and builds an in-memory index maintaining dispatch times in milliseconds for all HistogramKeys in backingStore Setting cacheSize to 0 disables in-memory caching so the cache only maintains the dispatch time index. - AccumulationCache(ConcurrentMap<Utils.HistogramKey, AgentDigest>, long, Ticker, Runnable) - Constructor for class com.wavefront.agent.histogram.accumulator.AccumulationCache
-
Constructs a new AccumulationCache instance around
backingStore
and builds an in-memory index maintaining dispatch times in milliseconds for all HistogramKeys in backingStore Setting cacheSize to 0 disables in-memory caching so the cache only maintains the dispatch time index. - AccumulationCache.AccumulationCacheMonitor - Class in com.wavefront.agent.histogram.accumulator
- AccumulationCacheMonitor() - Constructor for class com.wavefront.agent.histogram.accumulator.AccumulationCache.AccumulationCacheMonitor
- 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 - com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.ActionType
- 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(ResubmissionTask) - Method in class com.wavefront.agent.ResubmissionTaskQueue
- add(Iterable<T>) - Method in interface com.wavefront.agent.handlers.SenderTask
-
Add multiple valid items to the send queue (memory buffers).
- add(T) - Method in interface com.wavefront.agent.handlers.SenderTask
-
Add valid item to the send queue (memory buffers).
- addBlockedSample(String) - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- 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.agent.Utils
-
Requires an input uuid string Encoded as 32 hex characters.
- additionalPatterns - Variable in class com.wavefront.agent.config.LogsIngestionConfig
-
Additional grok patterns to use in pattern matching for the above
MetricMatcher
s. - addPoint(String) - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- addPoints(List<String>) - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- 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
- adminApiListenerPort - Variable in class com.wavefront.agent.AbstractAgent
- adminApiRemoteIpWhitelistRegex - Variable in class com.wavefront.agent.AbstractAgent
- 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.
- agentAPI - Variable in class com.wavefront.agent.AbstractAgent
- 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
- agentId - Variable in class com.wavefront.agent.AbstractAgent
- agentMetrics - Variable in class com.wavefront.agent.AbstractAgent
- agentMetricsCaptureTs - Variable in class com.wavefront.agent.AbstractAgent
- agentMetricsPointTags - Variable in class com.wavefront.agent.AbstractAgent
- aggregationIntervalSeconds - Variable in class com.wavefront.agent.config.LogsIngestionConfig
-
How often metrics are aggregated and sent to wavefront.
- AnnotatedPredicate<T> - Interface in com.wavefront.agent.preprocessor
-
Base for all "filter"-type rules.
- appendTag(String, String, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledProxyAPI
-
Add a single tag to a source.
- appendTag(String, String, boolean) - Method in class com.wavefront.agent.QueuedAgentService
- appendTag(String, String, String) - Method in class com.wavefront.agent.QueuedAgentService
- 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.PointLineReplaceRegexTransformer
- apply(InetAddress) - Method in class com.wavefront.agent.channel.CachingHostnameLookupResolver
- 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.SpanDropAnnotationTransformer
- apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanExtractAnnotationIfNotExistsTransformer
- apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
- apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanForceLowercaseTransformer
- apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanLimitLengthTransformer
- apply(Span) - Method in class com.wavefront.agent.preprocessor.SpanReplaceRegexTransformer
- aroundWriteTo(WriterInterceptorContext) - Method in class com.wavefront.agent.channel.DisableGZIPEncodingInterceptor
- asBytes(ByteBuffer) - Method in class com.tdunning.math.stats.AgentDigest
- asSmallBytes(ByteBuffer) - Method in class com.tdunning.math.stats.AgentDigest
- authMethod - Variable in class com.wavefront.agent.AbstractAgent
- authorize(String) - Method in interface com.wavefront.agent.auth.TokenAuthenticator
-
Validate a token.
- authorized(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
- authRequired() - Method in interface com.wavefront.agent.auth.TokenAuthenticator
-
Check whether authentication is required (i.e.
- authResponseMaxTtl - Variable in class com.wavefront.agent.AbstractAgent
- authResponseRefreshInterval - Variable in class com.wavefront.agent.AbstractAgent
- authStaticToken - Variable in class com.wavefront.agent.AbstractAgent
- authTokenIntrospectionAuthorizationHeader - Variable in class com.wavefront.agent.AbstractAgent
- authTokenIntrospectionServiceUrl - Variable in class com.wavefront.agent.AbstractAgent
- autodetect(String) - Static method in enum com.wavefront.agent.formatter.DataFormat
- avgHistogramDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
- avgHistogramKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
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
- blacklistRegex - Variable in class com.wavefront.agent.AbstractAgent
- block(T) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
-
Handle the input object as blocked.
- block(T, String) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
-
Handle the input object as blocked.
- blockedPointsPerBatch - Variable in class com.wavefront.agent.PointHandlerImpl
-
Deprecated.
- bufferSpaceLeft - Variable in class com.wavefront.agent.AbstractAgent
- build() - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
- build(ByteBufAllocator) - Method in class org.logstash.netty.SslSimpleBuilder
- byteSize() - Method in class com.tdunning.math.stats.AgentDigest
C
- CachingHostnameLookupResolver - Class in com.wavefront.agent.channel
-
Convert
InetAddress
toString
, either by performing reverse DNS lookups (cached, as the name implies), or by converting IP addresses into their string representation. - CachingHostnameLookupResolver() - Constructor for class com.wavefront.agent.channel.CachingHostnameLookupResolver
-
Create a new instance with all default settings: - rDNS lookup enabled - no cache size metric - max 5000 elements in the cache - 5 minutes refresh TTL - 1 hour expiry TTL
- 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>, Supplier<ReportableEntityPreprocessor>) - 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.histogram.QueuingChannelHandler
- channelRead0(ChannelHandlerContext, Object) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
- channelRead0(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.ChannelStringHandler
-
Deprecated.
- channelRead0(ChannelHandlerContext, Batch) - Method in class org.logstash.beats.BeatsHandler
- channelReadComplete(ChannelHandlerContext) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
- ChannelStringHandler - Class in com.wavefront.agent.listeners
-
Deprecated.
- ChannelStringHandler(Decoder<String>, PointHandler, ReportableEntityPreprocessor) - Constructor for class com.wavefront.agent.listeners.ChannelStringHandler
-
Deprecated.
- 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
- ClassNameSerializer() - Constructor for class com.wavefront.agent.histogram.MapSettings.ClassNameSerializer
- cleanUp() - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
- close() - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
- close() - Method in class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
- close() - Method in class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
- CODE_COMPRESSED_FRAME - Static variable in class org.logstash.beats.Protocol
- CODE_FRAME - Static variable in class org.logstash.beats.Protocol
- CODE_JSON_FRAME - Static variable in class org.logstash.beats.Protocol
- CODE_WINDOW_SIZE - Static variable in class org.logstash.beats.Protocol
- com.tdunning.math.stats - package com.tdunning.math.stats
- com.wavefront.agent - package com.wavefront.agent
- com.wavefront.agent.api - package com.wavefront.agent.api
- com.wavefront.agent.auth - package com.wavefront.agent.auth
- com.wavefront.agent.channel - package com.wavefront.agent.channel
- com.wavefront.agent.config - package com.wavefront.agent.config
- com.wavefront.agent.formatter - package com.wavefront.agent.formatter
- com.wavefront.agent.handlers - package com.wavefront.agent.handlers
- com.wavefront.agent.histogram - package com.wavefront.agent.histogram
- com.wavefront.agent.histogram.accumulator - package com.wavefront.agent.histogram.accumulator
- com.wavefront.agent.listeners - package com.wavefront.agent.listeners
- com.wavefront.agent.listeners.tracing - package com.wavefront.agent.listeners.tracing
- com.wavefront.agent.logsharvesting - package com.wavefront.agent.logsharvesting
-
Classes for harvesting metric data from logs and sending them to Wavefront.
- com.wavefront.agent.preprocessor - package com.wavefront.agent.preprocessor
- com.wavefront.agent.sampler - package com.wavefront.agent.sampler
- com.wavefront.common - package com.wavefront.common
- 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(Utils.HistogramKey, BiFunction<? super Utils.HistogramKey, ? super AgentDigest, ? extends AgentDigest>) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
-
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
- compute(Utils.HistogramKey, BiFunction<? super Utils.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.AbstractAgent
- 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.auth.TokenValidationMethod.TokenValidationMethodConverter
- convertToUuidString(String) - Static method in class com.wavefront.agent.Utils
-
Method converts a string Id to
UUID
. - countCpuNanos(long) - Method in class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
-
Deprecated.
- counters - Variable in class com.wavefront.agent.config.LogsIngestionConfig
-
Counters to ingest from incoming log data.
- create() - Static method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
- createAgentService(String) - Method in class com.wavefront.agent.AbstractAgent
-
Create RESTeasy proxies for remote calls via HTTP.
- createLayeredSocket(Socket, String, int, HttpContext) - Method in class com.wavefront.agent.SSLConnectionSocketFactoryImpl
- createResubmissionTasks(WavefrontV2API, int, String, boolean, UUID, String) - Static method in class com.wavefront.agent.QueuedAgentService
- createSenderTasks(HandlerKey, int) - Method in interface com.wavefront.agent.handlers.SenderTaskFactory
-
Create a collection of
objects
for a specified handler key. - createSenderTasks(HandlerKey, int) - Method in class com.wavefront.agent.handlers.SenderTaskFactoryImpl
- createSocket() - Method in class com.wavefront.agent.SSLSocketFactoryImpl
- createSocket(String, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
- createSocket(String, int, InetAddress, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
- createSocket(InetAddress, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
- createSocket(InetAddress, int, InetAddress, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
- createSocket(Socket, String, int, boolean) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
- createSocket(HttpContext) - Method in class com.wavefront.agent.SSLConnectionSocketFactoryImpl
- createTaskQueue(UUID, File) - Static method in class com.wavefront.agent.QueuedAgentService
- currentAgentId - Variable in class com.wavefront.agent.ResubmissionTask
-
To be injected.
- customSourceTags - Variable in class com.wavefront.agent.AbstractAgent
- customSourceTagsProperty - Variable in class com.wavefront.agent.AbstractAgent
D
- dataBackfillCutoffHours - Variable in class com.wavefront.agent.AbstractAgent
- dataDogJsonPorts - Variable in class com.wavefront.agent.AbstractAgent
- DataDogPortUnificationHandler - Class in com.wavefront.agent.listeners
-
Accepts incoming HTTP requests in DataDog JSON format.
- DataDogPortUnificationHandler(String, HealthCheckManager, ReportableEntityHandler<ReportPoint>, boolean, boolean, HttpClient, String, Supplier<ReportableEntityPreprocessor>) - Constructor for class com.wavefront.agent.listeners.DataDogPortUnificationHandler
- DataDogPortUnificationHandler(String, HealthCheckManager, ReportableEntityHandlerFactory, boolean, boolean, HttpClient, String, Supplier<ReportableEntityPreprocessor>) - Constructor for class com.wavefront.agent.listeners.DataDogPortUnificationHandler
- dataDogProcessServiceChecks - Variable in class com.wavefront.agent.AbstractAgent
- dataDogProcessSystemMetrics - Variable in class com.wavefront.agent.AbstractAgent
- dataDogRequestRelayTarget - Variable in class com.wavefront.agent.AbstractAgent
- DataFormat - Enum in com.wavefront.agent.formatter
-
Best-effort data format auto-detection.
- dataPrefillCutoffHours - Variable in class com.wavefront.agent.AbstractAgent
- DAY - com.wavefront.agent.histogram.Utils.Granularity
- DEBUG_SPAN_TAG_KEY - Static variable in class com.wavefront.agent.listeners.tracing.SpanDerivedMetricsUtils
- 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_CIPHERS - Static variable in class org.logstash.netty.SslSimpleBuilder
- delete - com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.ActionType
- delete(Utils.HistogramKey, AgentDigest, RemovalCause) - Method in class com.wavefront.agent.histogram.accumulator.Layering
- 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(String, int, Collection<SenderTask>, Supplier<ValidationConfiguration>, long) - Constructor for class com.wavefront.agent.handlers.DeltaCounterAccumulationHandlerImpl
-
Creates a new instance that handles either histograms or points.
- deltaCountersAggregationIntervalSeconds - Variable in class com.wavefront.agent.AbstractAgent
- deltaCountersAggregationListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- desc - com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.MessageType
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class com.wavefront.agent.histogram.MapSettings.ClassNameSerializer
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class com.wavefront.agent.ResubmissionTaskDeserializer
- destroy() - Method in class com.wavefront.agent.PushAgentDaemon
- DisableGZIPEncodingInterceptor - Class in com.wavefront.agent.channel
-
This RESTEasy interceptor allows disabling GZIP compression even for methods annotated with @GZIP by removing the Content-Encoding header.
- DisableGZIPEncodingInterceptor() - Constructor for class com.wavefront.agent.channel.DisableGZIPEncodingInterceptor
- disableRdnsLookup - Variable in class com.wavefront.agent.AbstractAgent
- drainBuffersToQueue() - Method in interface com.wavefront.agent.handlers.SenderTask
-
Force memory buffer flush.
- drainBuffersToQueue() - Method in interface com.wavefront.agent.handlers.SenderTaskFactory
-
Drain memory buffers to queue for all tasks.
- drainBuffersToQueue() - Method in class com.wavefront.agent.handlers.SenderTaskFactoryImpl
- drainBuffersToQueue() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- DROP - com.wavefront.agent.preprocessor.LengthLimitActionType
- DroppingSender - Class in com.wavefront.agent.histogram
-
Dummy sender.
- DroppingSender(ObjectQueue<ReportPoint>) - Constructor for class com.wavefront.agent.histogram.DroppingSender
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
- enforceBufferLimits() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- ensure(boolean, String) - Method in class com.wavefront.agent.config.Configuration
- ephemeral - Variable in class com.wavefront.agent.AbstractAgent
- equals(Object) - Method in class com.wavefront.agent.config.Configuration
- equals(Object) - Method in class com.wavefront.agent.handlers.HandlerKey
- equals(Object) - Method in class com.wavefront.agent.histogram.MapSettings
- equals(Object) - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
- equals(Object) - Method in class com.wavefront.agent.listeners.tracing.HeartbeatMetricKey
- equals(Object) - Method in class com.wavefront.agent.preprocessor.Preprocessor
- equals(Object) - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
- equals(Object) - Method in class com.wavefront.common.HostMetricTagsPair
- equals(Object) - Method in class org.logstash.beats.BatchIdentity
- ERROR_SPAN_TAG_KEY - Static variable in class com.wavefront.agent.listeners.tracing.SpanDerivedMetricsUtils
- ERROR_SPAN_TAG_VAL - Static variable in class com.wavefront.agent.listeners.tracing.SpanDerivedMetricsUtils
- evict(MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
- EvictingMetricsRegistry - Class in com.wavefront.agent.logsharvesting
-
Wrapper for a Yammer
MetricsRegistry
, but has extra features regarding automatic removal of metrics. - exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.listeners.ChannelByteArrayHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.listeners.ChannelStringHandler
-
Deprecated.
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.wavefront.agent.listeners.RawLogsIngesterPortUnificationHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.logstash.beats.BeatsHandler
- execute(Object) - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
- execute(Object) - Method in class com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask
- expandPlaceholders(String, ReportPoint) - Static method in class com.wavefront.agent.preprocessor.PreprocessorUtil
-
Substitute {{...}} placeholders with corresponding components of the point {{metricName}} {{sourceName}} are replaced with the metric name and source respectively {{anyTagK}} is replaced with the value of the anyTagK point tag
- expandPlaceholders(String, Span) - Static method in class com.wavefront.agent.preprocessor.PreprocessorUtil
-
Substitute {{...}} placeholders with corresponding components of a Span {{spanName}} {{sourceName}} are replaced with the span name and source respectively {{anyKey}} is replaced with the value of an annotation with anyKey key
- expiryMillis - Variable in class com.wavefront.agent.config.LogsIngestionConfig
-
Metrics are cleared from memory (and so their aggregation state is lost) if a metric is not updated within this many milliseconds.
- extractAnnotation(Span, String) - Method in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
- extractTag(ReportPoint, String) - Method in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
- extractToken(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
F
- FilebeatIngester - Class in com.wavefront.agent.logsharvesting
- FilebeatIngester(LogsIngester, Supplier<Long>) - Constructor for class com.wavefront.agent.logsharvesting.FilebeatIngester
- FilebeatMessage - Class in com.wavefront.agent.logsharvesting
-
Abstraction for
Message
- FilebeatMessage(Message) - Constructor for class com.wavefront.agent.logsharvesting.FilebeatMessage
- filebeatPort - Variable in class com.wavefront.agent.AbstractAgent
- filter(T) - Method in class com.wavefront.agent.preprocessor.Preprocessor
-
Apply all filter predicates sequentially, stop at the first "false" result
- filter(T, String[]) - Method in class com.wavefront.agent.preprocessor.Preprocessor
-
Apply all filter predicates sequentially, stop at the first "false" result
- firstMatchOnly - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
- flush() - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
- flush() - Method in class com.wavefront.agent.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
- FlushProcessor - Class in com.wavefront.agent.logsharvesting
-
Wrapper for
MetricProcessor
. - FlushProcessorContext - Class in com.wavefront.agent.logsharvesting
- flushThreads - Variable in class com.wavefront.agent.AbstractAgent
- FORCE_PEER - org.logstash.netty.SslSimpleBuilder.SslClientVerifyMode
- FORCE_SAMPLED_KEY - Static variable in class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
- forceConfigReload() - Method in class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
-
Forces the next call to
LogsIngestionConfigManager.getConfig()
to call the config supplier. - ForceQueueEnabledProxyAPI - Interface in com.wavefront.agent.api
-
Wrapper around WavefrontV2API that supports forced writing of tasks to the backing queue.
- 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
- fromMetricName(MetricName) - Static method in class com.wavefront.agent.logsharvesting.TimeSeriesUtils
- fromMillis(long) - Static method in enum com.wavefront.agent.histogram.Utils.Granularity
- fromSamplers(Sampler...) - Static method in class com.wavefront.agent.sampler.SpanSamplerUtils
- fromString(String) - Static method in enum com.wavefront.agent.auth.TokenValidationMethod
- fromString(String) - Static method in enum com.wavefront.agent.histogram.Utils.Granularity
- fromString(String) - Static method in enum com.wavefront.agent.preprocessor.LengthLimitActionType
G
- gauges - Variable in class com.wavefront.agent.config.LogsIngestionConfig
-
Gauges to ingest from incoming log data.
- GENERIC - com.wavefront.agent.formatter.DataFormat
- get() - Static method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
- get() - Static method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
- get(File) - Method in class com.wavefront.agent.histogram.MapLoader
- get(String) - Method in class com.wavefront.agent.preprocessor.PreprocessorConfigManager
- getAgentId() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
- getAttemptedPoints() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- 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.Utils.HistogramKey
- getBinId() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
- getBinId(long) - Method in enum com.wavefront.agent.histogram.Utils.Granularity
-
Bin id for an epoch time is the epoch time in the corresponding granularity.
- getBinTimeMillis() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
- getBlockedSampleSize() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- getBoolean(String, Boolean) - Method in class com.wavefront.agent.config.ReportableConfig
- getBufferFlushTask() - Method in class com.wavefront.agent.histogram.QueuingChannelHandler
- getBytesPerMinute() - Method in class com.wavefront.agent.QueuedAgentService
- getConfig() - Method in class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
- getCounter(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
- getCurrentMillis() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
- getDaemonId() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- getData() - Method in class org.logstash.beats.Message
-
Returns a list of key/value pairs representing the contents of the message.
- getDefaultCipherSuites() - Method in class com.wavefront.agent.SSLSocketFactoryImpl
- getDispatchTimeMillis() - Method in class com.tdunning.math.stats.AgentDigest
-
Time at which this digest should be dispatched to wavefront.
- getDurationSampler(int) - Static method in class com.wavefront.agent.sampler.SpanSamplerUtils
- getEntityType() - Method in class com.wavefront.agent.handlers.HandlerKey
- getEntries() - Method in class com.wavefront.agent.histogram.MapSettings
- getFailureCount() - Method in class com.wavefront.agent.handlers.InternalProxyWavefrontClient
- getFilters() - Method in class com.wavefront.agent.preprocessor.Preprocessor
-
Check all filter rules as an immutable list
- getFlushingToQueueFlag() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- getFormat() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
- getGauge(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
- getGranularityOrdinal() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
- getHandle() - Method in class com.wavefront.agent.handlers.HandlerKey
- getHandler(HandlerKey) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandlerFactory
-
Create, or return existing,
ReportableEntityHandler
. - getHandler(HandlerKey) - Method in class com.wavefront.agent.handlers.ReportableEntityHandlerFactoryImpl
- 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
- getHost() - Method in class com.wavefront.common.HostMetricTagsPair
- getHttpEnabled() - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
- getIdentityStream() - Method in class org.logstash.beats.Message
- getInMillis() - Method in enum com.wavefront.agent.histogram.Utils.Granularity
-
Duration of a corresponding bin in milliseconds.
- getInstance() - Static method in class com.wavefront.agent.SharedMetricsRegistry
- getKeyClass() - Method in class com.wavefront.agent.histogram.MapSettings
- getKeyMarshaller() - Method in class com.wavefront.agent.histogram.MapSettings
- getKeySetAccessor() - Method in class com.wavefront.agent.histogram.accumulator.Layering
- getLogLine() - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
- getLogLine() - Method in interface com.wavefront.agent.logsharvesting.LogsMessage
- getMetric() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
- getMetric() - Method in class com.wavefront.common.HostMetricTagsPair
- getMetricMangler() - Method in class com.wavefront.agent.formatter.GraphiteFormatter
- getNumApiCalls() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- getNumber(String, Number) - Method in class com.wavefront.agent.config.ReportableConfig
- getNumber(String, Number, Number, Number) - Method in class com.wavefront.agent.config.ReportableConfig
- getNumPointsQueued() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- getNumPointsToSend() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- getOps() - Method in class com.wavefront.agent.formatter.GraphiteFormatter
- getPattern() - Method in class com.wavefront.agent.config.MetricMatcher
- getProtocol() - Method in class org.logstash.beats.Ack
- getProtocol() - Method in 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
- getPushData() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
- getQueuedSourceTagTasksCount() - Method in class com.wavefront.agent.QueuedAgentService
- getQueuedTasksCount() - Method in class com.wavefront.agent.QueuedAgentService
- getRandomPostTask() - Method in class com.wavefront.agent.PointHandlerImpl
-
Deprecated.
- getRateSampler(double) - Static method in class com.wavefront.agent.sampler.SpanSamplerUtils
- getRawProperty(String, String) - Method in class com.wavefront.agent.config.ReportableConfig
-
Returns string value for the property without tracking it as a metric
- getRemoteAddress(ChannelHandlerContext) - Static method in class com.wavefront.agent.channel.CachingHostnameLookupResolver
- getRemoteName(ChannelHandlerContext) - Static method in class com.wavefront.agent.channel.ChannelUtils
-
Get remote client's address as string (without rDNS lookup) and local port
- 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
- getSize(JsonNode, Class<?>, Type, Annotation[], MediaType) - Method in class com.wavefront.agent.JsonNodeWriter
- getSource() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
- getSslCertificateFile() - Method in class org.logstash.netty.SslSimpleBuilder
- getSslKeyFile() - Method in class org.logstash.netty.SslSimpleBuilder
- getString(String, String) - Method in class com.wavefront.agent.config.ReportableConfig
- getString(String, String, Function<String, String>) - Method in class com.wavefront.agent.config.ReportableConfig
- getSupportedCipherSuites() - Method in class com.wavefront.agent.SSLSocketFactoryImpl
- getSystemPreprocessor(String) - Method in class com.wavefront.agent.preprocessor.PreprocessorConfigManager
- getTags() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
- getTags() - Method in class com.wavefront.common.HostMetricTagsPair
- getTagsAsMap() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
-
Unpacks tags into a map.
- getTaskRelativeScore() - Method in interface com.wavefront.agent.handlers.SenderTask
-
Calculate a numeric score (the lower the better) that is intended to help the
ReportableEntityHandler
to choose the best SenderTask to handle over data to. - getTimestampMillis() - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
- 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
- getValueClass() - Method in class com.wavefront.agent.histogram.MapSettings
- getValueLabel() - Method in class com.wavefront.agent.config.MetricMatcher
- getValueMarshaller() - Method in class com.wavefront.agent.histogram.MapSettings
- getWriteBackTask() - Method in class com.wavefront.agent.histogram.accumulator.Layering
-
Returns a runnable for writing back dirty entries to the backing store.
- granularityToString(Utils.Granularity) - Static method in enum com.wavefront.agent.histogram.Utils.Granularity
- graphiteBlacklistRegex - Variable in class com.wavefront.agent.AbstractAgent
- graphiteDelimiters - Variable in class com.wavefront.agent.AbstractAgent
- graphiteFieldsToRemove - Variable in class com.wavefront.agent.AbstractAgent
- graphiteFormat - Variable in class com.wavefront.agent.AbstractAgent
- GraphiteFormatter - Class in com.wavefront.agent.formatter
-
Specific formatter for the graphite/collectd world of metric-munged names.
- GraphiteFormatter(String, String, String) - Constructor for class com.wavefront.agent.formatter.GraphiteFormatter
- graphitePorts - Variable in class com.wavefront.agent.AbstractAgent
- graphiteWhitelistRegex - Variable in class com.wavefront.agent.AbstractAgent
- gzipCompression - Variable in class com.wavefront.agent.AbstractAgent
H
- hadSuccessfulCheckin - Variable in class com.wavefront.agent.AbstractAgent
- handle - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
- handleBlockedPoint(String) - Method in interface com.wavefront.agent.PointHandler
-
Deprecated.Called when a blocked line is encountered.
- handleBlockedPoint(String) - Method in class com.wavefront.agent.PointHandlerImpl
-
Deprecated.
- 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.ZipkinPortUnificationHandler
- handleHttpMessage(ChannelHandlerContext, FullHttpRequest) - Method in class com.wavefront.agent.listeners.WriteHttpJsonPortUnificationHandler
- handleImpl(ThriftRequest<Collector.submitBatches_args>) - Method in class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
- 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.
- handlerFactory - Variable in class com.wavefront.agent.PushAgent
- HandlerKey - Class in com.wavefront.agent.handlers
-
An immutable unique identifier for a handler pipeline (type of objects handled + port/handle name)
- 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.histogram.Utils.HistogramKey
- hashCode() - Method in class com.wavefront.agent.listeners.tracing.HeartbeatMetricKey
- hashCode() - Method in class com.wavefront.agent.preprocessor.Preprocessor
- hashCode() - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
- 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(String, String, int, String, int, String) - Constructor for class com.wavefront.agent.channel.HealthCheckManagerImpl
- HeartbeatMetricKey - Class in com.wavefront.agent.listeners.tracing
-
Composition class that makes up the heartbeat metric.
- 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(String, Accumulator, int, long, Utils.Granularity, short, Supplier<ValidationConfiguration>, boolean) - Constructor for class com.wavefront.agent.handlers.HistogramAccumulationHandlerImpl
-
Creates a new instance
- histogramAccumulatorFlushInterval - Variable in class com.wavefront.agent.AbstractAgent
- histogramAccumulatorFlushMaxBatchSize - Variable in class com.wavefront.agent.AbstractAgent
- histogramAccumulatorResolveInterval - Variable in class com.wavefront.agent.AbstractAgent
- histogramAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
- histogramCompression - Variable in class com.wavefront.agent.AbstractAgent
-
Deprecated.
- histogramDayAccumulators - Variable in class com.wavefront.agent.AbstractAgent
-
Deprecated.
- histogramDayAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
- histogramDayAvgDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
- histogramDayAvgKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
- histogramDayCompression - Variable in class com.wavefront.agent.AbstractAgent
- histogramDayFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
- histogramDayListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- histogramDayMemoryCache - Variable in class com.wavefront.agent.AbstractAgent
- histogramDisabled - Variable in class com.wavefront.agent.AbstractAgent
- histogramDistAccumulators - Variable in class com.wavefront.agent.AbstractAgent
-
Deprecated.
- histogramDistAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
- histogramDistAvgDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
- histogramDistAvgKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
- histogramDistCompression - Variable in class com.wavefront.agent.AbstractAgent
- histogramDistFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
- histogramDistListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- histogramDistMemoryCache - Variable in class com.wavefront.agent.AbstractAgent
- histogramExecutor - Variable in class com.wavefront.agent.PushAgent
- histogramFlushExecutor - Variable in class com.wavefront.agent.PushAgent
- histogramHourAccumulators - Variable in class com.wavefront.agent.AbstractAgent
-
Deprecated.
- histogramHourAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
- histogramHourAvgDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
- histogramHourAvgKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
- histogramHourCompression - Variable in class com.wavefront.agent.AbstractAgent
- histogramHourFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
- histogramHourListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- histogramHourMemoryCache - Variable in class com.wavefront.agent.AbstractAgent
- histogramHttpBufferSize - Variable in class com.wavefront.agent.AbstractAgent
- histogramMaxReceivedLength - Variable in class com.wavefront.agent.AbstractAgent
- histogramMinuteAccumulators - Variable in class com.wavefront.agent.AbstractAgent
-
Deprecated.
- histogramMinuteAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
- histogramMinuteAvgDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
- histogramMinuteAvgKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
- histogramMinuteCompression - Variable in class com.wavefront.agent.AbstractAgent
- histogramMinuteFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
- histogramMinuteListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- histogramMinuteMemoryCache - Variable in class com.wavefront.agent.AbstractAgent
- histogramProcessingQueueScanInterval - Variable in class com.wavefront.agent.AbstractAgent
-
Deprecated.
- histogramReceiveBufferFlushInterval - Variable in class com.wavefront.agent.AbstractAgent
-
Deprecated.
- histograms - Variable in class com.wavefront.agent.config.LogsIngestionConfig
-
Histograms to ingest from incoming log data.
- histogramStateDirectory - Variable in class com.wavefront.agent.AbstractAgent
- 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
- hostname - Variable in class com.wavefront.agent.AbstractAgent
- 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.Utils.Granularity
- HTTP_GET - com.wavefront.agent.auth.TokenValidationMethod
- httpAutoRetries - Variable in class com.wavefront.agent.AbstractAgent
- httpConnectTimeout - Variable in class com.wavefront.agent.AbstractAgent
- httpHealthCheckAllPorts - Variable in class com.wavefront.agent.AbstractAgent
- HttpHealthCheckEndpointHandler - Class in com.wavefront.agent.listeners
-
A simple healthcheck-only endpoint handler.
- HttpHealthCheckEndpointHandler(HealthCheckManager, int) - Constructor for class com.wavefront.agent.listeners.HttpHealthCheckEndpointHandler
- httpHealthCheckFailResponseBody - Variable in class com.wavefront.agent.AbstractAgent
- httpHealthCheckFailStatusCode - Variable in class com.wavefront.agent.AbstractAgent
- httpHealthCheckPassResponseBody - Variable in class com.wavefront.agent.AbstractAgent
- httpHealthCheckPassStatusCode - Variable in class com.wavefront.agent.AbstractAgent
- httpHealthCheckPath - Variable in class com.wavefront.agent.AbstractAgent
- httpHealthCheckPorts - Variable in class com.wavefront.agent.AbstractAgent
- httpHealthCheckResponseContentType - Variable in class com.wavefront.agent.AbstractAgent
- httpMaxConnPerRoute - Variable in class com.wavefront.agent.AbstractAgent
- httpMaxConnTotal - Variable in class com.wavefront.agent.AbstractAgent
- 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
- httpRequestTimeout - Variable in class com.wavefront.agent.AbstractAgent
- httpUserAgent - Variable in class com.wavefront.agent.AbstractAgent
I
- idFile - Variable in class com.wavefront.agent.AbstractAgent
- IdleStateEventHandler - Class in com.wavefront.agent.channel
-
Disconnect idle clients (handle READER_IDLE events triggered by IdleStateHandler)
- IdleStateEventHandler(Counter) - Constructor for class com.wavefront.agent.channel.IdleStateEventHandler
- IMessageListener - Interface in org.logstash.beats
-
This class is implemented in ruby in `lib/logstash/inputs/beats/message_listener`, this class is used to link the events triggered from the different connection to the actual work inside the plugin.
- 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.
- incrementBlockedPoints() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- 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.PushAgentDaemon
- input - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
- InteractiveLogsTester - Class in com.wavefront.agent.logsharvesting
- InteractiveLogsTester(Supplier<LogsIngestionConfig>, String) - Constructor for class com.wavefront.agent.logsharvesting.InteractiveLogsTester
- interactiveTest() - Method in class com.wavefront.agent.logsharvesting.InteractiveLogsTester
-
Read one line of stdin and print a message to stdout.
- internalApply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
- internalApply(Span) - Method in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
- InternalProxyWavefrontClient - Class in com.wavefront.agent.handlers
- InternalProxyWavefrontClient(ReportableEntityHandlerFactory) - Constructor for class com.wavefront.agent.handlers.InternalProxyWavefrontClient
- InternalProxyWavefrontClient(ReportableEntityHandlerFactory, String) - Constructor for class com.wavefront.agent.handlers.InternalProxyWavefrontClient
- 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
- isDefined(String) - Method in class com.wavefront.agent.config.ReportableConfig
- 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
- 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
- isRunning() - Method in class com.wavefront.agent.QueuedAgentService
- isSslEnable() - Method in class org.logstash.beats.Server
- isVersion2(byte) - Static method in class org.logstash.beats.Protocol
- isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.wavefront.agent.JsonNodeWriter
- iterator() - Method in class org.logstash.beats.V1Batch
- iterator() - Method in class org.logstash.beats.V2Batch
J
- JaegerThriftCollectorHandler - Class in com.wavefront.agent.listeners.tracing
-
Handler that processes trace data in Jaeger Thrift compact format and converts them to Wavefront format
- JaegerThriftCollectorHandler(String, ReportableEntityHandler<Span>, ReportableEntityHandler<SpanLogs>, WavefrontSender, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, Sampler, boolean, String, Set<String>) - Constructor for class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
- JaegerThriftCollectorHandler(String, ReportableEntityHandlerFactory, WavefrontSender, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, Sampler, boolean, String, Set<String>) - Constructor for class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
- javaNetConnection - Variable in class com.wavefront.agent.AbstractAgent
-
Deprecated.
- joinPushData(Collection<String>) - Static method in class com.wavefront.agent.handlers.LineDelimitedUtils
-
Join a batch of strings into a payload string.
- JSON_STRING - com.wavefront.agent.formatter.DataFormat
- jsonListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- JsonMetricsPortUnificationHandler - Class in com.wavefront.agent.listeners
-
Agent-side JSON metrics endpoint.
- JsonMetricsPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityHandler<ReportPoint>, 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
- keySet() - Method in interface com.wavefront.agent.histogram.accumulator.Layering.KeySetAccessor
-
Keys in the combined set.
L
- Layering - Class in com.wavefront.agent.histogram.accumulator
-
Basic layering between Caffeine and some backing store.
- Layering(ConcurrentMap<Utils.HistogramKey, AgentDigest>) - Constructor for class com.wavefront.agent.histogram.accumulator.Layering
- Layering.KeySetAccessor - Interface in com.wavefront.agent.histogram.accumulator
- lazySupplier(Supplier<T>) - Static method in class com.wavefront.agent.Utils
-
A lazy initialization wrapper for
Supplier
- LengthLimitActionType - Enum in com.wavefront.agent.preprocessor
- 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
- listenerIdleConnectionTimeout - Variable in class com.wavefront.agent.AbstractAgent
- load(Utils.HistogramKey) - Method in class com.wavefront.agent.histogram.accumulator.Layering
- loadLogsIngestionConfig() - Method in class com.wavefront.agent.AbstractAgent
- localAgent - Variable in class com.wavefront.agent.AbstractAgent
- logger - Static variable in class com.wavefront.agent.AbstractAgent
- logger - Static variable in class com.wavefront.agent.channel.IncompleteLineDetectingLineBasedFrameDecoder
- logger - Static variable in class com.wavefront.agent.channel.PlainTextOrHttpFrameDecoder
- logger - Static variable in class com.wavefront.agent.config.MetricMatcher
- logger - Static variable in class com.wavefront.agent.histogram.QueuingChannelHandler
- logger - Static variable in class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
- logger - Static variable in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
- logger - Static variable in class com.wavefront.agent.logsharvesting.FilebeatIngester
- logger - Static variable in class com.wavefront.agent.logsharvesting.LogsIngester
- logger - Static variable in class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
- logger - Static variable in class com.wavefront.agent.logsharvesting.MetricsReporter
- LogsIngester - Class in com.wavefront.agent.logsharvesting
-
Consumes log messages sent to
LogsIngester.ingestLog(LogsMessage)
. - LogsIngester(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
- logsIngestionConfigFile - Variable in class com.wavefront.agent.AbstractAgent
- LogsIngestionConfigManager - Class in com.wavefront.agent.logsharvesting
-
Wrapper for a
LogsIngestionConfig
that supports hot-loading and removal notifications. - LogsIngestionConfigManager(Supplier<LogsIngestionConfig>, Consumer<MetricMatcher>) - Constructor for class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
- LogsMessage - Interface in com.wavefront.agent.logsharvesting
- logWarning(String, Throwable, ChannelHandlerContext) - Method in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
-
Log a detailed error message with remote IP address
M
- main(String[]) - Static method in class com.wavefront.agent.PushAgent
- main(String[]) - Static method in class org.logstash.beats.Runner
- makeKey(ReportPoint, Utils.Granularity) - Static method in class com.wavefront.agent.histogram.Utils
- MalformedMessageException - Exception in com.wavefront.agent.logsharvesting
- managedExecutors - Variable in class com.wavefront.agent.AbstractAgent
- managedThreads - Variable in class com.wavefront.agent.PushAgent
- MapLoader<K,V,KM extends net.openhft.chronicle.hash.serialization.BytesReader<K> & net.openhft.chronicle.hash.serialization.BytesWriter<K>,VM extends net.openhft.chronicle.hash.serialization.SizedReader<V> & net.openhft.chronicle.hash.serialization.SizedWriter<V>> - Class in com.wavefront.agent.histogram
-
Loader for
ChronicleMap
. - MapLoader(Class<K>, Class<V>, long, double, double, KM, VM, boolean) - Constructor for class com.wavefront.agent.histogram.MapLoader
-
Creates a new
MapLoader
- MAPPER - Static variable in class org.logstash.beats.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(Class, Class, Class, Class, long, double, double) - Constructor for class com.wavefront.agent.histogram.MapSettings
- MapSettings.ClassNameSerializer - Class in com.wavefront.agent.histogram
- memGuardFlushThreshold - Variable in class com.wavefront.agent.AbstractAgent
- 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
- 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
- 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
- millisSinceEpoch() - Method in interface com.wavefront.agent.histogram.TimeProvider
- MINUTE - com.wavefront.agent.histogram.Utils.Granularity
N
- NONE - com.wavefront.agent.auth.TokenValidationMethod
- NoopHealthCheckManager - Class in com.wavefront.agent.channel
-
A no-op health check manager.
- NoopHealthCheckManager() - Constructor for class com.wavefront.agent.channel.NoopHealthCheckManager
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.
- opentsdbBlacklistRegex - Variable in class com.wavefront.agent.AbstractAgent
- opentsdbPorts - Variable in class com.wavefront.agent.AbstractAgent
- OpenTSDBPortUnificationHandler - Class in com.wavefront.agent.listeners
-
This class handles 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
- opentsdbWhitelistRegex - Variable in class com.wavefront.agent.AbstractAgent
- org.logstash.beats - package org.logstash.beats
- org.logstash.netty - package org.logstash.netty
P
- PARAMETERS_TO_HIDE - Static variable in class com.wavefront.agent.AbstractAgent
-
A set of commandline parameters to hide when echoing command line arguments
- parseUri(ChannelHandlerContext, FullHttpRequest) - Static method in class com.wavefront.agent.channel.ChannelUtils
-
Attempt to parse request URI.
- 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
- peek() - Method in class com.wavefront.agent.ResubmissionTaskQueue
- persistAccumulator - Variable in class com.wavefront.agent.AbstractAgent
- persistMessages - Variable in class com.wavefront.agent.AbstractAgent
-
Deprecated.
- persistMessagesCompression - Variable in class com.wavefront.agent.AbstractAgent
-
Deprecated.
- picklePorts - Variable in class com.wavefront.agent.AbstractAgent
- PlainTextOrHttpFrameDecoder - Class in com.wavefront.agent.channel
-
This class handles 2 different protocols on a single port.
- PlainTextOrHttpFrameDecoder(ChannelHandler) - Constructor for class com.wavefront.agent.channel.PlainTextOrHttpFrameDecoder
-
Constructor with default input buffer limits (4KB for plaintext, 16MB for HTTP).
- PlainTextOrHttpFrameDecoder(ChannelHandler, int, int) - Constructor for class com.wavefront.agent.channel.PlainTextOrHttpFrameDecoder
-
Constructor.
- pointFromKeyAndDigest(Utils.HistogramKey, AgentDigest) - Static method in class com.wavefront.agent.histogram.Utils
- PointHandler - Interface in com.wavefront.agent
-
Deprecated.
- 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>, Integer, Utils.Granularity) - Constructor for class com.wavefront.agent.histogram.PointHandlerDispatcher
- PointHandlerImpl - Class in com.wavefront.agent
-
Deprecated.
- PointHandlerImpl(String, String, int, PostPushDataTimedTask[]) - Constructor for class com.wavefront.agent.PointHandlerImpl
-
Deprecated.
- PointHandlerImpl(String, String, int, String, PostPushDataTimedTask[]) - Constructor for class com.wavefront.agent.PointHandlerImpl
-
Deprecated.
- PointLineBlacklistRegexFilter - Class in com.wavefront.agent.preprocessor
-
Blacklist regex filter.
- PointLineBlacklistRegexFilter(String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.PointLineBlacklistRegexFilter
- PointLineBlacklistRegexFilter(String, Counter) - Constructor for class com.wavefront.agent.preprocessor.PointLineBlacklistRegexFilter
-
Deprecated.
- PointLineReplaceRegexTransformer - Class in com.wavefront.agent.preprocessor
-
Replace regex transformer.
- PointLineReplaceRegexTransformer(String, String, String, Integer, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.PointLineReplaceRegexTransformer
- PointLineReplaceRegexTransformer(String, String, String, Integer, Counter) - Constructor for class com.wavefront.agent.preprocessor.PointLineReplaceRegexTransformer
-
Deprecated.
- PointLineWhitelistRegexFilter - Class in com.wavefront.agent.preprocessor
-
Whitelist regex filter.
- PointLineWhitelistRegexFilter(String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.PointLineWhitelistRegexFilter
- PointLineWhitelistRegexFilter(String, Counter) - Constructor for class com.wavefront.agent.preprocessor.PointLineWhitelistRegexFilter
-
Deprecated.
- pointsDiscarded - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
- pointToString(ReportPoint) - Static method in class com.wavefront.agent.PointHandlerImpl
-
Deprecated.
- PostPushDataResultTask(UUID, Long, String, String) - Constructor for class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
- PostPushDataTimedTask - Class in com.wavefront.agent
-
Deprecated.
- PostPushDataTimedTask(String, ForceQueueEnabledProxyAPI, String, UUID, String, int, RecyclableRateLimiter, long) - Constructor for class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- PostPushDataTimedTask(String, ForceQueueEnabledProxyAPI, UUID, String, int, RecyclableRateLimiter, long) - Constructor for class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- PostSourceTagResultTask(String, String, QueuedAgentService.PostSourceTagResultTask.ActionType, QueuedAgentService.PostSourceTagResultTask.MessageType, String) - Constructor for class com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask
- PostSourceTagResultTask(String, List<String>, QueuedAgentService.PostSourceTagResultTask.ActionType, QueuedAgentService.PostSourceTagResultTask.MessageType, String) - Constructor for class com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask
- prefix - Variable in class com.wavefront.agent.AbstractAgent
- Preprocessor<T> - Class in com.wavefront.agent.preprocessor
-
Generic container class for storing transformation and filter rules Created by Vasily on 9/13/16.
- Preprocessor() - Constructor for class com.wavefront.agent.preprocessor.Preprocessor
- Preprocessor(List<Function<T, T>>, List<AnnotatedPredicate<T>>) - Constructor for class com.wavefront.agent.preprocessor.Preprocessor
- preprocessorConfigFile - Variable in class com.wavefront.agent.AbstractAgent
- 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
- PreprocessorConfigManager(String) - Constructor for class com.wavefront.agent.preprocessor.PreprocessorConfigManager
- PreprocessorRuleMetrics - Class in com.wavefront.agent.preprocessor
-
A helper class for instrumenting preprocessor rules.
- PreprocessorRuleMetrics(Counter) - Constructor for class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
-
Deprecated.
- PreprocessorRuleMetrics(Counter, Counter) - Constructor for class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
-
Deprecated.
- 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
- preprocessPointLine(String, ReportableEntityHandler) - Method in class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
- processConfiguration(AgentConfiguration) - Method in class com.wavefront.agent.AbstractAgent
-
Actual agents can do additional configuration.
- processConfiguration(AgentConfiguration) - Method in class com.wavefront.agent.PushAgent
-
Push agent configuration during check-in by the collector.
- processCounter(MetricName, Counter, 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
- processId - Variable in class com.wavefront.agent.AbstractAgent
-
A unique process ID value (PID, when available, or a random hexadecimal string), assigned at proxy start-up, to be reported with all ~proxy metrics as a "processId" point tag to prevent potential ~proxy metrics collisions caused by users spinning up multiple proxies with duplicate names.
- processLine(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.AbstractLineDelimitedHandler
-
Process a single line for a line-based stream.
- processLine(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.RawLogsIngesterPortUnificationHandler
- processLine(ChannelHandlerContext, String) - Method in class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
- processLine(ChannelHandlerContext, String) - 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
- processPointLine(String, Decoder<String>, PointHandler, ReportableEntityPreprocessor, ChannelHandlerContext) - Static method in class com.wavefront.agent.listeners.ChannelStringHandler
-
Deprecated.This probably belongs in a base class.
- processTimer(MetricName, Timer, FlushProcessorContext) - Method in class com.wavefront.agent.logsharvesting.FlushProcessor
- processTimer(MetricName, Timer, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
- props - Variable in class com.wavefront.agent.AbstractAgent
- Protocol - Class in org.logstash.beats
-
Created by ph on 2016-05-16.
- Protocol() - Constructor for class org.logstash.beats.Protocol
- proxyCheckin(UUID, String, String, String, Long, JsonNode, Boolean) - Method in class com.wavefront.agent.QueuedAgentService
- proxyConfigProcessed(UUID) - Method in class com.wavefront.agent.QueuedAgentService
- proxyError(UUID, String) - Method in class com.wavefront.agent.QueuedAgentService
- proxyHost - Variable in class com.wavefront.agent.AbstractAgent
- 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.
- proxyPassword - Variable in class com.wavefront.agent.AbstractAgent
- proxyPort - Variable in class com.wavefront.agent.AbstractAgent
- proxyReport(UUID, String, String) - Method in class com.wavefront.agent.QueuedAgentService
- proxyReport(UUID, String, String, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledProxyAPI
-
Report batched data (metrics, histograms, spans, etc) to Wavefront servers.
- proxyReport(UUID, String, String, boolean) - Method in class com.wavefront.agent.QueuedAgentService
- proxyUser - Variable in class com.wavefront.agent.AbstractAgent
- PUSH_DATA_DELIMETER - Static variable in class com.wavefront.agent.handlers.LineDelimitedUtils
- pushAgent - Variable in class com.wavefront.agent.AbstractAgent
- PushAgent - Class in com.wavefront.agent
-
Push-only Agent.
- PushAgent() - Constructor for class com.wavefront.agent.PushAgent
- PushAgent(boolean) - Constructor for class com.wavefront.agent.PushAgent
-
Deprecated.
- PushAgentDaemon - Class in com.wavefront.agent
- PushAgentDaemon() - Constructor for class com.wavefront.agent.PushAgentDaemon
- pushBlockedSamples - Variable in class com.wavefront.agent.AbstractAgent
- pushDataSize(String) - Static method in class com.wavefront.agent.handlers.LineDelimitedUtils
-
Calculates the number of points in the pushData payload.
- pushFlushInterval - Variable in class com.wavefront.agent.AbstractAgent
- pushFlushIntervalInitialValue - Variable in class com.wavefront.agent.AbstractAgent
- pushFlushMaxPoints - Variable in class com.wavefront.agent.AbstractAgent
- pushFlushMaxPointsInitialValue - Variable in class com.wavefront.agent.AbstractAgent
- pushListenerHttpBufferSize - Variable in class com.wavefront.agent.AbstractAgent
- pushListenerMaxReceivedLength - Variable in class com.wavefront.agent.AbstractAgent
- pushListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- pushMemoryBufferLimit - Variable in class com.wavefront.agent.AbstractAgent
- pushRateLimit - Variable in class com.wavefront.agent.AbstractAgent
- pushRateLimiter - Variable in class com.wavefront.agent.AbstractAgent
- pushRateLimitMaxBurstSeconds - Variable in class com.wavefront.agent.AbstractAgent
- pushRelayListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- pushValidationLevel - Variable in class com.wavefront.agent.AbstractAgent
- put(Utils.HistogramKey, double, short, long) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
-
Update
AgentDigest
in the cache with a double value. - put(Utils.HistogramKey, double, short, long) - Method in interface com.wavefront.agent.histogram.accumulator.Accumulator
-
Update
AgentDigest
in the cache with a double value. - put(Utils.HistogramKey, AgentDigest) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
-
Update
AgentDigest
in the cache with anotherAgentDigest
. - put(Utils.HistogramKey, AgentDigest) - Method in interface com.wavefront.agent.histogram.accumulator.Accumulator
-
Update
AgentDigest
in the cache with anotherAgentDigest
. - put(Utils.HistogramKey, Histogram, short, long) - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
-
Update
AgentDigest
in the cache with aHistogram
value. - put(Utils.HistogramKey, Histogram, short, long) - Method in interface com.wavefront.agent.histogram.accumulator.Accumulator
-
Update
AgentDigest
in the cache with aHistogram
value.
Q
- quantile(double) - Method in class com.tdunning.math.stats.AgentDigest
- QueuedAgentService - Class in com.wavefront.agent
-
A wrapper for any WavefrontAPI that queues up any result posting if the backend is not available.
- QueuedAgentService(WavefrontV2API, String, int, ScheduledExecutorService, boolean, UUID, boolean, RecyclableRateLimiter, String) - Constructor for class com.wavefront.agent.QueuedAgentService
- QueuedAgentService.PostPushDataResultTask - Class in com.wavefront.agent
- QueuedAgentService.PostSourceTagResultTask - Class in com.wavefront.agent
- QueuedAgentService.PostSourceTagResultTask.ActionType - Enum in com.wavefront.agent
- QueuedAgentService.PostSourceTagResultTask.MessageType - Enum in com.wavefront.agent
- QueuedPushTooLargeException - Exception in com.wavefront.agent
- QueuedPushTooLargeException(String) - Constructor for exception com.wavefront.agent.QueuedPushTooLargeException
- QueuingChannelHandler<T> - Class in com.wavefront.agent.histogram
-
Inbound handler streaming a netty channel out to a square tape.
- QueuingChannelHandler(ObjectQueue<List<T>>, int, AtomicBoolean) - Constructor for class com.wavefront.agent.histogram.QueuingChannelHandler
R
- rawLogsHttpBufferSize - Variable in class com.wavefront.agent.AbstractAgent
- 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.
- rawLogsMaxReceivedLength - Variable in class com.wavefront.agent.AbstractAgent
- rawLogsPort - Variable in class com.wavefront.agent.AbstractAgent
- read(Bytes, long, AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
- read(Bytes, Utils.HistogramKey) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
- readMarshallable(WireIn) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
- readMarshallable(WireIn) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
- ReadProcessor - Class in com.wavefront.agent.logsharvesting
- ReadProcessor() - Constructor for class com.wavefront.agent.logsharvesting.ReadProcessor
- ReadProcessorContext - Class in com.wavefront.agent.logsharvesting
- ReadProcessorContext(Double) - Constructor for class com.wavefront.agent.logsharvesting.ReadProcessorContext
- readResolve() - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
- readResolve() - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
- recordAllData() - Method in class com.tdunning.math.stats.AgentDigest
-
Turns on internal data recording.
- reject(String, String) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
-
Reject the input object as invalid, i.e.
- reject(T) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
-
Reject the input object as invalid, i.e.
- reject(T, String) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
-
Reject the input object as invalid, i.e.
- 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.ResubmissionTaskQueue
- removeDescription(String, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledProxyAPI
-
Remove description from a source.
- removeDescription(String, boolean) - Method in class com.wavefront.agent.QueuedAgentService
- removeDescription(String, String) - Method in class com.wavefront.agent.QueuedAgentService
- removeTag(String, String, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledProxyAPI
-
Remove a single tag from a source.
- removeTag(String, String, boolean) - Method in class com.wavefront.agent.QueuedAgentService
- removeTag(String, String, String) - Method in class com.wavefront.agent.QueuedAgentService
- report(T) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
-
Validate and accept the input object.
- report(T, Object, Function<Object, String>) - Method in interface com.wavefront.agent.handlers.ReportableEntityHandler
-
Validate and accept the input object.
- ReportableConfig - Class in com.wavefront.agent.config
-
Wrapper class to simplify access to .properties file + track values as metrics as they are retrieved
- ReportableConfig() - Constructor for class com.wavefront.agent.config.ReportableConfig
- ReportableConfig(InputStream) - Constructor for class com.wavefront.agent.config.ReportableConfig
- ReportableConfig(String) - Constructor for class com.wavefront.agent.config.ReportableConfig
- ReportableEntityHandler<T> - Interface in com.wavefront.agent.handlers
-
Handler that processes incoming objects of a single entity type, validates them and hands them over to one of the
SenderTask
threads. - ReportableEntityHandlerFactory - Interface in com.wavefront.agent.handlers
-
Factory for
ReportableEntityHandler
objects. - ReportableEntityHandlerFactoryImpl - Class in com.wavefront.agent.handlers
-
Caching factory for
ReportableEntityHandler
objects. - ReportableEntityHandlerFactoryImpl(SenderTaskFactory, int, int, Supplier<ValidationConfiguration>) - Constructor for class com.wavefront.agent.handlers.ReportableEntityHandlerFactoryImpl
-
Create new instance.
- ReportableEntityPreprocessor - Class in com.wavefront.agent.preprocessor
-
A container class for multiple types of rules (point line-specific and parsed entity-specific) Created by Vasily on 9/15/16.
- ReportableEntityPreprocessor() - Constructor for class com.wavefront.agent.preprocessor.ReportableEntityPreprocessor
- reportEmptyHistogramStats - Variable in class com.wavefront.agent.config.LogsIngestionConfig
-
If true (default), simulate Yammer histogram behavior (report all stats as zeroes when histogram is empty).
- reportGauge(Number, MetricName) - Method in class com.wavefront.agent.config.ReportableConfig
- reportInternal(ReportPoint) - Method in class com.wavefront.agent.handlers.HistogramAccumulationHandlerImpl
- reportInternal(ReportSourceTag) - Method in class com.wavefront.agent.handlers.ReportSourceTagHandlerImpl
- reportInternal(Span) - Method in class com.wavefront.agent.handlers.SpanHandlerImpl
- reportInternal(SpanLogs) - Method in class com.wavefront.agent.handlers.SpanLogsHandlerImpl
- reportPoint(ReportPoint, String) - Method in interface com.wavefront.agent.PointHandler
-
Deprecated.Send a point for reporting.
- reportPoint(ReportPoint, String) - Method in class com.wavefront.agent.PointHandlerImpl
-
Deprecated.
- 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, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagIfNotExistsTransformer
- ReportPointAddTagIfNotExistsTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagIfNotExistsTransformer
-
Deprecated.
- ReportPointAddTagTransformer - Class in com.wavefront.agent.preprocessor
-
Creates a new point tag with a specified value, or overwrite an existing one.
- ReportPointAddTagTransformer(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
- ReportPointAddTagTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
-
Deprecated.
- ReportPointBlacklistRegexFilter - Class in com.wavefront.agent.preprocessor
-
Blacklist regex filter.
- ReportPointBlacklistRegexFilter(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointBlacklistRegexFilter
- ReportPointBlacklistRegexFilter(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointBlacklistRegexFilter
-
Deprecated.
- 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, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointDropTagTransformer
- ReportPointDropTagTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointDropTagTransformer
-
Deprecated.
- ReportPointExtractTagIfNotExistsTransformer - Class in com.wavefront.agent.preprocessor
-
Create a point tag by extracting a portion of a metric name, source name or another point tag.
- ReportPointExtractTagIfNotExistsTransformer(String, String, String, String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointExtractTagIfNotExistsTransformer
-
Deprecated.
- ReportPointExtractTagIfNotExistsTransformer(String, String, String, String, String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointExtractTagIfNotExistsTransformer
- ReportPointExtractTagTransformer - Class in com.wavefront.agent.preprocessor
-
Create a point tag by extracting a portion of a metric name, source name or another point tag Created by Vasily on 11/15/16.
- ReportPointExtractTagTransformer(String, String, String, String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
-
Deprecated.
- ReportPointExtractTagTransformer(String, String, String, String, String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
- ReportPointForceLowercaseTransformer - Class in com.wavefront.agent.preprocessor
-
Force lowercase transformer.
- ReportPointForceLowercaseTransformer(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointForceLowercaseTransformer
- ReportPointForceLowercaseTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointForceLowercaseTransformer
-
Deprecated.
- ReportPointLimitLengthTransformer - Class in com.wavefront.agent.preprocessor
- ReportPointLimitLengthTransformer(String, int, LengthLimitActionType, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointLimitLengthTransformer
- ReportPointRenameTagTransformer - Class in com.wavefront.agent.preprocessor
-
Rename a point tag (optional: if its value matches a regex pattern) Created by Vasily on 9/13/16.
- ReportPointRenameTagTransformer(String, String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointRenameTagTransformer
- ReportPointRenameTagTransformer(String, String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointRenameTagTransformer
-
Deprecated.
- ReportPointReplaceRegexTransformer - Class in com.wavefront.agent.preprocessor
-
Replace regex transformer.
- ReportPointReplaceRegexTransformer(String, String, String, String, Integer, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointReplaceRegexTransformer
- ReportPointReplaceRegexTransformer(String, String, String, String, Integer, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointReplaceRegexTransformer
-
Deprecated.
- reportPoints(List<ReportPoint>) - Method in interface com.wavefront.agent.PointHandler
-
Deprecated.Send a collection of points for reporting.
- reportPoints(List<ReportPoint>) - Method in class com.wavefront.agent.PointHandlerImpl
-
Deprecated.
- ReportPointTimestampInRangeFilter - Class in com.wavefront.agent.preprocessor
-
Filter condition for valid timestamp - should be no more than 1 day in the future and no more than X hours (usually 8760, or 1 year) in the past Created by Vasily on 9/16/16.
- ReportPointTimestampInRangeFilter(int, int) - Constructor for class com.wavefront.agent.preprocessor.ReportPointTimestampInRangeFilter
- ReportPointWhitelistRegexFilter - Class in com.wavefront.agent.preprocessor
-
Whitelist regex filter.
- ReportPointWhitelistRegexFilter(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.ReportPointWhitelistRegexFilter
- ReportPointWhitelistRegexFilter(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointWhitelistRegexFilter
-
Deprecated.
- reportSettingAsGauge(Number, String) - Method in class com.wavefront.agent.config.ReportableConfig
- ReportSourceTagHandlerImpl - Class in com.wavefront.agent.handlers
-
This class will validate parsed source tags and distribute them among SenderTask threads.
- ReportSourceTagHandlerImpl(String, int, Collection<SenderTask>) - Constructor for class com.wavefront.agent.handlers.ReportSourceTagHandlerImpl
- requestsDiscarded - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
- ResubmissionTask<T extends ResubmissionTask<T>> - Class in com.wavefront.agent
-
A task for resubmission.
- ResubmissionTask() - Constructor for class com.wavefront.agent.ResubmissionTask
- ResubmissionTaskDeserializer - Class in com.wavefront.agent
-
Deserializer of ResubmissionTasks from JSON.
- ResubmissionTaskDeserializer() - Constructor for class com.wavefront.agent.ResubmissionTaskDeserializer
- ResubmissionTaskQueue - Class in com.wavefront.agent
-
Thread-safe TaskQueue for holding ResubmissionTask objects
- ResubmissionTaskQueue(ObjectQueue<ResubmissionTask>, TaskInjector<ResubmissionTask>) - Constructor for class com.wavefront.agent.ResubmissionTaskQueue
- retryBackoffBaseSeconds - Variable in class com.wavefront.agent.AbstractAgent
- retryBackoffBaseSecondsInitialValue - Variable in class com.wavefront.agent.AbstractAgent
- retryCheckin - Variable in class com.wavefront.agent.AbstractAgent
- retryThreads - Variable in class com.wavefront.agent.AbstractAgent
- ruleEnd(long) - Method in class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
-
Measure rule execution time and add it to ruleCpuTimeNanosCounter (if available)
- ruleMetrics - Variable in class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
- ruleMetrics - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
- ruleMetrics - Variable in class com.wavefront.agent.preprocessor.SpanAddAnnotationTransformer
- ruleMetrics - Variable in class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
- ruleStart() - Method in class com.wavefront.agent.preprocessor.PreprocessorRuleMetrics
-
Mark rule start time, increment ruleCheckedCounter (if available) by 1
- run() - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache.AccumulationCacheMonitor
- run() - Method in class com.wavefront.agent.histogram.DroppingSender
- run() - Method in class com.wavefront.agent.histogram.PointHandlerDispatcher
- run() - Method in class com.wavefront.agent.listeners.tracing.JaegerThriftCollectorHandler
- run() - Method in class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
- run() - Method in class com.wavefront.agent.logsharvesting.MetricsReporter
- run() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.
- Runner - Class in org.logstash.beats
- Runner() - Constructor for class org.logstash.beats.Runner
S
- save - com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.ActionType
- sendDataTasks - Variable in class com.wavefront.agent.PointHandlerImpl
-
Deprecated.
- 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(ForceQueueEnabledProxyAPI, UUID, RecyclableRateLimiter, AtomicInteger, AtomicInteger, AtomicInteger) - Constructor for class com.wavefront.agent.handlers.SenderTaskFactoryImpl
-
Create new instance.
- 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
- serialize(Class, Type, JsonSerializationContext) - Method in class com.wavefront.agent.histogram.MapSettings.ClassNameSerializer
- serialize(Object, Type, JsonSerializationContext) - Method in class com.wavefront.agent.ResubmissionTaskDeserializer
- server - Variable in class com.wavefront.agent.AbstractAgent
- Server - Class in org.logstash.beats
- Server(String, int, int, int) - Constructor for class org.logstash.beats.Server
- serverEndpointUrl - Variable in class com.wavefront.agent.AbstractAgent
- service - Variable in class com.wavefront.agent.ResubmissionTask
-
To be injected.
- 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, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledProxyAPI
-
Set description for a source.
- setDescription(String, String, boolean) - Method in class com.wavefront.agent.QueuedAgentService
- setDescription(String, String, String) - Method in class com.wavefront.agent.QueuedAgentService
- 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
- setHttpClient(HttpClient) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
- 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(AtomicDouble) - Static method in class com.wavefront.agent.QueuedAgentService
- setSplitBatchSize(AtomicInteger) - Static method in class com.wavefront.agent.QueuedAgentService
-
Deprecated.
- setStaticToken(String) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
- setTags(String, String, List<String>) - Method in class com.wavefront.agent.QueuedAgentService
- setTags(String, List<String>, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledProxyAPI
-
Sets tags for a host, overriding existing tags.
- setTags(String, List<String>, boolean) - Method in class com.wavefront.agent.QueuedAgentService
- setTokenIntrospectionAuthorizationHeader(String) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
- setTokenIntrospectionServiceUrl(String) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
- setTokenValidationMethod(TokenValidationMethod) - Method in class com.wavefront.agent.auth.TokenAuthenticatorBuilder
- 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
- setupCheckins() - Method in class com.wavefront.agent.AbstractAgent
- setupMemoryGuard(double) - Method in class com.wavefront.agent.PushAgent
- setupQueueing(WavefrontV2API) - Method in class com.wavefront.agent.AbstractAgent
- setValue(T) - Method in class com.wavefront.agent.logsharvesting.ChangeableGauge
- setVerifyMode(SslSimpleBuilder.SslClientVerifyMode) - Method in class org.logstash.netty.SslSimpleBuilder
- setWrappedApi(WavefrontV2API) - Method in class com.wavefront.agent.QueuedAgentService
- 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
- SharedMetricsRegistry() - Constructor for class com.wavefront.agent.SharedMetricsRegistry
- shutdown() - Method in class com.wavefront.agent.AbstractAgent
- shutdown() - Method in interface com.wavefront.agent.handlers.ReportableEntityHandlerFactory
-
Perform finalizing tasks on handlers.
- shutdown() - Method in class com.wavefront.agent.handlers.ReportableEntityHandlerFactoryImpl
- shutdown() - Method in interface com.wavefront.agent.handlers.SenderTask
-
Shut down the scheduler for this task (prevent future scheduled runs).
- shutdown() - Method in interface com.wavefront.agent.handlers.SenderTaskFactory
-
Shut down all tasks.
- shutdown() - Method in class com.wavefront.agent.handlers.SenderTaskFactoryImpl
- shutdown() - Method in class com.wavefront.agent.PostPushDataTimedTask
-
Deprecated.Shut down the scheduler for this task (prevent future scheduled runs)
- shutdown() - Method in class com.wavefront.agent.QueuedAgentService
- shutdownTasks - Variable in class com.wavefront.agent.AbstractAgent
- shuttingDown - Variable in class com.wavefront.agent.AbstractAgent
- size() - 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.QueuedAgentService.PostPushDataResultTask
- size() - Method in class com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask
- size() - Method in class com.wavefront.agent.ResubmissionTask
- 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
- soLingerTime - Variable in class com.wavefront.agent.AbstractAgent
- source - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
- SOURCE_TAG - 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, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanAddAnnotationIfNotExistsTransformer
- SpanAddAnnotationTransformer - Class in com.wavefront.agent.preprocessor
-
Creates a new annotation with a specified key/value pair.
- SpanAddAnnotationTransformer(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanAddAnnotationTransformer
- SpanBlacklistRegexFilter - Class in com.wavefront.agent.preprocessor
-
Blacklist regex filter.
- SpanBlacklistRegexFilter(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanBlacklistRegexFilter
- SpanDerivedMetricsUtils - Class in com.wavefront.agent.listeners.tracing
-
Util methods to generate data (metrics/histograms/heartbeats) from tracing spans
- SpanDerivedMetricsUtils() - Constructor for class com.wavefront.agent.listeners.tracing.SpanDerivedMetricsUtils
- SpanDropAnnotationTransformer - Class in com.wavefront.agent.preprocessor
-
Removes a span annotation with a specific key if its value matches an optional regex pattern (always remove if null)
- SpanDropAnnotationTransformer(String, String, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanDropAnnotationTransformer
- SpanExtractAnnotationIfNotExistsTransformer - Class in com.wavefront.agent.preprocessor
-
Create a new span annotation by extracting a portion of a span name, source name or another annotation
- SpanExtractAnnotationIfNotExistsTransformer(String, String, String, String, String, String, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanExtractAnnotationIfNotExistsTransformer
- SpanExtractAnnotationTransformer - Class in com.wavefront.agent.preprocessor
-
Create a point tag by extracting a portion of a metric name, source name or another point tag
- SpanExtractAnnotationTransformer(String, String, String, String, String, String, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanExtractAnnotationTransformer
- SpanForceLowercaseTransformer - Class in com.wavefront.agent.preprocessor
-
Force lowercase transformer.
- SpanForceLowercaseTransformer(String, String, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanForceLowercaseTransformer
- SpanHandlerImpl - Class in com.wavefront.agent.handlers
-
Handler that processes incoming Span objects, validates them and hands them over to one of the
SenderTask
threads. - SpanLimitLengthTransformer - Class in com.wavefront.agent.preprocessor
- SpanLimitLengthTransformer(String, int, LengthLimitActionType, String, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanLimitLengthTransformer
- spanLogsDisabled - Variable in class com.wavefront.agent.AbstractAgent
- 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. - SpanReplaceRegexTransformer - Class in com.wavefront.agent.preprocessor
-
Replace regex transformer.
- SpanReplaceRegexTransformer(String, String, String, String, Integer, boolean, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanReplaceRegexTransformer
- SpanSamplerUtils - Class in com.wavefront.agent.sampler
-
Helper class for creating span samplers.
- SpanSamplerUtils() - Constructor for class com.wavefront.agent.sampler.SpanSamplerUtils
- SpanWhitelistRegexFilter - Class in com.wavefront.agent.preprocessor
-
Whitelist regex filter.
- SpanWhitelistRegexFilter(String, String, PreprocessorRuleMetrics) - Constructor for class com.wavefront.agent.preprocessor.SpanWhitelistRegexFilter
- splitPushData(String) - Static method in class com.wavefront.agent.handlers.LineDelimitedUtils
-
Split a newline-delimited payload into a string array.
- splitPushWhenRateLimited - Variable in class com.wavefront.agent.AbstractAgent
- splitTask() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
- splitTask() - Method in class com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask
- splitTask() - Method in class com.wavefront.agent.ResubmissionTask
- SSLConnectionSocketFactoryImpl - Class in com.wavefront.agent
-
Delegated SSLConnectionSocketFactory that sets SoTimeout explicitly (for Apache HttpClient).
- SSLConnectionSocketFactoryImpl(SSLConnectionSocketFactory, int) - Constructor for class com.wavefront.agent.SSLConnectionSocketFactoryImpl
- SslSimpleBuilder - Class in org.logstash.netty
-
Created by ph on 2016-05-27.
- SslSimpleBuilder(String, String, String) - Constructor for class org.logstash.netty.SslSimpleBuilder
- SslSimpleBuilder.SslClientVerifyMode - Enum in org.logstash.netty
- SSLSocketFactoryImpl - Class in com.wavefront.agent
-
Delegated SSLSocketFactory that sets SoTimeout explicitly.
- SSLSocketFactoryImpl(SSLSocketFactory, int) - Constructor for class com.wavefront.agent.SSLSocketFactoryImpl
- start() - Method in class com.wavefront.agent.logsharvesting.LogsIngester
- start() - Method in class com.wavefront.agent.PushAgentDaemon
- start() - Method in class com.wavefront.agent.QueuedAgentService
- start(String[]) - Method in class com.wavefront.agent.AbstractAgent
-
Entry-point for the application.
- startAdminListener(int) - Method in class com.wavefront.agent.PushAgent
- startAsManagedThread(Runnable, String) - Method in class com.wavefront.agent.PushAgent
- startDataDogListener(String, ReportableEntityHandlerFactory, HttpClient) - Method in class com.wavefront.agent.PushAgent
- startDeltaCounterListener(String, SharedGraphiteHostAnnotator, SenderTaskFactory) - Method in class com.wavefront.agent.PushAgent
- startGraphiteListener(String, ReportableEntityHandlerFactory, SharedGraphiteHostAnnotator) - Method in class com.wavefront.agent.PushAgent
- startHealthCheckListener(int) - Method in class com.wavefront.agent.PushAgent
- startHistogramListeners(Iterator<String>, ReportableEntityHandler<ReportPoint>, SharedGraphiteHostAnnotator, Utils.Granularity, int, boolean, File, Long, int, int, short) - 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
- 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
- startQueueingService() - Method in class com.wavefront.agent.AbstractAgent
- startRawLogsIngestionListener(int, LogsIngester) - Method in class com.wavefront.agent.PushAgent
- startRelayListener(String, ReportableEntityHandlerFactory, SharedGraphiteHostAnnotator) - Method in class com.wavefront.agent.PushAgent
- startTraceJaegerListener(String, ReportableEntityHandlerFactory, WavefrontSender, Sampler) - Method in class com.wavefront.agent.PushAgent
- startTraceListener(String, ReportableEntityHandlerFactory, Sampler) - Method in class com.wavefront.agent.PushAgent
- startTraceZipkinListener(String, ReportableEntityHandlerFactory, WavefrontSender, Sampler) - Method in class com.wavefront.agent.PushAgent
- startWriteHttpJsonListener(String, ReportableEntityHandlerFactory) - Method in class com.wavefront.agent.PushAgent
- STATIC_TOKEN - com.wavefront.agent.auth.TokenValidationMethod
- stop() - Method in class com.wavefront.agent.PushAgentDaemon
- stop() - Method in class org.logstash.beats.Server
- stopListeners() - Method in class com.wavefront.agent.AbstractAgent
- stopListeners() - Method in class com.wavefront.agent.PushAgent
T
- tag - com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.MessageType
- tag - Variable in class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
- tag - Variable in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
- test(String, String[]) - Method in class com.wavefront.agent.preprocessor.PointLineBlacklistRegexFilter
- test(String, String[]) - Method in class com.wavefront.agent.preprocessor.PointLineWhitelistRegexFilter
- 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.ReportPointBlacklistRegexFilter
- test(ReportPoint, String[]) - Method in class com.wavefront.agent.preprocessor.ReportPointTimestampInRangeFilter
- test(ReportPoint, String[]) - Method in class com.wavefront.agent.preprocessor.ReportPointWhitelistRegexFilter
- test(Span, String[]) - Method in class com.wavefront.agent.preprocessor.SpanBlacklistRegexFilter
- test(Span, String[]) - Method in class com.wavefront.agent.preprocessor.SpanWhitelistRegexFilter
- TimeProvider - Interface in com.wavefront.agent.histogram
- timeSeries(LogsMessage, Double[]) - Method in class com.wavefront.agent.config.MetricMatcher
-
Convert the given message to a timeSeries and a telemetry datum.
- TimeSeriesUtils - Class in com.wavefront.agent.logsharvesting
- TimeSeriesUtils() - Constructor for class com.wavefront.agent.logsharvesting.TimeSeriesUtils
- toHistogram(int) - Method in class com.tdunning.math.stats.AgentDigest
-
Creates a reporting Histogram from this AgentDigest (marked with the supplied duration).
- token - Variable in class com.wavefront.agent.AbstractAgent
- token - Variable in class com.wavefront.agent.ResubmissionTask
-
To be injected.
- tokenAuthenticator - Variable in class com.wavefront.agent.AbstractAgent
- tokenAuthenticator - Variable in class com.wavefront.agent.listeners.AbstractPortUnificationHandler
- 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.
- TokenValidationMethod.TokenValidationMethodConverter - Class in com.wavefront.agent.auth
- TokenValidationMethodConverter() - Constructor for class com.wavefront.agent.auth.TokenValidationMethod.TokenValidationMethodConverter
- toMetricName(TimeSeries) - Static method in class com.wavefront.agent.logsharvesting.TimeSeriesUtils
- toString() - Method in class com.wavefront.agent.config.Configuration
- toString() - Method in class com.wavefront.agent.handlers.HandlerKey
- toString() - Method in class com.wavefront.agent.histogram.MapLoader
- toString() - Method in class com.wavefront.agent.histogram.MapSettings
- toString() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
- toString() - Method in class com.wavefront.common.HostMetricTagsPair
- toString() - Method in class org.logstash.beats.BatchIdentity
- traceAlwaysSampleErrors - Variable in class com.wavefront.agent.AbstractAgent
- traceDerivedCustomTagKeys - Variable in class com.wavefront.agent.AbstractAgent
- traceDerivedCustomTagKeysProperty - Variable in class com.wavefront.agent.AbstractAgent
- traceDisabled - Variable in class com.wavefront.agent.AbstractAgent
- traceJaegerApplicationName - Variable in class com.wavefront.agent.AbstractAgent
- traceJaegerListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- traceListenerHttpBufferSize - Variable in class com.wavefront.agent.AbstractAgent
- traceListenerMaxReceivedLength - Variable in class com.wavefront.agent.AbstractAgent
- traceListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- TracePortUnificationHandler - Class in com.wavefront.agent.listeners.tracing
-
Process incoming trace-formatted data.
- TracePortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityDecoder<String, Span>, ReportableEntityDecoder<JsonNode, SpanLogs>, Supplier<ReportableEntityPreprocessor>, ReportableEntityHandler<Span>, ReportableEntityHandler<SpanLogs>, Sampler, boolean, 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, Sampler, boolean, Supplier<Boolean>, Supplier<Boolean>) - Constructor for class com.wavefront.agent.listeners.tracing.TracePortUnificationHandler
- traceSamplingDuration - Variable in class com.wavefront.agent.AbstractAgent
- traceSamplingRate - Variable in class com.wavefront.agent.AbstractAgent
- traceZipkinApplicationName - Variable in class com.wavefront.agent.AbstractAgent
- traceZipkinListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- TRACING_DERIVED_PREFIX - Static variable in class com.wavefront.agent.listeners.tracing.SpanDerivedMetricsUtils
- transform(T) - Method in class com.wavefront.agent.preprocessor.Preprocessor
-
Apply all transformation rules sequentially
- TRUNCATE - com.wavefront.agent.preprocessor.LengthLimitActionType
- TRUNCATE_WITH_ELLIPSIS - com.wavefront.agent.preprocessor.LengthLimitActionType
U
- unparsed_params - Variable in class com.wavefront.agent.AbstractAgent
- 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
-
- useWavefrontHistograms - Variable in class com.wavefront.agent.config.LogsIngestionConfig
-
If true, use
WavefrontHistogram
s rather thanHistogram
s. - Utils - Class in com.wavefront.agent.histogram
-
Helpers around histograms
- Utils - Class in com.wavefront.agent
-
A placeholder class for miscellaneous utility methods.
- Utils() - Constructor for class com.wavefront.agent.Utils
- Utils.Granularity - Enum in com.wavefront.agent.histogram
-
Standard supported aggregation Granularities.
- Utils.HistogramKey - Class in com.wavefront.agent.histogram
-
Uniquely identifies a time-series - time-interval pair.
- Utils.HistogramKeyMarshaller - Class in com.wavefront.agent.histogram
-
(For now, a rather trivial) encoding of
Utils.HistogramKey
the form short length and bytes Consider using chronicle-values or making this stateful with a local byte[] / Stringbuffers to be a little more efficient about encodings.
V
- 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
- 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.formatter.DataFormat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.wavefront.agent.histogram.Utils.Granularity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.wavefront.agent.preprocessor.LengthLimitActionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.ActionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.MessageType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.logstash.netty.SslSimpleBuilder.SslClientVerifyMode
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.wavefront.agent.auth.TokenValidationMethod
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.wavefront.agent.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.Utils.Granularity
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.wavefront.agent.preprocessor.LengthLimitActionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.ActionType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.wavefront.agent.QueuedAgentService.PostSourceTagResultTask.MessageType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.logstash.netty.SslSimpleBuilder.SslClientVerifyMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- 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
- VERSION_1 - Static variable in class org.logstash.beats.Protocol
- VERSION_2 - Static variable in class org.logstash.beats.Protocol
W
- WavefrontPortUnificationHandler - Class in com.wavefront.agent.listeners
-
Process incoming Wavefront-formatted data.
- WavefrontPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, Map<ReportableEntityType, ReportableEntityDecoder>, ReportableEntityHandlerFactory, SharedGraphiteHostAnnotator, Supplier<ReportableEntityPreprocessor>) - Constructor for class com.wavefront.agent.listeners.WavefrontPortUnificationHandler
-
Create new instance with lazy initialization for handlers.
- WavefrontV2API - Interface in com.wavefront.agent.api
-
Consolidated interface for proxy APIs.
- whitelistRegex - Variable in class com.wavefront.agent.AbstractAgent
- write(Utils.HistogramKey, AgentDigest) - Method in class com.wavefront.agent.histogram.accumulator.Layering
- write(Bytes, long, AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
- write(Bytes, Utils.HistogramKey) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
- writeExceptionText(Throwable, StringBuilder) - Static method in class com.wavefront.agent.channel.ChannelUtils
-
Write detailed exception text to a StringBuilder.
- writeHttpJsonListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
- WriteHttpJsonPortUnificationHandler - Class in com.wavefront.agent.listeners
-
This class handles incoming messages in write_http format.
- WriteHttpJsonPortUnificationHandler(String, TokenAuthenticator, HealthCheckManager, ReportableEntityHandler<ReportPoint>, 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, HttpResponseStatus, Object) - Static method in class com.wavefront.agent.channel.ChannelUtils
-
Writes a HTTP response to channel.
- writeHttpResponse(ChannelHandlerContext, HttpResponseStatus, Object, boolean) - Static method in class com.wavefront.agent.channel.ChannelUtils
-
Writes a HTTP response to channel.
- writeHttpResponse(ChannelHandlerContext, HttpResponseStatus, Object, FullHttpRequest) - Static method in class com.wavefront.agent.channel.ChannelUtils
-
Writes a HTTP response to channel.
- writeMarshallable(WireOut) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
- writeMarshallable(WireOut) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
- writeTo(JsonNode, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.wavefront.agent.JsonNodeWriter
Z
- ZipkinPortUnificationHandler - Class in com.wavefront.agent.listeners.tracing
-
Handler that processes Zipkin trace data over HTTP and converts them to Wavefront format.
- ZipkinPortUnificationHandler(String, HealthCheckManager, ReportableEntityHandlerFactory, WavefrontSender, Supplier<Boolean>, Supplier<Boolean>, Supplier<ReportableEntityPreprocessor>, Sampler, boolean, String, Set<String>) - Constructor for class com.wavefront.agent.listeners.tracing.ZipkinPortUnificationHandler
All Classes All Packages