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

A

AbstractAgent - Class in com.wavefront.agent
Agent that runs remotely on a server collecting metrics.
AbstractAgent() - Constructor for class com.wavefront.agent.AbstractAgent
 
AbstractAgent(boolean, boolean) - Constructor for class com.wavefront.agent.AbstractAgent
 
AccumulationCache - Class in com.wavefront.agent.histogram.accumulator
Expose a local cache of limited size along with a task to flush that cache to the backing store.
AccumulationCache(ConcurrentMap<Utils.HistogramKey, AgentDigest>, long, Ticker) - Constructor for class com.wavefront.agent.histogram.accumulator.AccumulationCache
 
AccumulationTask - Class in com.wavefront.agent.histogram.accumulator
Histogram accumulation task.
AccumulationTask(ObjectQueue<List<String>>, ConcurrentMap<Utils.HistogramKey, AgentDigest>, Decoder<String>, PointHandler, Validation.Level, long, Utils.Granularity, short) - Constructor for class com.wavefront.agent.histogram.accumulator.AccumulationTask
 
Ack - Class in org.logstash.beats
 
Ack(byte, int) - Constructor for class org.logstash.beats.Ack
 
AckEncoder - Class in org.logstash.beats
This Class is mostly used in the test suite to make the right assertions with the encoded data frame.
AckEncoder() - Constructor for class org.logstash.beats.AckEncoder
 
activeListeners - Variable in class com.wavefront.agent.AbstractAgent
 
add(double, int) - Method in class com.tdunning.math.stats.AgentDigest
 
add(double, int, List<Double>) - Method in class com.tdunning.math.stats.AgentDigest
 
addBlockedSample(String) - Method in class com.wavefront.agent.PostPushDataTimedTask
 
