All Classes Interface Summary Class Summary Enum Summary Exception Summary
Class |
Description |
AbstractAgent |
Agent that runs remotely on a server collecting metrics.
|
AbstractHttpOnlyHandler |
Base class for HTTP-only listeners.
|
AbstractLineDelimitedHandler |
Base class for all line-based protocols.
|
AbstractPortUnificationHandler |
This is a base class for the majority of proxy's listeners.
|
AccumulationCache |
Expose a local cache of limited size along with a task to flush that cache to the backing store.
|
Accumulator |
Caching wrapper around the backing store.
|
Ack |
|
AckEncoder |
This Class is mostly used in the test suite to make the right assertions with the encoded data frame.
|
AdminPortUnificationHandler |
Admin API for managing proxy-wide healthchecks.
|
AgentDigest |
NOTE: This is a pruned and modified version of MergingDigest .
|
AgentDigest.AgentDigestMarshaller |
Stateless AgentDigest codec for chronicle maps
|
AgentDigestFactory |
A simple factory for creating AgentDigest objects with a specific compression level
and expiration TTL.
|
AnnotatedPredicate<T> |
Base for all "filter"-type rules.
|
APIContainer |
Container for all Wavefront back-end API objects (proxy, source tag, event)
|
Batch |
Interface representing a Batch of Message .
|
BatchIdentity |
Identity of a filebeat batch, based on the first message.
|
BeatsHandler |
|
BeatsParser |
|
CachingHostnameLookupResolver |
Convert InetAddress to String , either by performing reverse DNS lookups (cached, as
the name implies), or by converting IP addresses into their string representation.
|
ChangeableGauge<T> |
|
ChannelByteArrayHandler |
Channel handler for byte array data.
|
ChannelUtils |
A collection of helper methods around Netty channels.
|
ConcurrentQueueFile |
|
ConcurrentShardedQueueFile |
A thread-safe QueueFile implementation, that uses multiple smaller "shard" files
instead of one large file.
|
Configuration |
|
ConfigurationException |
|
ConnectionHandler |
Manages the connection state to the beats client.
|
ConnectionTrackingHandler |
Track the number of currently active connections and total count of accepted incoming connections.
|
CountTransformer<T> |
A no-op rule that simply counts points or spans.
|
CustomTracingPortUnificationHandler |
Handler that process trace data sent from tier 1 SDK.
|
DataDogPortUnificationHandler |
Accepts incoming HTTP requests in DataDog JSON format.
|
DataFormat |
Best-effort data format auto-detection.
|
DataSubmissionException |
Exception to bypass standard handling for response status codes.
|
DataSubmissionTask<T extends DataSubmissionTask<T>> |
A serializable data submission task.
|
DelegatingReportableEntityHandlerFactoryImpl |
|
DeltaCounterAccumulationHandlerImpl |
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.
|
DirectByteArrayOutputStream |
Enables direct access to the internal array.
|
DisableGZIPEncodingInterceptor |
This RESTEasy interceptor allows disabling GZIP compression even for methods annotated with @GZIP by removing the
Content-Encoding header.
|
EntityProperties |
Unified interface for dynamic entity-specific dynamic properties, that may change at runtime
|
EntityPropertiesFactory |
Generates entity-specific wrappers for dynamic proxy settings.
|
EntityPropertiesFactoryImpl |
Generates entity-specific wrappers for dynamic proxy settings.
|
EventDataSubmissionTask |
|
EventHandlerImpl |
This class will validate parsed events and distribute them among SenderTask threads.
|
EvictingMetricsRegistry |
Wrapper for a Yammer MetricsRegistry , but has extra features
regarding automatic removal of metrics.
|
FeatureCheckUtils |
Constants and utility methods for validating feature subscriptions.
|
FileBasedTaskQueue<T extends DataSubmissionTask<T>> |
|
FilebeatIngester |
|
FilebeatMessage |
|
FlushProcessor |
Wrapper for MetricProcessor .
|
FlushProcessorContext |
|
GlobalProperties |
Unified interface for non-entity specific dynamic properties, that may change at runtime.
|
GlobalPropertiesImpl |
Dynamic non-entity specific properties, that may change at runtime.
|
Granularity |
Standard supported aggregation Granularities.
|
GraphiteFormatter |
Specific formatter for the graphite/collectd world of metric-munged names.
|
GZIPEncodingInterceptorWithVariableCompression |
An alternative to
GZIPEncodingInterceptor that allows
changing the GZIP deflater's compression level.
|
GZIPEncodingInterceptorWithVariableCompression.CommittedGZIPOutputStream |
|
GZIPEncodingInterceptorWithVariableCompression.EndableGZIPOutputStream |
|
HandlerKey |
An immutable unique identifier for a handler pipeline (type of objects handled + port/handle name)
|
HealthCheckManager |
Centrally manages healthcheck statuses (for controlling load balancers).
|
HealthCheckManagerImpl |
Centrally manages healthcheck statuses (for controlling load balancers).
|
HistogramAccumulationHandlerImpl |
A ReportPointHandler that ships parsed points to a histogram accumulator instead of
forwarding them to SenderTask.
|
HistogramKey |
Uniquely identifies a time-series - time-interval pair.
|
HistogramRecompressor |
Recompresses histograms to reduce their size.
|
HistogramUtils |
Helpers around histograms
|
HistogramUtils.HistogramKeyMarshaller |
(For now, a rather trivial) encoding of HistogramKey the form short length and bytes
Consider using chronicle-values or making this stateful with a local
byte[] / Stringbuffers to be a little more efficient about encodings.
|
HostMetricTagsPair |
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.
|
HttpHealthCheckEndpointHandler |
A simple healthcheck-only endpoint handler.
|
IdleStateEventHandler |
Disconnect idle clients (handle READER_IDLE events triggered by IdleStateHandler)
|
IgnoreStatusCodeException |
Exception used to ignore 404s for DELETE API calls for sourceTags.
|
IMessageListener |
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 |
Line-delimited decoder that has the ability of detecting when clients have disconnected while leaving some
data in the buffer.
|
InMemorySubmissionQueue<T extends DataSubmissionTask<T>> |
Implements proxy-specific in-memory-queue interface as a wrapper over tape ObjectQueue
|
InstrumentedTaskQueueDelegate<T extends DataSubmissionTask<T>> |
A thread-safe wrapper for TaskQueue that reports queue metrics.
|
InteractiveLogsTester |
|
InteractivePreprocessorTester |
Interactive tester for preprocessor rules.
|
InteractiveTester |
Base interface for all interactive testers (logs and preprocessor at the moment).
|
InternalProxyWavefrontClient |
|
JaegerGrpcCollectorHandler |
Handler that processes trace data in Jaeger ProtoBuf format and converts them to Wavefront
format
|
JaegerPortUnificationHandler |
Handler that processes Jaeger Thrift trace data over HTTP and converts them to Wavefront format.
|
JaegerProtobufUtils |
Utility methods for processing Jaeger Protobuf trace data.
|
JaegerTChannelCollectorHandler |
Handler that processes trace data in Jaeger Thrift compact format and converts them to Wavefront
format
|
JaegerThriftUtils |
Utility methods for processing Jaeger Thrift trace data.
|
JsonMetricsPortUnificationHandler |
Agent-side JSON metrics endpoint.
|
JsonNodeWriter |
Writer that serializes JsonNodes.
|
LengthLimitActionType |
|
LineBasedAllowFilter |
"Allow list" regex filter.
|
LineBasedBlockFilter |
Blocking regex-based filter.
|
LineBasedReplaceRegexTransformer |
Replace regex transformer.
|
LineDelimitedDataSubmissionTask |
|
LineDelimitedUtils |
A collection of helper methods around plaintext newline-delimited payloads.
|
LogsIngester |
|
LogsIngestionConfig |
Top level configuration object for ingesting log data into the Wavefront Proxy.
|
LogsIngestionConfigManager |
|
LogsMessage |
|
MalformedMessageException |
|
Managed |
Background process that can be started and stopped.
|
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>> |
Loader for ChronicleMap .
|
MapSettings |
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)
|
Message |
|
MessageListener |
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.
|
MetricMatcher |
Object defining transformation between a log line into structured telemetry data.
|
MetricsReporter |
|
NoopEventAPI |
A no-op SourceTagAPI stub.
|
NoopHealthCheckManager |
A no-op health check manager.
|
NoopProxyV2API |
Partial ProxyV2API wrapper stub that passed proxyCheckin/proxyConfigProcessed calls to the
delegate and replaces proxyReport/proxyError with a no-op.
|
NoopSourceTagAPI |
A no-op SourceTagAPI stub.
|
OpenTSDBPortUnificationHandler |
This class handles both OpenTSDB JSON and OpenTSDB plaintext protocol.
|
PlainTextOrHttpFrameDecoder |
This class handles 2 different protocols on a single port.
|
PointHandlerDispatcher |
Dispatch task for marshalling "ripe" digests for shipment to the agent to a point handler.
|
Predicates |
Collection of helper methods Base factory class for predicates; supports both text parsing as
well as YAML logic.
|
Preprocessor<T> |
Generic container class for storing transformation and filter rules
Created by Vasily on 9/13/16.
|
PreprocessorConfigManager |
Parses preprocessor rules (organized by listening port)
Created by Vasily on 9/15/16.
|
PreprocessorRuleMetrics |
A helper class for instrumenting preprocessor rules.
|
PreprocessorUtil |
Utility class for methods used by preprocessors.
|
Protocol |
Created by ph on 2016-05-16.
|
ProxyCheckInScheduler |
Registers the proxy with the back-end, sets up regular "check-ins" (every minute),
transmits proxy metrics to the back-end.
|
ProxyConfig |
|
ProxyConfig.TaskQueueLevelConverter |
|
ProxyConfig.TokenValidationMethodConverter |
|
ProxyMemoryGuard |
Logic around OoM protection logic that drains memory buffers on
MEMORY_THRESHOLD_EXCEEDED notifications, extracted from AbstractAgent.
|
PushAgent |
Push-only Agent.
|
QueueController<T extends DataSubmissionTask<T>> |
A queue controller (one per entity/port).
|
QueueExporter |
Supports proxy's ability to export data from buffer files.
|
QueueFile |
Proxy-specific FIFO queue interface for storing byte[] .
|
QueueFileFactory |
|
QueueingFactory |
|
QueueingFactoryImpl |
|
QueueingReason |
Additional context to help understand why a certain batch was queued.
|
QueueProcessor<T extends DataSubmissionTask<T>> |
A thread responsible for processing the backlog from a single task queue.
|
RawLogsIngesterPortUnificationHandler |
Process incoming logs in raw plaintext format.
|
ReadProcessor |
|
ReadProcessorContext |
|
RelayPortUnificationHandler |
A unified HTTP endpoint for mixed format data.
|
ReportableConfig |
Wrapper class to simplify access to .properties file + track values as metrics as they are retrieved
|
ReportableEntityHandler<T,U> |
Handler that processes incoming objects of a single entity type, validates them and
hands them over to one of the SenderTask threads.
|
ReportableEntityHandlerFactory |
|
ReportableEntityHandlerFactoryImpl |
|
ReportableEntityPreprocessor |
A container class for multiple types of rules (point line-specific and parsed entity-specific)
Created by Vasily on 9/15/16.
|
ReportPointAddPrefixTransformer |
Add prefix transformer.
|
ReportPointAddTagIfNotExistsTransformer |
Creates a new point tag with a specified value.
|
ReportPointAddTagTransformer |
Creates a new point tag with a specified value, or overwrite an existing one.
|
ReportPointAllowFilter |
"Allow list" regex filter.
|
ReportPointBlockFilter |
Blocking regex-based filter.
|
ReportPointDropTagTransformer |
Removes a point tag if its value matches an optional regex pattern (always remove if null)
Created by Vasily on 9/13/16.
|
ReportPointExtractTagIfNotExistsTransformer |
Create a point tag by extracting a portion of a metric name, source name or another point tag.
|
ReportPointExtractTagTransformer |
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.
|
ReportPointForceLowercaseTransformer |
Force lowercase transformer.
|
ReportPointLimitLengthTransformer |
|
ReportPointRenameTagTransformer |
Rename a point tag (optional: if its value matches a regex pattern)
Created by Vasily on 9/13/16.
|
ReportPointReplaceRegexTransformer |
Replace regex transformer.
|
ReportPointTimestampInRangeFilter |
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.
|
RetryTaskConverter<T extends DataSubmissionTask<T>> |
|
Runner |
|
SenderTask<T> |
Batch and ship valid items to Wavefront servers
|
SenderTaskFactory |
|
SenderTaskFactoryImpl |
|
Server |
|
SharedGraphiteHostAnnotator |
Given a raw Graphite/Wavefront line, look for any host tag, and add it if implicit.
|
SharedMetricsRegistry |
|
SourceTagSubmissionTask |
|
SpanAddAnnotationIfNotExistsTransformer |
Creates a new annotation with a specified key/value pair.
|
SpanAddAnnotationTransformer |
Creates a new annotation with a specified key/value pair.
|
SpanAllowAnnotationTransformer |
Only allow span annotations that match the allowed list.
|
SpanAllowFilter |
"Allow list" regex filter.
|
SpanBlockFilter |
Blocking regex-based filter.
|
SpanDropAnnotationTransformer |
Removes a span annotation with a specific key if its value matches an optional regex pattern (always remove if null)
|
SpanExtractAnnotationIfNotExistsTransformer |
Create a new span annotation by extracting a portion of a span name, source name or another annotation
|
SpanExtractAnnotationTransformer |
Create a point tag by extracting a portion of a metric name, source name or another point tag
|
SpanForceLowercaseTransformer |
Force lowercase transformer.
|
SpanHandlerImpl |
Handler that processes incoming Span objects, validates them and hands them over to one of
the SenderTask threads.
|
SpanLimitLengthTransformer |
|
SpanLogsHandlerImpl |
Handler that processes incoming SpanLogs objects, validates them and hands them over to one of
the SenderTask threads.
|
SpanRenameAnnotationTransformer |
Rename a given span tag's/annotation's (optional: if its value matches a regex pattern)
If the tag matches multiple span annotation keys , all keys will be renamed.
|
SpanReplaceRegexTransformer |
Replace regex transformer.
|
SpanSampler |
Sampler that takes a Span as input and delegates to a Sampler when evaluating the
sampling decision.
|
SpanSamplerUtils |
Helper class for creating span samplers.
|
SpanSanitizeTransformer |
Sanitize spans (e.g., span source and tag keys) according to the same rules that are applied at
the SDK-level.
|
SpanUtils |
Utility methods for handling Span and SpanLogs.
|
SQSQueueFactoryImpl |
|
SQSSubmissionQueue<T extends DataSubmissionTask<T>> |
Implements proxy-specific queue interface as a wrapper over AmazonSQS
|
SSLConnectionSocketFactoryImpl |
Delegated SSLConnectionSocketFactory that sets SoTimeout explicitly (for Apache HttpClient).
|
SslSimpleBuilder |
Created by ph on 2016-05-27.
|
SslSimpleBuilder.SslClientVerifyMode |
|
StatusTrackingHttpObjectAggregator |
A HttpObjectAggregator that correctly tracks HTTP 413 returned
for incoming payloads that are too large.
|
TapeQueueFile |
|
TaskConverter<T> |
Proxy-specific interface for converting data into and from queues,
this potentially allows us to support other converting mechanisms in the future.
|
TaskConverter.CompressionType |
Supported compression schemas
|
TaskInjector<T extends DataSubmissionTask<T>> |
|
TaskQueue<T extends DataSubmissionTask<T>> |
Proxy-specific queue interface, which is basically a wrapper for a Tape queue.
|
TaskQueueFactory |
|
TaskQueueFactoryImpl |
|
TaskQueueLevel |
Controls conditions under which proxy would actually queue data.
|
TaskQueueStub<T extends DataSubmissionTask<T>> |
A non-functional empty TaskQueue that throws an error when attempting to add a task.
|
TaskResult |
|
TaskSizeEstimator |
Calculates approximate task sizes to estimate how quickly we would run out of disk space
if we are no longer able to send data to the server endpoint (i.e.
|
TimeSeriesUtils |
|
TokenAuthenticator |
Token validator for processing incoming requests.
|
TokenAuthenticatorBuilder |
|
TokenValidationMethod |
Auth validation methods supported.
|
TracePortUnificationHandler |
Process incoming trace-formatted data.
|
TrafficShapingRateLimitAdjuster |
Experimental: use automatic traffic shaping (set rate limiter based on recently received
per second rates, heavily biased towards last 5 minutes)
|
Utils |
A placeholder class for miscellaneous utility methods.
|
V1Batch |
Implementation of Batch intended for batches constructed from v1 protocol
|
V2Batch |
Implementation of Batch for the v2 protocol backed by ByteBuf.
|
WavefrontPortUnificationHandler |
Process incoming Wavefront-formatted data.
|
WavefrontProxyService |
|
WriteHttpJsonPortUnificationHandler |
This class handles incoming messages in write_http format.
|
ZipkinPortUnificationHandler |
Handler that processes Zipkin trace data over HTTP and converts them to Wavefront format.
|