addFilter(AnnotatedPredicate<T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a filter rule
addFilter(int, AnnotatedPredicate<T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a filter rule and place it at a specific index
additionalPatterns - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Additional grok patterns to use in pattern matching for the above MetricMatchers.
addMessage(Message) - Method in class org.logstash.beats.Batch
 
addPoint(String) - Method in class com.wavefront.agent.PostPushDataTimedTask
 
addPoints(List<String>) - Method in class com.wavefront.agent.PostPushDataTimedTask
 
addTransformer(Function<T, T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a transformation rule
addTransformer(int, Function<T, T>) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Register a transformation rule and place it at a specific index
agentAPI - Variable in class com.wavefront.agent.AbstractAgent
 
agentConfigProcessed(UUID) - Method in class com.wavefront.agent.QueuedAgentService
 
AgentDigest - Class in com.tdunning.math.stats
NOTE: This is a pruned and modified version of MergingDigest.
AgentDigest(short, long) - Constructor for class com.tdunning.math.stats.AgentDigest
 
AgentDigest.AgentDigestMarshaller - Class in com.tdunning.math.stats
Stateless AgentDigest codec for chronicle maps
agentError(UUID, String) - Method in class com.wavefront.agent.QueuedAgentService
 
agentId - Variable in class com.wavefront.agent.AbstractAgent
 
agentMetrics - Variable in class com.wavefront.agent.AbstractAgent
 
agentMetricsCaptureTs - Variable in class com.wavefront.agent.AbstractAgent
 
agentMetricsPointTags - Variable in class com.wavefront.agent.AbstractAgent
 
AgentPreprocessorConfiguration - Class in com.wavefront.agent.preprocessor
Parses and stores all preprocessor rules (organized by listening port) Created by Vasily on 9/15/16.
AgentPreprocessorConfiguration() - Constructor for class com.wavefront.agent.preprocessor.AgentPreprocessorConfiguration
 
aggregationIntervalSeconds - Variable in class com.wavefront.agent.config.LogsIngestionConfig
How often metrics are aggregated and sent to wavefront.
AnnotatedPredicate<T> - Class in com.wavefront.agent.preprocessor
This is the base class for all "filter"-type rules.
AnnotatedPredicate() - Constructor for class com.wavefront.agent.preprocessor.AnnotatedPredicate
 
apply(String) - Method in class com.wavefront.agent.formatter.GraphiteFormatter
 
apply(T) - Method in class com.wavefront.agent.preprocessor.AnnotatedPredicate
 
apply(String) - Method in class com.wavefront.agent.preprocessor.PointLineBlacklistRegexFilter
 
apply(String) - Method in class com.wavefront.agent.preprocessor.PointLineReplaceRegexTransformer
 
apply(String) - Method in class com.wavefront.agent.preprocessor.PointLineWhitelistRegexFilter
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointAddPrefixTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointAddTagIfNotExistsTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointBlacklistRegexFilter
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointDropTagTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointExtractTagTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointRenameTagTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointReplaceRegexTransformer
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointTimestampInRangeFilter
 
apply(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointWhitelistRegexFilter
 
asBytes(ByteBuffer) - Method in class com.tdunning.math.stats.AgentDigest
 
asSmallBytes(ByteBuffer) - Method in class com.tdunning.math.stats.AgentDigest
 
avgHistogramDigestBytes - Variable in class com.wavefront.agent.AbstractAgent
 
avgHistogramKeyBytes - Variable in class com.wavefront.agent.AbstractAgent
 

B

Batch - Class in org.logstash.beats
 
Batch() - Constructor for class org.logstash.beats.Batch
 
BeatsHandler - Class in org.logstash.beats
 
BeatsHandler(IMessageListener) - Constructor for class org.logstash.beats.BeatsHandler
 
BeatsParser - Class in org.logstash.beats
 
BeatsParser() - Constructor for class org.logstash.beats.BeatsParser
 
BeatsParser.InvalidFrameProtocolException - Exception in org.logstash.beats
 
blacklistRegex - Variable in class com.wavefront.agent.AbstractAgent
 
blockedPointsPerBatch - Variable in class com.wavefront.agent.PointHandlerImpl
 
bufferSpaceLeft - Variable in class com.wavefront.agent.AbstractAgent
 
build(ByteBufAllocator) - Method in class org.logstash.netty.SslSimpleBuilder
 
byteSize() - Method in class com.tdunning.math.stats.AgentDigest
 

C

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
 
channelRead0(ChannelHandlerContext, String) - Method in class com.wavefront.agent.ChannelStringHandler
 
channelRead0(ChannelHandlerContext, Object) - Method in class com.wavefront.agent.histogram.QueuingChannelHandler
 
channelRead0(ChannelHandlerContext, Batch) - Method in class org.logstash.beats.BeatsHandler
 
ChannelStringHandler - Class in com.wavefront.agent
Parses points from a channel using the given decoder and send it off to the AgentAPI interface.
ChannelStringHandler(Decoder<String>, PointHandler, PointPreprocessor) - Constructor for class com.wavefront.agent.ChannelStringHandler
 
charactersAreValid(String) - Static method in class com.wavefront.agent.Validation
 
checkin(UUID, String, String, String, Long, Boolean, JsonNode, Boolean, Boolean) - Method in class com.wavefront.agent.QueuedAgentService
 
childChannelOptions - Variable in class com.wavefront.agent.PushAgent
 
close() - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
CODE_COMPRESSED_FRAME - Static variable in class org.logstash.beats.Protocol
 
CODE_FRAME - Static variable in class org.logstash.beats.Protocol
 
CODE_JSON_FRAME - Static variable in class org.logstash.beats.Protocol
 
CODE_WINDOW_SIZE - Static variable in class org.logstash.beats.Protocol
 
com.google.common.util.concurrent - package com.google.common.util.concurrent
 
com.tdunning.math.stats - package com.tdunning.math.stats
 
com.wavefront - package com.wavefront
 
com.wavefront.agent - package com.wavefront.agent
 
com.wavefront.agent.api - package com.wavefront.agent.api
 
com.wavefront.agent.config - package com.wavefront.agent.config
 
com.wavefront.agent.formatter - package com.wavefront.agent.formatter
 
com.wavefront.agent.histogram - package com.wavefront.agent.histogram
 
com.wavefront.agent.histogram.accumulator - package com.wavefront.agent.histogram.accumulator
 
com.wavefront.agent.histogram.tape - package com.wavefront.agent.histogram.tape
 
com.wavefront.agent.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
 
commitHeaders(ClientInvocation, HttpURLConnection) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
compareTo(Message) - Method in class org.logstash.beats.Message
 
complete() - Method in class org.logstash.beats.Batch
 
compress() - Method in class com.tdunning.math.stats.AgentDigest
 
compression() - Method in class com.tdunning.math.stats.AgentDigest
 
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
 
connectSocket(int, Socket, HttpHost, InetSocketAddress, InetSocketAddress, HttpContext) - Method in class com.wavefront.agent.SSLConnectionSocketFactoryImpl
 
counters - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Counters to ingest from incoming log data.
create(double, double) - Static method in class com.google.common.util.concurrent.RecyclableRateLimiter
 
createAgentService() - Method in class com.wavefront.agent.AbstractAgent
Create RESTeasy proxies for remote calls via HTTP.
createConnection(ClientInvocation) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
createLayeredSocket(Socket, String, int, HttpContext) - Method in class com.wavefront.agent.SSLConnectionSocketFactoryImpl
 
createSocket(HttpContext) - Method in class com.wavefront.agent.SSLConnectionSocketFactoryImpl
 
createSocket(Socket, String, int, boolean) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
createSocket() - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
createSocket(InetAddress, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
createSocket(InetAddress, int, InetAddress, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
createSocket(String, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
createSocket(String, int, InetAddress, int) - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
currentAgentId - Variable in class com.wavefront.agent.ResubmissionTask
To be injected.
customSourceTags - Variable in class com.wavefront.agent.AbstractAgent
 
customSourceTagsProperty - Variable in class com.wavefront.agent.AbstractAgent
 

D

dataBackfillCutoffHours - Variable in class com.wavefront.agent.AbstractAgent
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class org.logstash.beats.BeatsParser
 
DEFAULT_CIPHERS - Static variable in class org.logstash.netty.SslSimpleBuilder
 
delete(Utils.HistogramKey, AgentDigest, RemovalCause) - Method in class com.wavefront.agent.histogram.accumulator.Layering
 
deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class com.wavefront.agent.ResubmissionTaskDeserializer
 
destroy() - Method in class com.wavefront.agent.PushAgentDaemon
 
disableRdnsLookup - Variable in class com.wavefront.agent.AbstractAgent
 
drainBuffersToQueue() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
DroppingSender - Class in com.wavefront.agent.histogram
Dummy sender.
DroppingSender(ObjectQueue<ReportPoint>) - Constructor for class com.wavefront.agent.histogram.DroppingSender
 

E

enableSSL(SslSimpleBuilder) - Method in class org.logstash.beats.Server
 
encode(ChannelHandlerContext, Ack, ByteBuf) - Method in class org.logstash.beats.AckEncoder
 
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.histogram.Utils.HistogramKey
 
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.ChannelStringHandler
 
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.PostWorkUnitResultTask
 
executeRequest(ClientInvocation, HttpURLConnection) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
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.

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
flush() - Method in class com.wavefront.agent.logsharvesting.LogsIngester
 
FlushProcessorContext - Class in com.wavefront.agent.logsharvesting
 
flushThreads - Variable in class com.wavefront.agent.AbstractAgent
 
forceConfigReload() - Method in class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
Forces the next call to LogsIngestionConfigManager.getConfig() to call the config supplier.
ForceQueueEnabledAgentAPI - Interface in com.wavefront.agent.api
 
forPointLine() - Method in class com.wavefront.agent.preprocessor.PointPreprocessor
 
forPort(String) - Method in class com.wavefront.agent.preprocessor.AgentPreprocessorConfiguration
 
forReportPoint() - Method in class com.wavefront.agent.preprocessor.PointPreprocessor
 
from(byte[]) - Method in class com.wavefront.agent.histogram.tape.TapeReportPointConverter
 
from(byte[]) - Method in class com.wavefront.agent.histogram.tape.TapeStringListConverter
 
fromMetricName(MetricName) - Static method in class com.wavefront.agent.logsharvesting.TimeSeriesUtils
 
fromMillis(long) - Static method in enum com.wavefront.agent.histogram.Utils.Granularity
 

G

gauges - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Gauges to ingest from incoming log data.
get() - Static method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
get(File) - Method in class com.wavefront.agent.histogram.MapLoader
 
get() - Static method in class com.wavefront.agent.histogram.tape.TapeReportPointConverter
 
get() - Static method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
getAgentId() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
getAttemptedPoints() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getAvailablePermits() - Method in class com.google.common.util.concurrent.RecyclableRateLimiter
Get the number of accumulated permits
getBatch() - Method in class org.logstash.beats.Message
 
getBatchSize() - Method in class org.logstash.beats.Batch
 
getBinDurationInMillis() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getBinId(long) - Method in enum com.wavefront.agent.histogram.Utils.Granularity
Bin id for an epoch time is the epoch time in the corresponding granularity.
getBinId() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getBinTimeMillis() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getBlockedSampleSize() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getBufferFlushTask() - Method in class com.wavefront.agent.histogram.QueuingChannelHandler
 
getBytesPerMinute() - Method in class com.wavefront.agent.QueuedAgentService
 
getCache() - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
 
getCompressionEnabledInstance() - Static method in class com.wavefront.agent.histogram.tape.TapeStringListConverter
Returns the TapeStringListConverter object instance with LZ4 compression enabled
getConfig() - Method in class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
 
getConfig(UUID, String, Long, Long, Long, Long, String, String) - Method in class com.wavefront.agent.QueuedAgentService
 
getCounter(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
getCurrentMillis() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
getDaemonId() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getData() - Method in class org.logstash.beats.Message
 
getDefaultCipherSuites() - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
getDefaultInstance() - Static method in class com.wavefront.agent.histogram.tape.TapeStringListConverter
Returns the TapeStringListConverter object instance with default settings (no compression)
getDispatchTimeMillis() - Method in class com.tdunning.math.stats.AgentDigest
Time at which this digest should be dispatched to wavefront.
getFlushingToQueueFlag() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getFlushTasks(String) - Method in class com.wavefront.agent.AbstractAgent
 
getFlushTasks(String, String) - Method in class com.wavefront.agent.AbstractAgent
 
getFormat() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
getGauge(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
getGranularityOrdinal() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getHeaders(HttpURLConnection) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
getHistogram(MetricName, MetricMatcher) - Method in class com.wavefront.agent.logsharvesting.EvictingMetricsRegistry
 
getHostnameVerifier() - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
getIdentityStream() - Method in class org.logstash.beats.Message
 
getInMillis() - Method in enum com.wavefront.agent.histogram.Utils.Granularity
Duration of a corresponding bin in milliseconds.
getKeySetAccessor() - Method in class com.wavefront.agent.histogram.accumulator.Layering
 
getLastFilterResult() - Method in class com.wavefront.agent.preprocessor.Preprocessor
Get the detailed message, if available, with the result of the last filter() operation
getLockObject() - Method in class com.wavefront.agent.ResubmissionTaskQueue
 
getLoggingTask() - Method in class com.wavefront.PointHandlerLoggingDecorator
 
getLogLine() - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
 
getLogLine() - Method in interface com.wavefront.agent.logsharvesting.LogsMessage
 
getMessage(T) - Method in class com.wavefront.agent.preprocessor.AnnotatedPredicate
If special handling is needed based on the result of apply(), override getMessage() to return more details
getMessage(ReportPoint) - Method in class com.wavefront.agent.preprocessor.ReportPointTimestampInRangeFilter
 
getMessages() - Method in class org.logstash.beats.Batch
 
getMetric() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getMetricMangler() - Method in class com.wavefront.agent.formatter.GraphiteFormatter
 
getNumApiCalls() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getNumPointsQueued() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getNumPointsToSend() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
getOps() - Method in class com.wavefront.agent.formatter.GraphiteFormatter
 
getPattern() - Method in class com.wavefront.agent.config.MetricMatcher
 
getProtocol() - Method in class org.logstash.beats.Ack
 
getProtocol() - Method in class org.logstash.beats.Batch
 
getPushData() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
getQueuedTasksCount() - Method in class com.wavefront.agent.QueuedAgentService
 
getRandomPostTask() - Method in class com.wavefront.agent.PointHandlerImpl
 
getResolveTask() - Method in class com.wavefront.agent.histogram.accumulator.AccumulationCache
Task to merge the contents of this cache with the corresponding backing store.
getSequence() - Method in class org.logstash.beats.Ack
 
getSequence() - Method in class org.logstash.beats.Message
 
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
 
getSslContext() - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
getSslKeyFile() - Method in class org.logstash.netty.SslSimpleBuilder
 
getSupportedCipherSuites() - Method in class com.wavefront.agent.SSLSocketFactoryImpl
 
getTags() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
getTagsAsMap() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
Unpacks tags into a map.
getTape(File) - Method in class com.wavefront.agent.histogram.tape.TapeDeck
 
getTimestampMillis() - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
 
getValue() - Method in class com.wavefront.agent.logsharvesting.ReadProcessorContext
 
getValueLabel() - Method in class com.wavefront.agent.config.MetricMatcher
 
getWorkUnitId() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
getWriteBackTask() - Method in class com.wavefront.agent.histogram.accumulator.Layering
Returns a runnable for writing back dirty entries to the backing store.
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

handleBlockedPoint(String) - Method in interface com.wavefront.agent.PointHandler
Called when a blocked line is encountered.
handleBlockedPoint(String) - Method in class com.wavefront.agent.PointHandlerImpl
 
handleBlockedPoint(String) - Method in class com.wavefront.PointHandlerLoggingDecorator
 
handlerAdded(ChannelHandlerContext) - Method in class org.logstash.beats.BeatsHandler
 
handlerRemoved(ChannelHandlerContext) - Method in class org.logstash.beats.BeatsHandler
 
hasCapture(String) - Method in class com.wavefront.agent.config.MetricMatcher
 
hasFilters() - Method in class com.wavefront.agent.preprocessor.Preprocessor
Check if any filters are registered
hashCode() - Method in class com.wavefront.agent.config.Configuration
 
hashCode() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
hasTransformers() - Method in class com.wavefront.agent.preprocessor.Preprocessor
Check if any transformation rules are registered
histogramAccumulatorResolveInterval - Variable in class com.wavefront.agent.AbstractAgent
 
histogramAccumulatorSize - Variable in class com.wavefront.agent.AbstractAgent
 
histogramCompression - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDayAccumulators - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDayFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDaysListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistAccumulators - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
 
histogramDistListenerPorts - 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
 
histogramHourFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
 
histogramHoursListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
HistogramLineIngester - Class in com.wavefront.agent.histogram
A ChannelInitializer for Histogram samples via TCP.
HistogramLineIngester(Collection<ChannelHandler>, int) - Constructor for class com.wavefront.agent.histogram.HistogramLineIngester
 
histogramMinsListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
histogramMinuteAccumulators - Variable in class com.wavefront.agent.AbstractAgent
 
histogramMinuteFlushSecs - Variable in class com.wavefront.agent.AbstractAgent
 
histograms - Variable in class com.wavefront.agent.config.LogsIngestionConfig
Histograms to ingest from incoming log data.
histogramScanExecutor - Variable in class com.wavefront.agent.PushAgent
 
histogramStateDirectory - Variable in class com.wavefront.agent.AbstractAgent
 
hostAuthenticated(UUID, UUID) - Method in class com.wavefront.agent.QueuedAgentService
 
hostConnectionEstablished(UUID, UUID) - Method in class com.wavefront.agent.QueuedAgentService
 
hostConnectionFailed(UUID, UUID, String) - Method in class com.wavefront.agent.QueuedAgentService
 
hostname - Variable in class com.wavefront.agent.AbstractAgent
 
hostnameVerifier - Variable in class com.wavefront.agent.JavaNetConnectionEngine
 
hostOrDefault(String) - Method in class com.wavefront.agent.logsharvesting.FilebeatMessage
 
hostOrDefault(String) - Method in interface com.wavefront.agent.logsharvesting.LogsMessage
 
httpConnectTimeout - Variable in class com.wavefront.agent.AbstractAgent
 
httpJsonPorts - Variable in class com.wavefront.agent.AbstractAgent
 
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
 
IMessageListener - Interface in org.logstash.beats
This class is implemented in ruby in `lib/logstash/inputs/beats/message_listener`, this class is used to link the events triggered from the different connection to the actual work inside the plugin.
incrementBlockedPoints() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
ingestLog(LogsMessage) - Method in class com.wavefront.agent.logsharvesting.LogsIngester
 
ingestLog(ChannelHandlerContext, String) - Method in class com.wavefront.agent.logsharvesting.RawLogsIngester
 
init(DaemonContext) - Method in class com.wavefront.agent.PushAgentDaemon
 
initChannel(Channel) - Method in class com.wavefront.agent.histogram.HistogramLineIngester
 
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.
invoke(ClientInvocation) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
isEmpty() - Method in class org.logstash.beats.Batch
 
isSslEnable() - Method in class org.logstash.beats.Server
 
isVersion2(byte) - Static method in class org.logstash.beats.Protocol
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.wavefront.agent.JsonNodeWriter
 

J

javaNetConnection - Variable in class com.wavefront.agent.AbstractAgent
 
JavaNetConnectionEngine - Class in com.wavefront.agent
ClientHttpEngine that uses HttpURLConnection to connect to an Http endpoint.
JavaNetConnectionEngine() - Constructor for class com.wavefront.agent.JavaNetConnectionEngine
 
JsonMetricsEndpoint - Class in com.wavefront.agent
Agent-side JSON metrics endpoint.
JsonMetricsEndpoint(String, String, String, String, int, PostPushDataTimedTask[], PointPreprocessor) - Constructor for class com.wavefront.agent.JsonMetricsEndpoint
 
JsonNodeWriter - Class in com.wavefront.agent
Writer that serializes JsonNodes.
JsonNodeWriter() - Constructor for class com.wavefront.agent.JsonNodeWriter
 

K

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
 
listen() - Method in class com.wavefront.agent.logsharvesting.RawLogsIngester
 
listen() - Method in class org.logstash.beats.Server
 
load(Utils.HistogramKey) - Method in class com.wavefront.agent.histogram.accumulator.Layering
 
loadFromStream(InputStream) - Method in class com.wavefront.agent.preprocessor.AgentPreprocessorConfiguration
 
loadLogsIngestionConfig() - Method in class com.wavefront.agent.AbstractAgent
 
localAgent - Variable in class com.wavefront.agent.AbstractAgent
 
logger - Static variable in class com.wavefront.agent.AbstractAgent
 
logger - Static variable in class com.wavefront.agent.config.MetricMatcher
 
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
 
logger - Static variable in class com.wavefront.agent.WriteHttpJsonMetricsEndpoint
 
LogsIngester - Class in com.wavefront.agent.logsharvesting
Consumes log messages sent to LogsIngester.ingestLog(LogsMessage).
LogsIngester(PointHandler, Supplier<LogsIngestionConfig>, String, Supplier<Long>) - Constructor for class com.wavefront.agent.logsharvesting.LogsIngester
 
LogsIngestionConfig - Class in com.wavefront.agent.config
Top level configuration object for ingesting log data into the Wavefront Proxy.
LogsIngestionConfig() - Constructor for class com.wavefront.agent.config.LogsIngestionConfig
 
logsIngestionConfigFile - Variable in class com.wavefront.agent.AbstractAgent
 
LogsIngestionConfigManager - Class in com.wavefront.agent.logsharvesting
Wrapper for a LogsIngestionConfig that supports hot-loading and removal notifications.
LogsIngestionConfigManager(Supplier<LogsIngestionConfig>, Consumer<MetricMatcher>) - Constructor for class com.wavefront.agent.logsharvesting.LogsIngestionConfigManager
 
LogsMessage - Interface in com.wavefront.agent.logsharvesting
 

M

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

N

NamedThreadFactory - Class in com.wavefront.agent
Simple thread factory to be used with Executors.newScheduledThreadPool that allows assigning name prefixes to all pooled threads to simplify thread identification during troubleshooting.
NamedThreadFactory(String) - Constructor for class com.wavefront.agent.NamedThreadFactory
 
newThread(Runnable) - Method in class com.wavefront.agent.NamedThreadFactory
 

O

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
 
opentsdbWhitelistRegex - Variable in class com.wavefront.agent.AbstractAgent
 
org.logstash.beats - package org.logstash.beats
 
org.logstash.netty - package org.logstash.netty
 

P

patternsFile() - Method in class com.wavefront.agent.config.LogsIngestionConfig
 
persistAccumulator - Variable in class com.wavefront.agent.AbstractAgent
 
persistMessages - Variable in class com.wavefront.agent.AbstractAgent
 
persistMessagesCompression - Variable in class com.wavefront.agent.AbstractAgent
 
picklePorts - Variable in class com.wavefront.agent.AbstractAgent
 
PointHandler - Interface in com.wavefront.agent
Interface for a handler of Report Points.
PointHandlerDispatcher - Class in com.wavefront.agent.histogram
Dispatch task for marshalling "ripe" digests for shipment to the agent to a point handler.
PointHandlerDispatcher(ConcurrentMap<Utils.HistogramKey, AgentDigest>, PointHandler) - Constructor for class com.wavefront.agent.histogram.PointHandlerDispatcher
 
PointHandlerImpl - Class in com.wavefront.agent
Adds all graphite strings to a working list, and batches them up on a set schedule (100ms) to be sent (through the daemon's logic) up to the collector on the server side.
PointHandlerImpl(String, String, int, PostPushDataTimedTask[]) - Constructor for class com.wavefront.agent.PointHandlerImpl
 
PointHandlerImpl(String, String, int, String, PostPushDataTimedTask[]) - Constructor for class com.wavefront.agent.PointHandlerImpl
 
PointHandlerLoggingDecorator - Class in com.wavefront
Stores basic stats around logged points.
PointHandlerLoggingDecorator(PointHandler) - Constructor for class com.wavefront.PointHandlerLoggingDecorator
 
PointLineBlacklistRegexFilter - Class in com.wavefront.agent.preprocessor
Blacklist regex filter.
PointLineBlacklistRegexFilter(String, Counter) - Constructor for class com.wavefront.agent.preprocessor.PointLineBlacklistRegexFilter
 
PointLineReplaceRegexTransformer - Class in com.wavefront.agent.preprocessor
Replace regex transformer.
PointLineReplaceRegexTransformer(String, String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.PointLineReplaceRegexTransformer
 
PointLineWhitelistRegexFilter - Class in com.wavefront.agent.preprocessor
Whitelist regex filter.
PointLineWhitelistRegexFilter(String, Counter) - Constructor for class com.wavefront.agent.preprocessor.PointLineWhitelistRegexFilter
 
PointPreprocessor - Class in com.wavefront.agent.preprocessor
A container class for both types of rules (point line-specific and parsed point-specific) Created by Vasily on 9/15/16.
PointPreprocessor() - Constructor for class com.wavefront.agent.preprocessor.PointPreprocessor
 
pointToString(ReportPoint) - Static method in class com.wavefront.agent.PointHandlerImpl
 
postPushData(UUID, UUID, Long, String, String, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledAgentAPI
 
postPushData(UUID, UUID, Long, String, String) - Method in class com.wavefront.agent.QueuedAgentService
 
postPushData(UUID, UUID, Long, String, String, boolean) - Method in class com.wavefront.agent.QueuedAgentService
 
PostPushDataResultTask(UUID, UUID, Long, String, String) - Constructor for class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
PostPushDataTimedTask - Class in com.wavefront.agent
 
PostPushDataTimedTask(String, ForceQueueEnabledAgentAPI, String, UUID, String, int, RecyclableRateLimiter, long) - Constructor for class com.wavefront.agent.PostPushDataTimedTask
Deprecated.
PostPushDataTimedTask(String, ForceQueueEnabledAgentAPI, UUID, String, int, RecyclableRateLimiter, long) - Constructor for class com.wavefront.agent.PostPushDataTimedTask
 
postWorkUnitResult(UUID, UUID, UUID, ShellOutputDTO, boolean) - Method in interface com.wavefront.agent.api.ForceQueueEnabledAgentAPI
 
postWorkUnitResult(UUID, UUID, UUID, ShellOutputDTO) - Method in class com.wavefront.agent.QueuedAgentService
 
postWorkUnitResult(UUID, UUID, UUID, ShellOutputDTO, boolean) - Method in class com.wavefront.agent.QueuedAgentService
 
PostWorkUnitResultTask(UUID, UUID, UUID, ShellOutputDTO) - Constructor for class com.wavefront.agent.QueuedAgentService.PostWorkUnitResultTask
 
prefix - Variable in class com.wavefront.agent.AbstractAgent
 
Preprocessor<T> - Class in com.wavefront.agent.preprocessor
Generic container class for storing transformation and filter rules Created by Vasily on 9/13/16.
Preprocessor() - Constructor for class com.wavefront.agent.preprocessor.Preprocessor
 
preprocessorConfigFile - Variable in class com.wavefront.agent.AbstractAgent
 
preprocessors - Variable in class com.wavefront.agent.AbstractAgent
 
processConfiguration(AgentConfiguration) - Method in class com.wavefront.agent.AbstractAgent
Actual agents can do additional configuration.
processConfiguration(AgentConfiguration) - Method in class com.wavefront.agent.PushAgent
Push agent configuration during check-in by the collector.
processCounter(MetricName, Counter, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processGauge(MetricName, Gauge<?>, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processHistogram(MetricName, Histogram, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processMeter(MetricName, Metered, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
processPointLine(String, Decoder<String>, PointHandler, PointPreprocessor, ChannelHandlerContext) - Static method in class com.wavefront.agent.ChannelStringHandler
This probably belongs in a base class.
processTimer(MetricName, Timer, ReadProcessorContext) - Method in class com.wavefront.agent.logsharvesting.ReadProcessor
 
props - Variable in class com.wavefront.agent.AbstractAgent
 
Protocol - Class in org.logstash.beats
Created by ph on 2016-05-16.
Protocol() - Constructor for class org.logstash.beats.Protocol
 
proxyHost - Variable in class com.wavefront.agent.AbstractAgent
 
proxyPassword - Variable in class com.wavefront.agent.AbstractAgent
 
proxyPort - Variable in class com.wavefront.agent.AbstractAgent
 
proxyUser - Variable in class com.wavefront.agent.AbstractAgent
 
pushAgent - Variable in class com.wavefront.agent.AbstractAgent
 
PushAgent - Class in com.wavefront.agent
Push-only Agent.
PushAgent() - Constructor for class com.wavefront.agent.PushAgent
 
PushAgent(boolean) - Constructor for class com.wavefront.agent.PushAgent
 
PushAgentDaemon - Class in com.wavefront.agent
 
PushAgentDaemon() - Constructor for class com.wavefront.agent.PushAgentDaemon
 
pushBlockedSamples - Variable in class com.wavefront.agent.AbstractAgent
 
pushFlushInterval - Variable in class com.wavefront.agent.AbstractAgent
 
pushFlushMaxPoints - Variable in class com.wavefront.agent.AbstractAgent
 
pushListenerPorts - Variable in class com.wavefront.agent.AbstractAgent
 
pushLogLevel - Variable in class com.wavefront.agent.AbstractAgent
 
pushMemoryBufferLimit - Variable in class com.wavefront.agent.AbstractAgent
 
pushRateLimit - Variable in class com.wavefront.agent.AbstractAgent
 
pushRateLimiter - Variable in class com.wavefront.agent.AbstractAgent
 
pushValidationLevel - Variable in class com.wavefront.agent.AbstractAgent
 

Q

quantile(double) - Method in class com.tdunning.math.stats.AgentDigest
 
QueuedAgentService - Class in com.wavefront.agent
A wrapper for any AgentAPI that queues up any result posting if the backend is not available.
QueuedAgentService(AgentAPI, String, int, ScheduledExecutorService, boolean, UUID, boolean, String) - Constructor for class com.wavefront.agent.QueuedAgentService
Deprecated.
QueuedAgentService(AgentAPI, String, int, ScheduledExecutorService, boolean, UUID, boolean, RecyclableRateLimiter) - Constructor for class com.wavefront.agent.QueuedAgentService
 
QueuedAgentService.PostPushDataResultTask - Class in com.wavefront.agent
 
QueuedAgentService.PostWorkUnitResultTask - Class 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) - Constructor for class com.wavefront.agent.histogram.QueuingChannelHandler
 

R

RawLogsIngester - Class in com.wavefront.agent.logsharvesting
 
RawLogsIngester(LogsIngester, int, Supplier<Long>) - Constructor for class com.wavefront.agent.logsharvesting.RawLogsIngester
 
rawLogsPort - Variable in class com.wavefront.agent.AbstractAgent
 
read(Bytes, long, AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
read(Bytes, Utils.HistogramKey) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
readMarshallable(WireIn) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
readMarshallable(WireIn) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
ReadProcessor - Class in com.wavefront.agent.logsharvesting
 
ReadProcessor() - Constructor for class com.wavefront.agent.logsharvesting.ReadProcessor
 
ReadProcessorContext - Class in com.wavefront.agent.logsharvesting
 
ReadProcessorContext(Double) - Constructor for class com.wavefront.agent.logsharvesting.ReadProcessorContext
 
readResolve() - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
readResolve() - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
recordAllData() - Method in class com.tdunning.math.stats.AgentDigest
Turns on internal data recording.
RecyclableRateLimiter - Class in com.google.common.util.concurrent
An alternative RateLimiter implementation that allows to "return" unused permits back to the pool to handle retries gracefully and allow precise control over outgoing rate, plus allows accumulating "credits" for unused permits over a time window other than 1 second.
recyclePermits(int) - Method in class com.google.common.util.concurrent.RecyclableRateLimiter
Return the specified number of permits back to the pool
reportMetrics(String, String, Long, UriInfo, JsonNode) - Method in class com.wavefront.agent.JsonMetricsEndpoint
 
reportMetrics(UriInfo, JsonNode) - Method in class com.wavefront.agent.WriteHttpJsonMetricsEndpoint
 
reportPoint(ReportPoint, String) - Method in interface com.wavefront.agent.PointHandler
Send a point for reporting.
reportPoint(ReportPoint, String) - Method in class com.wavefront.agent.PointHandlerImpl
 
reportPoint(ReportPoint, String) - Method in class com.wavefront.PointHandlerLoggingDecorator
 
ReportPointAddPrefixTransformer - Class in com.wavefront.agent.preprocessor
Add prefix transformer.
ReportPointAddPrefixTransformer(String) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddPrefixTransformer
 
ReportPointAddTagIfNotExistsTransformer - Class in com.wavefront.agent.preprocessor
Creates a new point tag with a specified value.
ReportPointAddTagIfNotExistsTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagIfNotExistsTransformer
 
ReportPointAddTagTransformer - Class in com.wavefront.agent.preprocessor
Creates a new point tag with a specified value, or overwrite an existing one.
ReportPointAddTagTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointAddTagTransformer
 
ReportPointBlacklistRegexFilter - Class in com.wavefront.agent.preprocessor
Blacklist regex filter.
ReportPointBlacklistRegexFilter(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointBlacklistRegexFilter
 
ReportPointDropTagTransformer - Class in com.wavefront.agent.preprocessor
Removes a point tag if its value matches an optional regex pattern (always remove if null) Created by Vasily on 9/13/16.
ReportPointDropTagTransformer(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointDropTagTransformer
 
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
 
ReportPointRenameTagTransformer - Class in com.wavefront.agent.preprocessor
Rename a point tag (optional: if its value matches a regex pattern) Created by Vasily on 9/13/16.
ReportPointRenameTagTransformer(String, String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointRenameTagTransformer
 
ReportPointReplaceRegexTransformer - Class in com.wavefront.agent.preprocessor
Replace regex transformer.
ReportPointReplaceRegexTransformer(String, String, String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointReplaceRegexTransformer
 
reportPoints(List<ReportPoint>) - Method in interface com.wavefront.agent.PointHandler
Send a collection of points for reporting.
reportPoints(List<ReportPoint>) - Method in class com.wavefront.agent.PointHandlerImpl
 
reportPoints(List<ReportPoint>) - Method in class com.wavefront.PointHandlerLoggingDecorator
 
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) - Constructor for class com.wavefront.agent.preprocessor.ReportPointTimestampInRangeFilter
 
ReportPointWhitelistRegexFilter - Class in com.wavefront.agent.preprocessor
Whitelist regex filter.
ReportPointWhitelistRegexFilter(String, String, Counter) - Constructor for class com.wavefront.agent.preprocessor.ReportPointWhitelistRegexFilter
 
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
Created by Vasily on 8/18/16.
ResubmissionTaskQueue(ObjectQueue<ResubmissionTask>, TaskInjector<ResubmissionTask>) - Constructor for class com.wavefront.agent.ResubmissionTaskQueue
 
retryBackoffBaseSeconds - Variable in class com.wavefront.agent.AbstractAgent
 
retryThreads - Variable in class com.wavefront.agent.AbstractAgent
 
run() - Method in class com.wavefront.agent.histogram.accumulator.AccumulationTask
 
run() - Method in class com.wavefront.agent.histogram.DroppingSender
 
run() - Method in class com.wavefront.agent.histogram.HistogramLineIngester
 
run() - Method in class com.wavefront.agent.histogram.PointHandlerDispatcher
 
run() - Method in class com.wavefront.agent.histogram.TapeDispatcher
 
run() - Method in class com.wavefront.agent.logsharvesting.MetricsReporter
 
run() - Method in class com.wavefront.agent.PostPushDataTimedTask
 
Runner - Class in org.logstash.beats
 
Runner() - Constructor for class org.logstash.beats.Runner
 

S

sendDataTasks - Variable in class com.wavefront.agent.PointHandlerImpl
 
serialize(Object, Type, JsonSerializationContext) - Method in class com.wavefront.agent.ResubmissionTaskDeserializer
 
server - Variable in class com.wavefront.agent.AbstractAgent
 
Server - Class in org.logstash.beats
 
Server(int) - Constructor for class org.logstash.beats.Server
 
Server(int, int) - Constructor for class org.logstash.beats.Server
 
service - Variable in class com.wavefront.agent.ResubmissionTask
To be injected.
sessionId - Variable in class com.wavefront.agent.AbstractAgent
A random value assigned at proxy start-up, to be reported as ~agent.session.id metric to detect ~agent metrics collisions caused by duplicate proxy names
setBatch(Batch) - Method in class org.logstash.beats.Message
 
setBatchSize(int) - Method in class org.logstash.beats.Batch
 
setCertificateAuthorities(String[]) - Method in class org.logstash.netty.SslSimpleBuilder
 
setCipherSuites(String[]) - Method in class org.logstash.netty.SslSimpleBuilder
 
setHandshakeTimeoutMilliseconds(int) - Method in class org.logstash.netty.SslSimpleBuilder
 
setHostnameVerifier(HostnameVerifier) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
setMessageListener(IMessageListener) - Method in class org.logstash.beats.Server
 
setPatternsFile(String) - Method in class com.wavefront.agent.config.MetricMatcher
 
setProtocol(byte) - Method in class org.logstash.beats.Batch
 
setProtocols(String[]) - Method in class org.logstash.netty.SslSimpleBuilder
 
setRetryBackoffBaseSeconds(double) - Static method in class com.wavefront.agent.QueuedAgentService
 
setSplitBatchSize(int) - Static method in class com.wavefront.agent.QueuedAgentService
 
setSslContext(SSLContext) - Method in class com.wavefront.agent.JavaNetConnectionEngine
 
setValue(T) - Method in class com.wavefront.agent.logsharvesting.ChangeableGauge
 
setVerifyMode(SslSimpleBuilder.SslClientVerifyMode) - Method in class org.logstash.netty.SslSimpleBuilder
 
shutdown() - Method in class com.wavefront.agent.AbstractAgent
 
shutdown() - Method in class com.wavefront.agent.PostPushDataTimedTask
Shut down the scheduler for this task (prevent future scheduled runs)
shutdownTasks - Variable in class com.wavefront.agent.AbstractAgent
 
shuttingDown - Variable in class com.wavefront.agent.AbstractAgent
 
size(AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
size() - Method in class com.tdunning.math.stats.AgentDigest
 
size() - Method in class com.wavefront.agent.QueuedAgentService.PostPushDataResultTask
 
size() - Method in class com.wavefront.agent.QueuedAgentService.PostWorkUnitResultTask
 
size() - Method in class com.wavefront.agent.ResubmissionTask
 
size() - Method in class org.logstash.beats.Batch
 
smallByteSize() - Method in class com.tdunning.math.stats.AgentDigest
 
soLingerTime - Variable in class com.wavefront.agent.AbstractAgent
 
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.PostWorkUnitResultTask
 
splitTask() - Method in class com.wavefront.agent.ResubmissionTask
 
SSLConnectionSocketFactoryImpl - Class in com.wavefront.agent
Delegated SSLConnectionSocketFactory that sets SoTimeout explicitly (for Apache HttpClient).
SSLConnectionSocketFactoryImpl(SSLConnectionSocketFactory, int) - Constructor for class com.wavefront.agent.SSLConnectionSocketFactoryImpl
 
sslContext - Variable in class com.wavefront.agent.JavaNetConnectionEngine
 
SslSimpleBuilder - Class in org.logstash.netty
Created by ph on 2016-05-27.
SslSimpleBuilder(String, String, String) - Constructor for class org.logstash.netty.SslSimpleBuilder
 
SslSimpleBuilder.SslClientVerifyMode - Enum in org.logstash.netty
 
SSLSocketFactoryImpl - Class in com.wavefront.agent
Delegated SSLSocketFactory that sets SoTimeout explicitly.
SSLSocketFactoryImpl(SSLSocketFactory, int) - Constructor for class com.wavefront.agent.SSLSocketFactoryImpl
 
start(String[]) - Method in class com.wavefront.agent.AbstractAgent
Entry-point for the application.
start() - Method in class com.wavefront.agent.logsharvesting.LogsIngester
 
start() - Method in class com.wavefront.agent.PushAgentDaemon
 
startAsManagedThread(Runnable, String) - Method in class com.wavefront.agent.PushAgent
 
startCustomListener(String, Decoder<String>, PointHandler, PointPreprocessor) - Method in class com.wavefront.agent.PushAgent
Registers a custom point handler on a particular port.
startGraphiteListener(String, boolean) - Method in class com.wavefront.agent.PushAgent
 
startHistogramListener(String, Decoder<String>, PointHandler, AccumulationCache, File, Utils.Granularity, TapeDeck<List<String>>, long, int) - Method in class com.wavefront.agent.PushAgent
Needs to set up a queueing handler and a consumer/lexer for the queue
startListeners() - Method in class com.wavefront.agent.AbstractAgent
 
startListeners() - Method in class com.wavefront.agent.PushAgent
 
startOpenTsdbListener(String) - Method in class com.wavefront.agent.PushAgent
 
startPickleListener(String, GraphiteFormatter) - Method in class com.wavefront.agent.PushAgent
 
stop() - Method in class com.wavefront.agent.PushAgentDaemon
 
stop() - Method in class org.logstash.beats.Server
 
stopListeners() - Method in class com.wavefront.agent.AbstractAgent
 
stopListeners() - Method in class com.wavefront.agent.PushAgent
 

T

TapeDeck<T> - Class in com.wavefront.agent.histogram.tape
Factory for Square Tape ObjectQueue instances for this agent.
TapeDeck(FileObjectQueue.Converter<T>, boolean) - Constructor for class com.wavefront.agent.histogram.tape.TapeDeck
 
TapeDispatcher - Class in com.wavefront.agent.histogram
Dispatch task for marshalling "ripe" digests for shipment to the agent into a (Tape) ObjectQueue
TapeDispatcher(ConcurrentMap<Utils.HistogramKey, AgentDigest>, ObjectQueue<ReportPoint>) - Constructor for class com.wavefront.agent.histogram.TapeDispatcher
 
TapeReportPointConverter - Class in com.wavefront.agent.histogram.tape
Adapter exposing the Avro's SpecificRecord encoding/decoding to Square tape's FileObjectQueue.Converter interface.
TapeStringListConverter - Class in com.wavefront.agent.histogram.tape
[Square] Tape converter for Lists of strings with LZ4 compression support.
tenuredGenPool - Variable in class com.wavefront.agent.AbstractAgent
 
TimeProvider - Interface in com.wavefront.agent.histogram
 
timeSeries(LogsMessage, Double[]) - Method in class com.wavefront.agent.config.MetricMatcher
Convert the given message to a timeSeries and a telemetry datum.
TimeSeriesUtils - Class in com.wavefront.agent.logsharvesting
 
TimeSeriesUtils() - Constructor for class com.wavefront.agent.logsharvesting.TimeSeriesUtils
 
toHistogram(int) - Method in class com.tdunning.math.stats.AgentDigest
Creates a reporting Histogram from this AgentDigest (marked with the supplied duration).
toMetricName(TimeSeries) - Static method in class com.wavefront.agent.logsharvesting.TimeSeriesUtils
 
toStream(ReportPoint, OutputStream) - Method in class com.wavefront.agent.histogram.tape.TapeReportPointConverter
 
toStream(List<String>, OutputStream) - Method in class com.wavefront.agent.histogram.tape.TapeStringListConverter
 
toString() - Method in class com.wavefront.agent.config.Configuration
 
toString() - Method in class com.wavefront.agent.histogram.accumulator.AccumulationTask
 
toString() - Method in class com.wavefront.agent.histogram.MapLoader
 
toString() - Method in class com.wavefront.agent.histogram.tape.TapeDeck
 
toString() - Method in class com.wavefront.agent.histogram.Utils.HistogramKey
 
toString() - Method in class com.wavefront.PointHandlerLoggingDecorator
 
transform(T) - Method in class com.wavefront.agent.preprocessor.Preprocessor
Apply all transformation rules sequentially

U

unparsed_params - Variable in class com.wavefront.agent.AbstractAgent
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class org.logstash.beats.BeatsHandler
 
useWavefrontHistograms - Variable in class com.wavefront.agent.config.LogsIngestionConfig
If true, use WavefrontHistograms rather than Histograms.
Utils - Class in com.wavefront.agent.histogram
Helpers around histograms
Utils.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

validatePoint(ReportPoint, String, String, Validation.Level) - Static method in class com.wavefront.agent.Validation
 
Validation - Class in com.wavefront.agent
Consolidates point validation logic for point handlers
Validation() - Constructor for class com.wavefront.agent.Validation
 
Validation.Level - Enum in com.wavefront.agent
 
value() - Method in class com.wavefront.agent.logsharvesting.ChangeableGauge
 
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.Validation.Level
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.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.Validation.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.logstash.netty.SslSimpleBuilder.SslClientVerifyMode
Returns an array containing the constants of this enum type, in the order they are declared.
verifyAndInit() - Method in class com.wavefront.agent.config.Configuration
 
verifyAndInit() - Method in class com.wavefront.agent.config.LogsIngestionConfig
 
verifyAndInit() - Method in class com.wavefront.agent.config.MetricMatcher
 
VERSION_1 - Static variable in class org.logstash.beats.Protocol
 
VERSION_2 - Static variable in class org.logstash.beats.Protocol
 

W

whitelistRegex - Variable in class com.wavefront.agent.AbstractAgent
 
write(Bytes, long, AgentDigest) - Method in class com.tdunning.math.stats.AgentDigest.AgentDigestMarshaller
 
write(Utils.HistogramKey, AgentDigest) - Method in class com.wavefront.agent.histogram.accumulator.Layering
 
write(Bytes, Utils.HistogramKey) - Method in class com.wavefront.agent.histogram.Utils.HistogramKeyMarshaller
 
WriteHttpJsonMetricsEndpoint - Class in com.wavefront.agent
Agent-side JSON metrics endpoint for parsing JSON from write_http collectd plugin.
WriteHttpJsonMetricsEndpoint(String, String, String, String, int, PostPushDataTimedTask[], PointPreprocessor) - Constructor for class com.wavefront.agent.WriteHttpJsonMetricsEndpoint
 
writeHttpJsonPorts - Variable in class com.wavefront.agent.AbstractAgent
 
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
 
A B C D E F G H I J K L M N O P Q R S T U V W 
Skip navigation links

Copyright © 2017. All rights reserved.