- CachingGroupData - Class in com.yahoo.bullet.querying.aggregations.grouping
-
This class exists to optimize how the
GroupDataSummary
updates the summary for each record update.
- CachingGroupData(Map<String, String>, Map<String, String>, Map<GroupOperation, Number>) - Constructor for class com.yahoo.bullet.querying.aggregations.grouping.CachingGroupData
-
Constructor that initializes the CachingGroupData with an existing
Map
of
GroupOperation
to values and
a
Map
of Strings that represent the group fields.
- CastEvaluator - Class in com.yahoo.bullet.querying.evaluators
-
An evaluator that force casts the result of an evaluator to a given type.
- CastEvaluator(CastExpression) - Constructor for class com.yahoo.bullet.querying.evaluators.CastEvaluator
-
- CastExpression - Class in com.yahoo.bullet.query.expressions
-
An expression that requires a value and a cast type.
- CastExpression(Expression, Type) - Constructor for class com.yahoo.bullet.query.expressions.CastExpression
-
Constructor that creates a cast expression.
- castTo(Function<Object, Object>) - Method in class com.yahoo.bullet.common.Validator.Entry
-
Apply a cast to the value in the
BulletConfig
after validation and defaults are applied.
- categorize(Map<String, Querier>) - Method in class com.yahoo.bullet.querying.QueryCategorizer
-
Categorize the given
Map
of query IDs to
Querier
instances.
- categorize(BulletRecord, Map<String, Querier>) - Method in class com.yahoo.bullet.querying.QueryCategorizer
-
Categorize the given
Map
of query IDs to
Querier
instances after consuming the given record.
- categorize() - Method in class com.yahoo.bullet.querying.QueryManager
-
Categorizes all the queries in the manager regardless of partitioning, using a
QueryCategorizer
.
- categorize(BulletRecord) - Method in class com.yahoo.bullet.querying.QueryManager
-
Categorizes only the queries for the
BulletRecord
after partitioning using the
QueryCategorizer
.
- CHARSET - Static variable in class com.yahoo.bullet.pubsub.PubSubMessage
-
- checkIf(Predicate<Object>) - Method in class com.yahoo.bullet.common.Validator.Entry
-
Add a
Predicate
to check for the field represented by the entry.
- checkIf(BiPredicate<Object, Object>) - Method in class com.yahoo.bullet.common.Validator.Relationship
-
Provide the
BiPredicate
that acts as the check for this relationship.
- checkIf(Predicate<List<Object>>) - Method in class com.yahoo.bullet.common.Validator.State
-
Provide the
Predicate
that accepts the values that this state is checking.
- checkType(StorageManager<V>, Class<S>) - Static method in interface com.yahoo.bullet.storage.Criteria
-
Utility method to help check and cast if a given storage is of the given type.
- clear() - Method in class com.yahoo.bullet.common.Config
-
Clears out the configuration.
- clear() - Method in class com.yahoo.bullet.common.RandomPool
-
Clear the RandomPool.
- clear(String) - Method in class com.yahoo.bullet.storage.MemoryStorageManager
-
- clear(String, Set<String>) - Method in class com.yahoo.bullet.storage.MemoryStorageManager
-
- clear(String) - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
- clear(String, Set<String>) - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
- clear(String, int) - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
- clear(String) - Method in class com.yahoo.bullet.storage.NullStorageManager
-
- clear(String, Set<String>) - Method in class com.yahoo.bullet.storage.NullStorageManager
-
- clear() - Method in class com.yahoo.bullet.storage.StorageManager
-
Clears the default namespace.
- clear(int) - Method in class com.yahoo.bullet.storage.StorageManager
-
Clears the specified partition under the default namespace.
- clear(Set<String>) - Method in class com.yahoo.bullet.storage.StorageManager
-
Removes a given set of IDs from the storage under the default namespace.
- Clip - Class in com.yahoo.bullet.result
-
- Clip() - Constructor for class com.yahoo.bullet.result.Clip
-
- Closable - Interface in com.yahoo.bullet.common
-
- close() - Method in class com.yahoo.bullet.common.metrics.HTTPMetricEventPublisher
-
- close() - Method in class com.yahoo.bullet.pubsub.BulletPubSubResponder
-
- close() - Method in class com.yahoo.bullet.pubsub.PubSubResponder
-
- close() - Method in class com.yahoo.bullet.pubsub.rest.RESTPublisher
-
- close() - Method in class com.yahoo.bullet.pubsub.rest.RESTSubscriber
-
- com.yahoo.bullet.common - package com.yahoo.bullet.common
-
- com.yahoo.bullet.common.metrics - package com.yahoo.bullet.common.metrics
-
- com.yahoo.bullet.pubsub - package com.yahoo.bullet.pubsub
-
- com.yahoo.bullet.pubsub.rest - package com.yahoo.bullet.pubsub.rest
-
- com.yahoo.bullet.query - package com.yahoo.bullet.query
-
- com.yahoo.bullet.query.aggregations - package com.yahoo.bullet.query.aggregations
-
- com.yahoo.bullet.query.expressions - package com.yahoo.bullet.query.expressions
-
- com.yahoo.bullet.query.postaggregations - package com.yahoo.bullet.query.postaggregations
-
- com.yahoo.bullet.querying - package com.yahoo.bullet.querying
-
- com.yahoo.bullet.querying.aggregations - package com.yahoo.bullet.querying.aggregations
-
- com.yahoo.bullet.querying.aggregations.grouping - package com.yahoo.bullet.querying.aggregations.grouping
-
- com.yahoo.bullet.querying.aggregations.sketches - package com.yahoo.bullet.querying.aggregations.sketches
-
- com.yahoo.bullet.querying.evaluators - package com.yahoo.bullet.querying.evaluators
-
- com.yahoo.bullet.querying.partitioning - package com.yahoo.bullet.querying.partitioning
-
- com.yahoo.bullet.querying.postaggregations - package com.yahoo.bullet.querying.postaggregations
-
- com.yahoo.bullet.result - package com.yahoo.bullet.result
-
- com.yahoo.bullet.storage - package com.yahoo.bullet.storage
-
- com.yahoo.bullet.windowing - package com.yahoo.bullet.windowing
-
- combine(byte[]) - Method in interface com.yahoo.bullet.common.Monoidal
-
Combines a serialized piece of data into this Monoid.
- combine(byte[]) - Method in class com.yahoo.bullet.querying.aggregations.GroupAllStrategy
-
- combine(byte[]) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
Merges the serialized form of a GroupData into this.
- combine(GroupData) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
Merge a GroupData into this.
- combine(byte[]) - Method in class com.yahoo.bullet.querying.aggregations.RawStrategy
-
- combine(byte[]) - Method in class com.yahoo.bullet.querying.aggregations.SketchingStrategy
-
- combine(byte[]) - Method in class com.yahoo.bullet.querying.Querier
-
Presents the query with a serialized data representation of a prior result for the query.
- combine(byte[]) - Method in class com.yahoo.bullet.windowing.Basic
-
- combine(byte[]) - Method in class com.yahoo.bullet.windowing.SlidingRecord
-
- commit(String) - Method in class com.yahoo.bullet.pubsub.BufferingSubscriber
-
Commits allow clients to implement at least once, at most once or exactly once semantics when processing messages.
- commit(String) - Method in interface com.yahoo.bullet.pubsub.Subscriber
-
Commits allow clients to implement at least once, at most once or exactly once semantics when processing messages.
- Computation - Class in com.yahoo.bullet.query.postaggregations
-
- Computation(List<Field>) - Constructor for class com.yahoo.bullet.query.postaggregations.Computation
-
Constructor that creates a Computation post-aggregation.
- COMPUTATION_REQUIRES_FIELDS - Static variable in class com.yahoo.bullet.query.postaggregations.Computation
-
- ComputationStrategy - Class in com.yahoo.bullet.querying.postaggregations
-
- ComputationStrategy(Computation) - Constructor for class com.yahoo.bullet.querying.postaggregations.ComputationStrategy
-
Constructor that creates a Computation post-strategy.
- Config - Class in com.yahoo.bullet.common
-
- Config(String) - Constructor for class com.yahoo.bullet.common.Config
-
Constructor that loads a specific file and loads the settings in that file.
- Config(String, String) - Constructor for class com.yahoo.bullet.common.Config
-
Constructor that loads specific file augmented with defaults and the name of the default configuration file.
- config - Variable in class com.yahoo.bullet.common.metrics.MetricPublisher
-
- config - Variable in class com.yahoo.bullet.pubsub.PubSub
-
- config - Variable in class com.yahoo.bullet.pubsub.PubSubResponder
-
- Configurable - Interface in com.yahoo.bullet.common
-
- configure(BulletConfig) - Method in interface com.yahoo.bullet.common.Configurable
-
Takes a
BulletConfig
containing configuration and applies it to itself.
- configure(BulletConfig) - Method in class com.yahoo.bullet.query.aggregations.Aggregation
-
- configure(BulletConfig) - Method in class com.yahoo.bullet.query.Query
-
- configure(BulletConfig) - Method in class com.yahoo.bullet.query.Window
-
- consume(BulletRecord) - Method in interface com.yahoo.bullet.common.Monoidal
-
Consumes a single BulletRecord
into this Monoid.
- consume(BulletRecord) - Method in class com.yahoo.bullet.querying.aggregations.FrequentItemsSketchingStrategy
-
- consume(BulletRecord) - Method in class com.yahoo.bullet.querying.aggregations.GroupAllStrategy
-
- consume(BulletRecord) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
Consumes the given BulletRecord
and computes group operation metrics.
- consume(BulletRecord) - Method in class com.yahoo.bullet.querying.aggregations.QuantileSketchingStrategy
-
- consume(BulletRecord) - Method in class com.yahoo.bullet.querying.aggregations.RawStrategy
-
- consume(BulletRecord) - Method in class com.yahoo.bullet.querying.aggregations.ThetaSketchingStrategy
-
- consume(BulletRecord) - Method in class com.yahoo.bullet.querying.aggregations.TupleSketchingStrategy
-
- consume(BulletRecord) - Method in class com.yahoo.bullet.querying.Querier
-
Consume a BulletRecord
for this query.
- consume(BulletRecord) - Method in class com.yahoo.bullet.windowing.Basic
-
- consume(BulletRecord) - Method in class com.yahoo.bullet.windowing.SlidingRecord
-
- consumeRegisteredConcept(Meta.Concept, Map<String, String>, Consumer<String>) - Static method in class com.yahoo.bullet.result.Meta
-
Utility function to apply a method for a given
Meta.Concept
name if provided in the given
Map
of names.
- CONTENT_TYPE - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPublisher
-
- context - Variable in class com.yahoo.bullet.pubsub.PubSub
-
- convert(Map<String, String>, Map<String, Number>) - Method in class com.yahoo.bullet.common.metrics.MetricEventPublisher
-
- convert(Map<String, String>, Map<String, Number>) - Method in class com.yahoo.bullet.common.metrics.MetricPublisher
-
Convert the given dimensions and metrics into the concrete type of this class.
- copy() - Method in class com.yahoo.bullet.common.Validator
-
Returns a copy of this validator.
- copy() - Method in class com.yahoo.bullet.pubsub.Metadata
-
Returns a copy of the current metadata.
- copy(GroupData) - Static method in class com.yahoo.bullet.querying.aggregations.grouping.CachingGroupData
-
- copy() - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummary
-
- COUNT - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupOperation
-
- count() - Method in class com.yahoo.bullet.windowing.Basic
-
Counts the number of windows that have been opened since creation.
- COUNT_DISTINCT_AGGREGATION_SKETCH_ENTRIES - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- COUNT_DISTINCT_AGGREGATION_SKETCH_FAMILY - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- COUNT_DISTINCT_AGGREGATION_SKETCH_RESIZE_FACTOR - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- COUNT_DISTINCT_AGGREGATION_SKETCH_SAMPLING - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- COUNT_FIELD - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
-
- COUNT_FIELD - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- COUNT_FIELD - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- CountDistinct - Class in com.yahoo.bullet.query.aggregations
-
- CountDistinct(List<String>, String) - Constructor for class com.yahoo.bullet.query.aggregations.CountDistinct
-
Constructor that creates a COUNT_DISTINCT aggregation.
- createClient() - Method in class com.yahoo.bullet.common.metrics.HTTPMetricEventPublisher
-
Creates a CloseableHttpClient
client to use for HTTP requests.
- Criteria<T,R> - Interface in com.yahoo.bullet.storage
-
- Culling - Class in com.yahoo.bullet.query.postaggregations
-
- Culling(Set<String>) - Constructor for class com.yahoo.bullet.query.postaggregations.Culling
-
Constructor that creates a Culling post-aggregation.
- CULLING_REQUIRES_FIELDS - Static variable in class com.yahoo.bullet.query.postaggregations.Culling
-
- CullingStrategy - Class in com.yahoo.bullet.querying.postaggregations
-
- CullingStrategy(Culling) - Constructor for class com.yahoo.bullet.querying.postaggregations.CullingStrategy
-
Constructor that creates a Culling post-strategy.
- fail(String) - Method in class com.yahoo.bullet.pubsub.BufferingSubscriber
-
Marks the processing of the
PubSubMessage
with the given id as failed.
- fail(String) - Method in interface com.yahoo.bullet.pubsub.Subscriber
-
Marks the processing of the
PubSubMessage
with the given id as failed.
- field - Variable in class com.yahoo.bullet.query.aggregations.Distribution
-
- Field - Class in com.yahoo.bullet.query
-
- Field(String, Expression) - Constructor for class com.yahoo.bullet.query.Field
-
Constructor that creates a field used in projection and computation.
- fieldAliases - Variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
- FieldEvaluator - Class in com.yahoo.bullet.querying.evaluators
-
An evaluator that extracts a given field from a BulletRecord
.
- FieldEvaluator(FieldExpression) - Constructor for class com.yahoo.bullet.querying.evaluators.FieldEvaluator
-
- FieldEvaluator.FieldExtractor - Interface in com.yahoo.bullet.querying.evaluators
-
- FieldExpression - Class in com.yahoo.bullet.query.expressions
-
An expression that requires a field name.
- FieldExpression(String) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
-
Constructor that creates a field expression.
- FieldExpression(String, Integer) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
-
Constructor that creates a field expression with a list index.
- FieldExpression(String, String) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
-
Constructor that creates a field expression with a map key.
- FieldExpression(String, Integer, String) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
-
Constructor that creates a field expression with a list index and a map subkey.
- FieldExpression(String, String, String) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
-
Constructor that creates a field expression with map key and a map subkey.
- fields - Variable in class com.yahoo.bullet.querying.aggregations.SketchingStrategy
-
- Filter - Class in com.yahoo.bullet.querying
-
Filter consists of an evaluator built from the filter expression in the bullet query.
- Filter(Expression) - Constructor for class com.yahoo.bullet.querying.Filter
-
- finish() - Method in class com.yahoo.bullet.querying.Querier
-
Terminate the query and return the final result.
- fire(String, Number) - Method in class com.yahoo.bullet.common.metrics.MetricPublisher
-
Fire and forget an event with no extra dimensions and the given single metric.
- fire(Map<String, Number>) - Method in class com.yahoo.bullet.common.metrics.MetricPublisher
-
Fire and forget an event with no extra dimensions and the given metrics.
- fire(Map<String, String>, Map<String, Number>) - Method in class com.yahoo.bullet.common.metrics.MetricPublisher
-
Fire and forget an event with the given extra dimensions and the given metrics.
- forArgument(String, Throwable) - Static method in exception com.yahoo.bullet.pubsub.PubSubException
-
Method to create a PubSubException when a required argument could not be read.
- FrequentItemsSketch - Class in com.yahoo.bullet.querying.aggregations.sketches
-
Wraps a ItemsSketch
of String.
- FrequentItemsSketch(ErrorType, int, long, int, BulletRecordProvider) - Constructor for class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
-
Creates a FrequentItemsSketch with the given ErrorType
, the maximum map entries, and threshold.
- FrequentItemsSketch(ErrorType, int, int, BulletRecordProvider) - Constructor for class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
-
Creates a FrequentItemsSketch with the given ErrorType
and the maximum map entries.
- FrequentItemsSketchingStrategy - Class in com.yahoo.bullet.querying.aggregations
-
- FrequentItemsSketchingStrategy(TopK, BulletConfig) - Constructor for class com.yahoo.bullet.querying.aggregations.FrequentItemsSketchingStrategy
-
- from(BulletConfig) - Static method in class com.yahoo.bullet.common.metrics.MetricPublisher
-
Create a
MetricPublisher
instance using the class specified in the config file.
- from(BulletConfig) - Static method in class com.yahoo.bullet.pubsub.PubSub
-
Create a PubSub instance using the class specified in the config file.
- from(String) - Static method in enum com.yahoo.bullet.result.Meta.Concept
-
Creates a Concept instance from a String version of it.
- from(BulletConfig) - Static method in class com.yahoo.bullet.storage.StorageManager
-
Create a
StorageManager
instance using the class specified in the config file.
- fromBytes(byte[]) - Static method in class com.yahoo.bullet.common.SerializerDeserializer
-
- fromJSON(String) - Static method in class com.yahoo.bullet.pubsub.PubSubMessage
-
Converts a json representation back to an instance.
- fromJSON(String, Class<T>) - Static method in interface com.yahoo.bullet.result.JSONFormatter
-
- fromMemory(Memory) - Static method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummary
-
- fromMemory(Memory) - Static method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummaryFactory
-
- generatePoints(double, Function<Double, Double>, int, int) - Static method in class com.yahoo.bullet.common.Utilities
-
Generates an array of points from the given arguments.
- get(String) - Method in class com.yahoo.bullet.common.Config
-
Looks up the key and returns the matching value or null if not.
- get() - Method in class com.yahoo.bullet.common.RandomPool
-
Get a random item from the pool.
- get(StorageManager<V>) - Method in interface com.yahoo.bullet.storage.Criteria
-
- get(StorageManager<V>) - Method in class com.yahoo.bullet.storage.MultiMemoryCountingCriteria
-
- get(String) - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves data stored for a given String identifier in the default namespace as a
Serializable
object.
- getAll(Optional<Set<String>>) - Method in class com.yahoo.bullet.common.Config
-
Gets all mappings for a set of keys.
- getAll(Criteria<T, R>) - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves all the IDs matching the specified
Criteria
from the storage as the type of the storage.
- getAll() - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves all the IDs from the default namespace in the storage as a
Map
of IDs to their
Serializable
values.
- getAll(Set<String>) - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves the values for the provided IDs from the default namespace in the storage as a
Map
of IDs to
their
Serializable
values.
- getAllBut(Optional<Set<String>>) - Method in class com.yahoo.bullet.common.Config
-
Gets all mappings other than a set of keys.
- getAllRaw(String) - Method in class com.yahoo.bullet.storage.MemoryStorageManager
-
- getAllRaw(String) - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
- getAllRaw(String) - Method in class com.yahoo.bullet.storage.NullStorageManager
-
- getAllString() - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves all the IDs from the default namespace in the storage as a
Map
of IDs to their String values.
- getAllString(Set<String>) - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves the values for the provided IDs from the default namespace in the storage as a
Map
of IDs to
their String values.
- getAllWithPrefix(Optional<Set<String>>, String, boolean) - Method in class com.yahoo.bullet.common.Config
-
Get mappings for all keys with the specified prefix.
- getAs(String, Class<T>) - Method in class com.yahoo.bullet.common.Config
-
Get a value from the config as a particular type.
- getAsBulletRecord(BulletRecordProvider) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
Gets the metrics and the group values stored as a BulletRecord
.
- getAsBulletRecord(Map<String, String>, BulletRecordProvider) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
Gets the metrics and the group values stored as a BulletRecord
.
- getBulletRecordProvider() - Method in class com.yahoo.bullet.common.BulletConfig
-
Get the BulletRecordProvider
stored in this BulletConfig instance.
- getCasted(Object, Class<U>) - Static method in class com.yahoo.bullet.common.Utilities
-
Tries to get the object casted as the target type.
- getCasted(Map<String, Object>, String, Class<U>) - Static method in class com.yahoo.bullet.common.Utilities
-
Tries to get a key from a map as the target type.
- getContent() - Method in class com.yahoo.bullet.pubsub.Metadata
-
- getContentAsString() - Method in class com.yahoo.bullet.pubsub.PubSubMessage
-
Returns the content stored in the message as a String.
- getCurrentRate() - Method in class com.yahoo.bullet.querying.RateLimiter
-
Returns the absolute current rate since the last check interval.
- getData() - Method in interface com.yahoo.bullet.common.Monoidal
-
Get the data serialized as a byte[].
- getData() - Method in class com.yahoo.bullet.querying.aggregations.GroupAllStrategy
-
- getData() - Method in class com.yahoo.bullet.querying.aggregations.RawStrategy
-
- getData() - Method in class com.yahoo.bullet.querying.aggregations.SketchingStrategy
-
- getData() - Method in class com.yahoo.bullet.querying.Querier
-
Get the result emitted so far after the last window.
- getData() - Method in class com.yahoo.bullet.windowing.Basic
-
- getData() - Method in class com.yahoo.bullet.windowing.SlidingRecord
-
- getDefaultNamespace() - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
- getDefaultNamespace() - Method in class com.yahoo.bullet.storage.StorageManager
-
Gets the default namespace to store data under.
- getDefaultValue() - Method in class com.yahoo.bullet.common.Validator.Entry
-
Get the defaultValue in the Entry after applying the cast, if present.
- getDimensions(Map<String, String>) - Method in class com.yahoo.bullet.common.metrics.HTTPMetricEventPublisher
-
- getDimensions(Map<String, String>) - Method in class com.yahoo.bullet.common.metrics.MetricPublisher
-
Returns any static dimensions to use.
- getEvaluator() - Method in class com.yahoo.bullet.query.expressions.BinaryExpression
-
- getEvaluator() - Method in class com.yahoo.bullet.query.expressions.CastExpression
-
- getEvaluator() - Method in class com.yahoo.bullet.query.expressions.Expression
-
Gets a new instance of an evaluator for this expression.
- getEvaluator() - Method in class com.yahoo.bullet.query.expressions.FieldExpression
-
- getEvaluator() - Method in class com.yahoo.bullet.query.expressions.ListExpression
-
- getEvaluator() - Method in class com.yahoo.bullet.query.expressions.NAryExpression
-
- getEvaluator() - Method in class com.yahoo.bullet.query.expressions.UnaryExpression
-
- getEvaluator() - Method in class com.yahoo.bullet.query.expressions.ValueExpression
-
- getFamily() - Method in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
-
- getFamily() - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- getFamily() - Method in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
-
Returns a String representing the family of this sketch.
- getFamily() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- getFamily() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- getFields() - Method in class com.yahoo.bullet.query.aggregations.Aggregation
-
Gets the aggregation fields.
- getFields() - Method in class com.yahoo.bullet.query.aggregations.Distribution
-
- getFields() - Method in class com.yahoo.bullet.query.aggregations.GroupBy
-
- getFields() - Method in class com.yahoo.bullet.query.aggregations.TopK
-
- getFieldsToNames() - Method in class com.yahoo.bullet.query.aggregations.GroupBy
-
Gets a map from field names to aliases.
- getGroup() - Method in class com.yahoo.bullet.common.metrics.HTTPMetricEventPublisher
-
- getGroup() - Method in class com.yahoo.bullet.common.metrics.MetricEventPublisher
-
- getKeys(Query) - Method in interface com.yahoo.bullet.querying.partitioning.Partitioner
-
Returns the partitioning keys for this
Query
instance.
- getKeys(BulletRecord) - Method in interface com.yahoo.bullet.querying.partitioning.Partitioner
-
Returns the partitioning keys for this BulletRecord
instance.
- getKeys(Query) - Method in class com.yahoo.bullet.querying.partitioning.SimpleEqualityPartitioner
-
Returns the partitioning keys for this
Query
instance.
- getKeys(BulletRecord) - Method in class com.yahoo.bullet.querying.partitioning.SimpleEqualityPartitioner
-
- getLowerBound(int) - Method in class com.yahoo.bullet.querying.aggregations.sketches.KMVSketch
-
Gets the lower bound at this standard deviation after the last createResult.
- getLowerBound(int) - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- getLowerBound(int) - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- getMessage() - Method in exception com.yahoo.bullet.common.BulletException
-
- getMessages() - Method in class com.yahoo.bullet.pubsub.BufferingSubscriber
-
Implement this method to read and return a
List
of
PubSubMessage
from your actual PubSub source.
- getMessages() - Method in class com.yahoo.bullet.pubsub.rest.RESTSubscriber
-
- getMetadata() - Method in interface com.yahoo.bullet.common.Monoidal
-
Get the metadata only of the data so far.
- getMetadata(String, Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
-
Returns the sketch metadata as a
Meta
object.
- getMetadata() - Method in class com.yahoo.bullet.querying.aggregations.SketchingStrategy
-
- getMetadata() - Method in interface com.yahoo.bullet.querying.aggregations.Strategy
-
- getMetadata() - Method in class com.yahoo.bullet.querying.Querier
-
Returns the
Meta
of the result so far.
- getMetadata(Map<String, String>) - Method in class com.yahoo.bullet.windowing.Basic
-
- getMetadata(Map<String, String>) - Method in class com.yahoo.bullet.windowing.Scheme
-
Return any metadata for the windowing scheme with the given configured names for the metadata concepts.
- getMetadata() - Method in class com.yahoo.bullet.windowing.Scheme
-
- getMetadata(Map<String, String>) - Method in class com.yahoo.bullet.windowing.SlidingRecord
-
- getMetadata(Map<String, String>) - Method in class com.yahoo.bullet.windowing.Tumbling
-
- getMetricsAsBulletRecord(BulletRecordProvider) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
Gets the metrics stored for the group as a BulletRecord
.
- getName() - Method in class com.yahoo.bullet.query.expressions.FieldExpression
-
Gets the name of this field expression formatted with delimiters for any index and/or keys.
- getOrDefault(String, Object) - Method in class com.yahoo.bullet.common.Config
-
If there was a mapping for the key, the mapping is returned if not null, otherwise returns the defaultValue.
- getOrDefaultAs(String, T, Class<T>) - Method in class com.yahoo.bullet.common.Config
-
Get a value from the config as a particular type or default to a provided value.
- getPartition(int) - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves the IDs stored in the provided partition for the default namespace.
- getPartitionRaw(String, int) - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
- getPostStrategy() - Method in class com.yahoo.bullet.query.postaggregations.Computation
-
- getPostStrategy() - Method in class com.yahoo.bullet.query.postaggregations.Culling
-
- getPostStrategy() - Method in class com.yahoo.bullet.query.postaggregations.Having
-
- getPostStrategy() - Method in class com.yahoo.bullet.query.postaggregations.OrderBy
-
- getPostStrategy() - Method in class com.yahoo.bullet.query.postaggregations.PostAggregation
-
Returns a new
PostStrategy
that handles this post-aggregation.
- getPublisher() - Method in class com.yahoo.bullet.pubsub.PubSub
-
- getPublisher() - Method in class com.yahoo.bullet.pubsub.rest.RESTPubSub
-
- getPublishers(int) - Method in class com.yahoo.bullet.pubsub.PubSub
-
Get a list of n
Publisher
instances with the allocated partitions in the appropriate queue
(See
PubSub.context
) split as evenly as possible among them.
- getPublishers(int) - Method in class com.yahoo.bullet.pubsub.rest.RESTPubSub
-
- getQuery() - Method in class com.yahoo.bullet.querying.Querier
-
Gets the
Query
instance for this Query.
- getQuery(String) - Method in class com.yahoo.bullet.querying.QueryManager
-
Retrieves a query stored in the manager or null, if not found.
- getRateLimitError() - Method in class com.yahoo.bullet.querying.Querier
-
- getRaw(String, String) - Method in class com.yahoo.bullet.storage.MemoryStorageManager
-
- getRaw(String, String) - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
- getRaw(String, String) - Method in class com.yahoo.bullet.storage.NullStorageManager
-
- getRecords() - Method in interface com.yahoo.bullet.common.Monoidal
-
Get the data so far as a
List
of
BulletRecord
.
- getRecords() - Method in class com.yahoo.bullet.querying.aggregations.FrequentItemsSketchingStrategy
-
- getRecords() - Method in class com.yahoo.bullet.querying.aggregations.GroupAllStrategy
-
- getRecords() - Method in class com.yahoo.bullet.querying.aggregations.RawStrategy
-
- getRecords() - Method in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
-
- getRecords() - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- getRecords() - Method in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
-
Collects the data presented to the sketch so far and returns the
List
of
BulletRecord
representation of the resulting data in the sketch.
- getRecords() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- getRecords() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- getRecords() - Method in class com.yahoo.bullet.querying.aggregations.SketchingStrategy
-
- getRecords() - Method in class com.yahoo.bullet.querying.aggregations.ThetaSketchingStrategy
-
- getRecords() - Method in class com.yahoo.bullet.querying.Querier
-
Returns the
List
of
BulletRecord
result so far.
- getRecords() - Method in class com.yahoo.bullet.windowing.Basic
-
- getRequiredConfig(Class<T>, String) - Method in class com.yahoo.bullet.pubsub.PubSub
-
A method to get a required configuration of a particular type.
- getRequiredConfigAs(String, Class<T>) - Method in class com.yahoo.bullet.common.Config
-
Get a value from the config as a particular type or throw an exception with a message if not found.
- getResult() - Method in interface com.yahoo.bullet.common.Monoidal
-
Get the data so far as a
Clip
.
- getResult() - Method in class com.yahoo.bullet.querying.aggregations.FrequentItemsSketchingStrategy
-
- getResult() - Method in class com.yahoo.bullet.querying.aggregations.GroupAllStrategy
-
- getResult() - Method in class com.yahoo.bullet.querying.aggregations.RawStrategy
-
- getResult(String, Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
-
- getResult(String, Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- getResult(String, Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
-
Gets the result from the data presented to the sketch as a
Clip
.
- getResult(String, Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- getResult(String, Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- getResult() - Method in class com.yahoo.bullet.querying.aggregations.SketchingStrategy
-
- getResult() - Method in class com.yahoo.bullet.querying.aggregations.ThetaSketchingStrategy
-
- getResult() - Method in class com.yahoo.bullet.querying.Querier
-
Gets the resulting
Clip
of the results so far.
- getResult() - Method in class com.yahoo.bullet.windowing.Basic
-
- getResultName(GroupOperation) - Static method in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
Returns the name of the result field to use for the given
GroupOperation
.
- getSchema() - Method in class com.yahoo.bullet.common.BulletConfig
-
- getScheme(Strategy, BulletConfig) - Method in class com.yahoo.bullet.query.Window
-
- getSize() - Method in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
-
- getSize() - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- getSize() - Method in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
-
Returns the size of the Sketch in bytes.
- getSize() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- getSize() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- getStats() - Method in class com.yahoo.bullet.querying.QueryManager
-
Gets some statistics about the current state of partitioning and queries in this manager.
- getStrategy(BulletConfig) - Method in class com.yahoo.bullet.query.aggregations.Aggregation
-
Returns a new
Strategy
instance that handles this aggregation.
- getStrategy(BulletConfig) - Method in class com.yahoo.bullet.query.aggregations.CountDistinct
-
- getStrategy(BulletConfig) - Method in class com.yahoo.bullet.query.aggregations.Distribution
-
- getStrategy(BulletConfig) - Method in class com.yahoo.bullet.query.aggregations.GroupAll
-
- getStrategy(BulletConfig) - Method in class com.yahoo.bullet.query.aggregations.GroupBy
-
- getStrategy(BulletConfig) - Method in class com.yahoo.bullet.query.aggregations.Raw
-
- getStrategy(BulletConfig) - Method in class com.yahoo.bullet.query.aggregations.TopK
-
- getString(String) - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves data stored for a given String identifier in the default namespace as a String.
- getSubscriber() - Method in class com.yahoo.bullet.pubsub.PubSub
-
- getSubscriber() - Method in class com.yahoo.bullet.pubsub.rest.RESTPubSub
-
- getSubscribers(int) - Method in class com.yahoo.bullet.pubsub.PubSub
-
Get a list of n
Subscriber
instances with allocated partitions from the appropriate queue
(See
PubSub.context
) split as evenly as possible among them.
- getSubscribers(int) - Method in class com.yahoo.bullet.pubsub.rest.RESTPubSub
-
- getSummarySetOperations() - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummaryFactory
-
- getTheta() - Method in class com.yahoo.bullet.querying.aggregations.sketches.KMVSketch
-
Gets the theta value for this sketch after the last createResult.
- getTheta() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- getTheta() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- getType() - Method in class com.yahoo.bullet.query.Window
-
Gets the classification of this window for the given emit and include types.
- getUpperBound(int) - Method in class com.yahoo.bullet.querying.aggregations.sketches.KMVSketch
-
Gets the uppper bound at this standard deviation after the last createResult.
- getUpperBound(int) - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- getUpperBound(int) - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- getValidator() - Static method in class com.yahoo.bullet.common.BulletConfig
-
Returns a copy of the
Validator
used by this config.
- GROUP - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
-
- GROUP_AGGREGATION_MAX_SIZE - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- GROUP_AGGREGATION_SKETCH_ENTRIES - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- GROUP_AGGREGATION_SKETCH_RESIZE_FACTOR - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- GROUP_AGGREGATION_SKETCH_SAMPLING - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- GroupAll - Class in com.yahoo.bullet.query.aggregations
-
- GroupAll(Set<GroupOperation>) - Constructor for class com.yahoo.bullet.query.aggregations.GroupAll
-
Constructor that creates a GROUP aggregation with a set of group operations.
- GroupAllStrategy - Class in com.yahoo.bullet.querying.aggregations
-
- GroupAllStrategy(GroupAll, BulletConfig) - Constructor for class com.yahoo.bullet.querying.aggregations.GroupAllStrategy
-
- GroupBy - Class in com.yahoo.bullet.query.aggregations
-
- GroupBy(Integer, Map<String, String>, Set<GroupOperation>) - Constructor for class com.yahoo.bullet.query.aggregations.GroupBy
-
Constructor that creates a GROUP aggregation with a specified max size and fields.
- GroupData - Class in com.yahoo.bullet.querying.aggregations.grouping
-
This class represents the results of a GroupOperations.
- GroupData(Map<String, String>, Set<GroupOperation>) - Constructor for class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
Constructor that initializes the GroupData with a
Set
of
GroupOperation
and a
Map
of
Strings that represent the group fields.
- GroupData(Set<GroupOperation>) - Constructor for class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
- GroupData(Map<String, String>, Map<String, String>, Map<GroupOperation, Number>) - Constructor for class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
Constructor that initializes the GroupData with an existing
Map
of
GroupOperation
to values and
a
Map
of Strings that represent the group fields.
- GroupDataSummary - Class in com.yahoo.bullet.querying.aggregations.grouping
-
- GroupDataSummary() - Constructor for class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummary
-
- GroupDataSummaryFactory - Class in com.yahoo.bullet.querying.aggregations.grouping
-
- GroupDataSummaryFactory() - Constructor for class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummaryFactory
-
- GroupDataSummarySetOperations - Class in com.yahoo.bullet.querying.aggregations.grouping
-
The stateless implementation of the summary set operations for a
GroupDataSummary
.
- GroupDataSummarySetOperations() - Constructor for class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummarySetOperations
-
- groupFields - Variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
- GroupOperation - Class in com.yahoo.bullet.querying.aggregations.grouping
-
This class captures an operation that will be performed on an entire group - counts, sums, mins etc.
- GroupOperation(GroupOperation.GroupOperationType, String, String) - Constructor for class com.yahoo.bullet.querying.aggregations.grouping.GroupOperation
-
Constructor that creates a group operation.
- GroupOperation.GroupOperationType - Enum in com.yahoo.bullet.querying.aggregations.grouping
-
- GroupOperation.GroupOperator - Interface in com.yahoo.bullet.querying.aggregations.grouping
-
- GSON - Static variable in interface com.yahoo.bullet.result.JSONFormatter
-
- ifTrueThenCheck(Predicate<Object>) - Static method in class com.yahoo.bullet.common.Validator
-
Returns a
BiPredicate
that checks to see if the first boolean argument implies the second
Predicate
.
- IMPROPER_EMIT - Static variable in class com.yahoo.bullet.query.Window
-
- IMPROPER_EVERY - Static variable in class com.yahoo.bullet.query.Window
-
- IMPROPER_INCLUDE - Static variable in class com.yahoo.bullet.query.Window
-
- increment(String) - Method in class com.yahoo.bullet.common.metrics.MetricCollector
-
Increment the value for the given key.
- increment() - Method in class com.yahoo.bullet.querying.RateLimiter
-
Increment the measure that this is counting by one.
- INFINITY - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- Initializable - Interface in com.yahoo.bullet.common
-
- initialize() - Method in interface com.yahoo.bullet.common.Initializable
-
Validates and initializes this object.
- INITIALIZED_POSITION - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummary
-
- intersection(GroupDataSummary, GroupDataSummary) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummarySetOperations
-
- INVALID_DOUBLES - Static variable in interface com.yahoo.bullet.result.JSONFormatter
-
- isAtleastNTimes(double) - Static method in class com.yahoo.bullet.common.Validator
-
Returns a
BiPredicate
that checks to see if the first argument is at least the given times
more than the second.
- isBoolean(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is a
Boolean
.
- isClassName(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the given object refers to a class name that can be loaded.
- isClosed() - Method in interface com.yahoo.bullet.common.Closable
-
Returns true if this is currently closed.
- isClosed() - Method in class com.yahoo.bullet.querying.aggregations.RawStrategy
-
- isClosed() - Method in interface com.yahoo.bullet.querying.aggregations.Strategy
-
Returns false if more data should not be consumed or combined.
- isClosed() - Method in class com.yahoo.bullet.querying.Querier
-
Depending on the
Querier.Mode.ALL
mode this is operating in, returns true if and only if the query window is
closed and you should emit the result at this time.
- isClosed() - Method in class com.yahoo.bullet.windowing.Basic
-
- isClosed() - Method in class com.yahoo.bullet.windowing.SlidingRecord
-
- isClosed() - Method in class com.yahoo.bullet.windowing.Tumbling
-
- isClosedForPartition() - Method in class com.yahoo.bullet.windowing.Basic
-
- isClosedForPartition() - Method in class com.yahoo.bullet.windowing.Scheme
-
Returns true if this window is closed when operating in partition mode.
- isClosedForPartition() - Method in class com.yahoo.bullet.windowing.SlidingRecord
-
- isClosedForPartition() - Method in class com.yahoo.bullet.windowing.Tumbling
-
- isDone() - Method in class com.yahoo.bullet.querying.Querier
-
Returns true if the query has expired and will never accept any more data.
- isEmpty(Map) - Static method in class com.yahoo.bullet.common.Utilities
-
Checks to see if the
Map
contains any mappings.
- isEmpty(Collection) - Static method in class com.yahoo.bullet.common.Utilities
-
Checks to see if the
Collection
contains any items.
- isEmpty(String) - Static method in class com.yahoo.bullet.common.Utilities
-
Checks to see if the
String
is present.
- isEstimationMode() - Method in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
-
- isEstimationMode() - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- isEstimationMode() - Method in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
-
Returns whether this sketch was in estimation mode or not.
- isEstimationMode() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- isEstimationMode() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- isExceedingRateLimit() - Method in class com.yahoo.bullet.querying.Querier
-
Returns whether this is exceeding the rate limit.
- isFalse(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is false or not.
- isFloat(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is an floating-point.
- isGreaterOrEqual(Object, Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the first numeric object is greater than or equal to the second numeric object.
- isImplied(Object, Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the first boolean object implies the second boolean object.
- isImpliedBy(Predicate<Object>, Predicate<Object>) - Static method in class com.yahoo.bullet.common.Validator
-
- isIn(T...) - Static method in class com.yahoo.bullet.common.Validator
-
Creates a
Predicate
that checks to see if the given object is in the list of values.
- isInRange(T, T) - Static method in class com.yahoo.bullet.common.Validator
-
Creates a
Predicate
that checks to see if the given object is a
Number
in the proper range.
- isInt(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is an integer type.
- isList(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is a
List
.
- isListOfType(Class<T>) - Static method in class com.yahoo.bullet.common.Validator
-
Creates a
Predicate
that checks to see if the given object is a non-empty
List
of the
given type.
- isMap(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is a
Map
.
- isMapOfType(Class<K>, Class<V>) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is a
Map
of the given key and value type.
- isMe(String) - Method in enum com.yahoo.bullet.result.Meta.Concept
-
Returns true iff the given String concept is this Concept.
- isNonEmptyList(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is a non-empty
List
.
- isNonEmptyMap(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is a non-empty
Map
.
- isNotNull(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is null or not.
- isNull(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is null or not.
- isNumber(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is a
Number
.
- isPositive(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value was positive.
- isPositiveInt(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value was a positive integer (
Integer
or
Long
).
- isPowerOfTwo(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value was a positive integer (
Integer
or
Long
) and a power of 2.
- isRateLimited() - Method in class com.yahoo.bullet.querying.RateLimiter
-
Checks to see if this is rate limited.
- isString(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is a
String
.
- isTimeBased() - Method in class com.yahoo.bullet.query.Window
-
Returns true if this is a time based window (emits based on time).
- isTimedOut() - Method in class com.yahoo.bullet.querying.RunningQuery
-
Returns true if this running query has timed out.
- isTrue(Object) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is true or not.
- isType(Object, Class) - Static method in class com.yahoo.bullet.common.Validator
-
Checks to see if the value is of the provided type or not.
- ITEM_FIELD - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
-
- makeError(String, String) - Static method in class com.yahoo.bullet.common.BulletError
-
Creates a BulletError with the given error message and resolution.
- makeInitialMetrics(Set<GroupOperation>) - Static method in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
- makeMeta() - Method in class com.yahoo.bullet.querying.RateLimitError
-
Makes this into a
Meta
object.
- ManualDistribution - Class in com.yahoo.bullet.query.aggregations
-
- ManualDistribution(String, DistributionType, Integer, List<Double>) - Constructor for class com.yahoo.bullet.query.aggregations.ManualDistribution
-
Constructor that creates a DISTRIBUTION aggregation with a specified max size.
- match(BulletRecord) - Method in class com.yahoo.bullet.querying.Filter
-
Checks whether the given record matches this filter.
- MAX - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupOperation
-
- MAX_CONCURRENCY - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
-
- MAX_UNCOMMITTED_MESSAGES - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
-
- MAXIMUM_EQUALITY_FIELDS - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- maxUncommittedMessages - Variable in class com.yahoo.bullet.pubsub.BufferingSubscriber
-
The maximum number of PubSubMessages we can have unacked at any time.
- MemoryStorageManager<V extends Serializable> - Class in com.yahoo.bullet.storage
-
A Storage manager that stores everything in-memory and does not support namespaces or partitions.
- MemoryStorageManager(BulletConfig) - Constructor for class com.yahoo.bullet.storage.MemoryStorageManager
-
Constructor.
- merge(Config) - Method in class com.yahoo.bullet.common.BulletConfig
-
- merge(Config) - Method in class com.yahoo.bullet.common.Config
-
Merges another Config into this one.
- merge(Monoidal) - Method in interface com.yahoo.bullet.common.Monoidal
-
Combine the data from another instance of the same type of object into this Monoid.
- merge() - Method in class com.yahoo.bullet.querying.aggregations.sketches.DualSketch
-
This method must be called before getting any kind of data out of the sketch.
- merge(Meta) - Method in class com.yahoo.bullet.result.Meta
-
Merge another Meta into this Meta.
- mergeBothSketches() - Method in class com.yahoo.bullet.querying.aggregations.sketches.DualSketch
-
Merge and reset both the update sketch and the union sketch into the result.
- mergeBothSketches() - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- mergeBothSketches() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- mergeBothSketches() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- mergeInPlace(GroupDataSummary, GroupDataSummary) - Static method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummary
-
- mergeUnionSketch() - Method in class com.yahoo.bullet.querying.aggregations.sketches.DualSketch
-
Merge and reset just the union sketch into the result.
- mergeUnionSketch() - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- mergeUnionSketch() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- mergeUnionSketch() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- mergeUpdateSketch() - Method in class com.yahoo.bullet.querying.aggregations.sketches.DualSketch
-
Merge and reset just the update sketch into the result.
- mergeUpdateSketch() - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- mergeUpdateSketch() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- mergeUpdateSketch() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- Meta - Class in com.yahoo.bullet.result
-
- Meta() - Constructor for class com.yahoo.bullet.result.Meta
-
- Meta.Concept - Enum in com.yahoo.bullet.result
-
- META_KEY - Static variable in class com.yahoo.bullet.result.Clip
-
- META_STD_DEV_1 - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.KMVSketch
-
- META_STD_DEV_2 - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.KMVSketch
-
- META_STD_DEV_3 - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.KMVSketch
-
- META_STD_DEV_LB - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.KMVSketch
-
- META_STD_DEV_UB - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.KMVSketch
-
- Metadata - Class in com.yahoo.bullet.pubsub
-
- Metadata() - Constructor for class com.yahoo.bullet.pubsub.Metadata
-
Default constructor that creates an empty instance of metadata.
- Metadata(Metadata.Signal, Serializable) - Constructor for class com.yahoo.bullet.pubsub.Metadata
-
- Metadata.Signal - Enum in com.yahoo.bullet.pubsub
-
- metadataKeys - Variable in class com.yahoo.bullet.querying.aggregations.SketchingStrategy
-
- metadataKeys - Variable in class com.yahoo.bullet.windowing.Scheme
-
- METRIC_PUBLISHER_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- MetricCollector - Class in com.yahoo.bullet.common.metrics
-
Utility class to concurrently store frequency and average metrics for various string keys.
- MetricCollector(List<String>) - Constructor for class com.yahoo.bullet.common.metrics.MetricCollector
-
A constructor that sets up the collector with an initial count of 0 for each of the given metrics.
- MetricCollector(List<String>, List<String>) - Constructor for class com.yahoo.bullet.common.metrics.MetricCollector
-
A constructor that sets up the collector with an initial count of 0 for each of the given metrics.
- MetricEvent - Class in com.yahoo.bullet.common.metrics
-
Simple wrapper that represents a metric event being published.
- MetricEvent(String, Map<String, String>, Map<String, Number>) - Constructor for class com.yahoo.bullet.common.metrics.MetricEvent
-
Constructor.
- MetricEventPublisher - Class in com.yahoo.bullet.common.metrics
-
- MetricEventPublisher(BulletConfig) - Constructor for class com.yahoo.bullet.common.metrics.MetricEventPublisher
-
- MetricPublisher<T> - Class in com.yahoo.bullet.common.metrics
-
- MetricPublisher(BulletConfig) - Constructor for class com.yahoo.bullet.common.metrics.MetricPublisher
-
- metrics - Variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
-
- MIN - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupOperation
-
- Monoidal - Interface in com.yahoo.bullet.common
-
This interface captures the associative operations that can be performed within Bullet.
- MultiMemoryCountingCriteria - Class in com.yahoo.bullet.storage
-
- MultiMemoryCountingCriteria() - Constructor for class com.yahoo.bullet.storage.MultiMemoryCountingCriteria
-
- MultiMemoryStorageManager<V extends Serializable> - Class in com.yahoo.bullet.storage
-
A storage that stores everything in-memory and supports namespaces and partitions.
- MultiMemoryStorageManager(BulletConfig) - Constructor for class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
Constructor.
- partialCopy() - Method in class com.yahoo.bullet.querying.aggregations.grouping.CachingGroupData
-
Creates a partial copy of itself.
- partition(BulletRecord) - Method in class com.yahoo.bullet.querying.QueryManager
-
Takes a
BulletRecord
instance and returns the matching queries (according to the
Partitioner
)
for it as as
Map
of query IDs to the
Querier
instances.
- PARTITION_COUNT - Static variable in class com.yahoo.bullet.storage.StorageConfig
-
- Partitioner - Interface in com.yahoo.bullet.querying.partitioning
-
- POSITIVE_INFINITY - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- POSITIVE_INFINITY_END - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- PostAggregation - Class in com.yahoo.bullet.query.postaggregations
-
- PostAggregation() - Constructor for class com.yahoo.bullet.query.postaggregations.PostAggregation
-
- PostAggregationType - Enum in com.yahoo.bullet.query.postaggregations
-
- PostStrategy - Interface in com.yahoo.bullet.querying.postaggregations
-
- PREFIX - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
-
- PREFIX - Static variable in class com.yahoo.bullet.storage.StorageConfig
-
- PROBABILITY_FIELD - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- project(BulletRecord, BulletRecordProvider) - Method in class com.yahoo.bullet.querying.Projection
-
Projects onto a new BulletRecord.
- project(BulletRecord) - Method in class com.yahoo.bullet.querying.Projection
-
Projects onto a BulletRecord.
- Projection - Class in com.yahoo.bullet.query
-
- Projection() - Constructor for class com.yahoo.bullet.query.Projection
-
Default constructor that creates a PASS_THROUGH projection.
- Projection(List<Field>, boolean) - Constructor for class com.yahoo.bullet.query.Projection
-
Constructor that creates a COPY or NO_COPY projection.
- Projection - Class in com.yahoo.bullet.querying
-
Projection consists of a mapping of names to evaluators built from the projection in the Bullet query.
- Projection(List<Field>) - Constructor for class com.yahoo.bullet.querying.Projection
-
Constructor that creates a Projection from the given fields.
- Projection.Type - Enum in com.yahoo.bullet.query
-
The type of the Projection decides how its fields are projected.
- provider - Variable in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
-
- publish(MetricEvent) - Method in class com.yahoo.bullet.common.metrics.HTTPMetricEventPublisher
-
- publish(String, Number) - Method in class com.yahoo.bullet.common.metrics.MetricPublisher
-
Publishes an event with no extra dimensions and the given single metric.
- publish(Map<String, Number>) - Method in class com.yahoo.bullet.common.metrics.MetricPublisher
-
Publishes an event no extra dimensions and the given metrics.
- publish(Map<String, String>, Map<String, Number>) - Method in class com.yahoo.bullet.common.metrics.MetricPublisher
-
Publish an event with the given dimensions and metrics.
- publish(T) - Method in class com.yahoo.bullet.common.metrics.MetricPublisher
-
Publish a payload of the concrete type of this class.
- publisher - Variable in class com.yahoo.bullet.pubsub.BulletPubSubResponder
-
- Publisher - Interface in com.yahoo.bullet.pubsub
-
- PUBLISHER_CONNECT_TIMEOUT - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
-
- pubSub - Variable in class com.yahoo.bullet.pubsub.BulletPubSubResponder
-
- PubSub - Class in com.yahoo.bullet.pubsub
-
Notation: Partition is a unit of parallelism in the Pub/Sub queue.
- PubSub(BulletConfig) - Constructor for class com.yahoo.bullet.pubsub.PubSub
-
- PubSub.Context - Enum in com.yahoo.bullet.pubsub
-
- PUBSUB_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- PUBSUB_CONTEXT_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- PubSubException - Exception in com.yahoo.bullet.pubsub
-
- PubSubException(String) - Constructor for exception com.yahoo.bullet.pubsub.PubSubException
-
Constructor to initialize PubSubException with a message.
- PubSubException(String, Throwable) - Constructor for exception com.yahoo.bullet.pubsub.PubSubException
-
Constructor to initialize PubSubException with a message and a
Throwable
cause.
- PubSubMessage - Class in com.yahoo.bullet.pubsub
-
The class of messages that can be understood by the PubSub package.
- PubSubMessage() - Constructor for class com.yahoo.bullet.pubsub.PubSubMessage
-
Constructor for a message having no information.
- PubSubMessage(String, Metadata.Signal) - Constructor for class com.yahoo.bullet.pubsub.PubSubMessage
-
- PubSubMessage(String, byte[]) - Constructor for class com.yahoo.bullet.pubsub.PubSubMessage
-
Constructor for a message having only content.
- PubSubMessage(String, String) - Constructor for class com.yahoo.bullet.pubsub.PubSubMessage
-
Constructor for a message having only content as a String.
- PubSubMessage(String, byte[], Metadata.Signal) - Constructor for class com.yahoo.bullet.pubsub.PubSubMessage
-
- PubSubMessage(String, String, Metadata) - Constructor for class com.yahoo.bullet.pubsub.PubSubMessage
-
Constructor for a message having content as a String and
Metadata
.
- PubSubMessage(String, byte[], Metadata) - Constructor for class com.yahoo.bullet.pubsub.PubSubMessage
-
Constructor for a message having content and
Metadata
.
- PubSubResponder - Class in com.yahoo.bullet.pubsub
-
This can be extended by any class that needs to respond to a
PubSubMessage
.
- PubSubResponder(BulletConfig) - Constructor for class com.yahoo.bullet.pubsub.PubSubResponder
-
Constructor.
- put(String, V) - Method in class com.yahoo.bullet.storage.StorageManager
-
Stores any
Serializable
object for a given String identifier in the default namespace.
- putAll(Map<String, V>) - Method in class com.yahoo.bullet.storage.StorageManager
-
Stores a map of IDs and values into the storage in the default namespace.
- putAllString(Map<String, String>) - Method in class com.yahoo.bullet.storage.StorageManager
-
Stores a map of IDs and String values into the storage in the default namespace.
- putNotNull(Map<K, V>, K, V) - Static method in class com.yahoo.bullet.common.Utilities
-
Adds the given mapping to the given
Map
if the value is not null.
- putRaw(String, String, byte[]) - Method in class com.yahoo.bullet.storage.MemoryStorageManager
-
- putRaw(String, String, byte[]) - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
- putRaw(String, String, byte[]) - Method in class com.yahoo.bullet.storage.NullStorageManager
-
- putString(String, String) - Method in class com.yahoo.bullet.storage.StorageManager
-
Stores a String for a given String identifier in the default namespace.
- RandomPool<T> - Class in com.yahoo.bullet.common
-
- RandomPool(List<T>) - Constructor for class com.yahoo.bullet.common.RandomPool
-
Constructor for the RandomPool that takes a list of items.
- RANGE_FIELD - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- RATE_LIMIT_ENABLE - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- RATE_LIMIT_MAX_EMIT_COUNT - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- RATE_LIMIT_TIME_INTERVAL - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- RateLimiter - Class in com.yahoo.bullet.querying
-
This class implements a simple rate checking mechanism.
- RateLimiter(int) - Constructor for class com.yahoo.bullet.querying.RateLimiter
-
- RateLimiter(int, int) - Constructor for class com.yahoo.bullet.querying.RateLimiter
-
Create an instance of this that uses the given maximum and the given time interval.
- RateLimitError - Class in com.yahoo.bullet.querying
-
- RateLimitError(double, double) - Constructor for class com.yahoo.bullet.querying.RateLimitError
-
/**
Creates an instance of this from a given absolute exceeded rate and a maximum rate limit.
- Raw - Class in com.yahoo.bullet.query.aggregations
-
- Raw(Integer) - Constructor for class com.yahoo.bullet.query.aggregations.Raw
-
Constructor that creates a RAW aggregation with a specified max size.
- RAW_AGGREGATION_MAX_SIZE - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- RawStrategy - Class in com.yahoo.bullet.querying.aggregations
-
Implements the LIMIT operation on multiple raw BulletRecord
.
- RawStrategy(Aggregation, BulletConfig) - Constructor for class com.yahoo.bullet.querying.aggregations.RawStrategy
-
- readYAML(String) - Method in class com.yahoo.bullet.common.Config
-
Reads a YAML file containing mappings and returns them as a
Map
.
- receive() - Method in class com.yahoo.bullet.pubsub.BufferingSubscriber
-
- receive() - Method in interface com.yahoo.bullet.pubsub.Subscriber
-
Gets a new
PubSubMessage
from the assigned partition/partitions (Here a partition is a unit of
parallelism in the Pub/Sub queue, See
PubSub
).
- receivedMessages - Variable in class com.yahoo.bullet.pubsub.BufferingSubscriber
-
A List of messages read.
- RECORD_PROVIDER_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- RECORD_SCHEMA_FILE_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- RECORDS_KEY - Static variable in class com.yahoo.bullet.result.Clip
-
- RegionDistribution - Class in com.yahoo.bullet.query.aggregations
-
- RegionDistribution(String, DistributionType, Integer, double, double, double) - Constructor for class com.yahoo.bullet.query.aggregations.RegionDistribution
-
Constructor that creates a DISTRIBUTION aggregation with a specified max size.
- relate(String, String, String) - Method in class com.yahoo.bullet.common.Validator
-
Create a relationship with a description for it for the given fields.
- remove(String) - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves and removes data stored for a given String identifier as a
Serializable
object in the default
namespace.
- removeAndGetQueries(Set<String>) - Method in class com.yahoo.bullet.querying.QueryManager
-
Removes and returns the
List
of
Querier
instances for the given non-null query IDs.
- removeAndGetQuery(String) - Method in class com.yahoo.bullet.querying.QueryManager
-
Removes and returns a
Querier
from the manager.
- removeQueries(Set<String>) - Method in class com.yahoo.bullet.querying.QueryManager
-
Removes all the queries for the given non-null
Set
of query IDs from the manager completely.
- removeRaw(String, String) - Method in class com.yahoo.bullet.storage.MemoryStorageManager
-
- removeRaw(String, String) - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
- removeRaw(String, String) - Method in class com.yahoo.bullet.storage.NullStorageManager
-
- removeString(String) - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves and removes data stored for a given String identifier as a String in the default namespace.
- repartition(String, int) - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
-
- repartition(int) - Method in class com.yahoo.bullet.storage.StorageManager
-
Repartitions the data into the given new number of partitions in the default namespace.
- requireNonNull(List<T>) - Static method in class com.yahoo.bullet.common.Utilities
-
- requireNonNull(Set<T>) - Static method in class com.yahoo.bullet.common.Utilities
-
- requireNonNull(Map<K, V>) - Static method in class com.yahoo.bullet.common.Utilities
-
- reset() - Method in interface com.yahoo.bullet.common.Monoidal
-
Reset the data so far and make this the identity element for the Monoid with respect to inserting data.
- reset() - Method in class com.yahoo.bullet.querying.aggregations.GroupAllStrategy
-
- reset() - Method in class com.yahoo.bullet.querying.aggregations.RawStrategy
-
- reset() - Method in class com.yahoo.bullet.querying.aggregations.sketches.DualSketch
-
Resets the Sketch to the original state.
- reset() - Method in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
-
- reset() - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- reset() - Method in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
-
Resets the Sketch to the original state.
- reset() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
-
- reset() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
-
- reset() - Method in class com.yahoo.bullet.querying.aggregations.SketchingStrategy
-
- reset() - Method in class com.yahoo.bullet.querying.Querier
-
Resets this object.
- reset() - Method in class com.yahoo.bullet.windowing.AdditiveTumbling
-
- reset() - Method in class com.yahoo.bullet.windowing.Basic
-
- reset() - Method in class com.yahoo.bullet.windowing.SlidingRecord
-
- reset() - Method in class com.yahoo.bullet.windowing.Tumbling
-
- resetForPartition() - Method in class com.yahoo.bullet.windowing.AdditiveTumbling
-
- resetForPartition() - Method in class com.yahoo.bullet.windowing.Basic
-
- resetForPartition() - Method in class com.yahoo.bullet.windowing.Scheme
-
Resets the window when operating in partition mode.
- RESOLUTIONS - Static variable in class com.yahoo.bullet.querying.RateLimitError
-
- RESOLUTIONS_KEY - Static variable in class com.yahoo.bullet.common.BulletError
-
- respond(String, PubSubMessage) - Method in class com.yahoo.bullet.pubsub.BulletPubSubResponder
-
- respond(String, PubSubMessage) - Method in class com.yahoo.bullet.pubsub.PubSubResponder
-
- restart() - Method in class com.yahoo.bullet.querying.Querier
-
Forces a restart of a valid query to mark the
correct start of this object if it was previously created but delayed in starting it (by using the negation of
Querier.shouldBuffer()
.
- RESTPublisher - Class in com.yahoo.bullet.pubsub.rest
-
- RESTPublisher(CloseableHttpClient, int) - Constructor for class com.yahoo.bullet.pubsub.rest.RESTPublisher
-
Create a RESTQueryPublisher from a CloseableHttpClient
.
- RESTPubSub - Class in com.yahoo.bullet.pubsub.rest
-
- RESTPubSub(BulletConfig) - Constructor for class com.yahoo.bullet.pubsub.rest.RESTPubSub
-
- RESTPubSubConfig - Class in com.yahoo.bullet.pubsub.rest
-
- RESTPubSubConfig(String) - Constructor for class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
-
Constructor that loads specific file augmented with defaults.
- RESTPubSubConfig(Config) - Constructor for class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
-
Constructor that loads the defaults and augments it with defaults.
- RESTQueryPublisher - Class in com.yahoo.bullet.pubsub.rest
-
- RESTQueryPublisher(CloseableHttpClient, String, String, int) - Constructor for class com.yahoo.bullet.pubsub.rest.RESTQueryPublisher
-
Create a RESTQueryPublisher from a CloseableHttpClient
, queryURL and resultURL.
- RESTResultPublisher - Class in com.yahoo.bullet.pubsub.rest
-
- RESTResultPublisher(CloseableHttpClient, int) - Constructor for class com.yahoo.bullet.pubsub.rest.RESTResultPublisher
-
Create a RESTQueryPublisher from a CloseableHttpClient
.
- RESTSubscriber - Class in com.yahoo.bullet.pubsub.rest
-
- RESTSubscriber(int, List<String>, CloseableHttpClient, long, int) - Constructor for class com.yahoo.bullet.pubsub.rest.RESTSubscriber
-
Create a RESTSubscriber.
- RESULT_METADATA_ENABLE - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- RESULT_METADATA_METRICS - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- RESULT_METADATA_METRICS_CONCEPT_KEY - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- RESULT_METADATA_METRICS_NAME_KEY - Static variable in class com.yahoo.bullet.common.BulletConfig
-
- RESULT_SUBSCRIBER_MIN_WAIT - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
-
- RESULT_URL - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
-
- RETRIES - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
-
- retrieve(StorageManager<V>) - Method in interface com.yahoo.bullet.storage.Criteria
-
- retrieve(StorageManager<V>) - Method in class com.yahoo.bullet.storage.MultiMemoryCountingCriteria
-
- retrieveAll(Criteria<T, R>) - Method in class com.yahoo.bullet.storage.StorageManager
-
Retrieves all the data matching the specified
Criteria
as the types of the
Criteria
.
- RETRY_INTERVAL_MS - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
-
- round(double, int) - Static method in class com.yahoo.bullet.common.Utilities
-
Rounds a double up to the specified number of places.
- RunningQuery - Class in com.yahoo.bullet.querying
-
A wrapper for a running query.
- RunningQuery(String, Query, Metadata) - Constructor for class com.yahoo.bullet.querying.RunningQuery
-
Constructor that takes an id, query, query string, and start time.
- validate() - Method in class com.yahoo.bullet.common.BulletConfig
-
Validates and fixes configuration for this config.
- validate() - Method in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
-
- validate(BulletConfig) - Method in class com.yahoo.bullet.common.Validator
-
Validate and normalize the provided
BulletConfig
for the defined entries and relationships.
- validate() - Method in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
-
- validate() - Method in class com.yahoo.bullet.storage.StorageConfig
-
- Validator - Class in com.yahoo.bullet.common
-
- Validator() - Constructor for class com.yahoo.bullet.common.Validator
-
Default constructor.
- Validator.Entry - Class in com.yahoo.bullet.common
-
This represents a field in the Validator.
- Validator.Relationship - Class in com.yahoo.bullet.common
-
This represents a binary relationship between two fields in a
BulletConfig
.
- Validator.State - Class in com.yahoo.bullet.common
-
This represents a n-ary validation for the config.
- VALUE_FIELD - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
-
- ValueEvaluator - Class in com.yahoo.bullet.querying.evaluators
-
An evaluator that returns a constant value.
- ValueEvaluator(ValueExpression) - Constructor for class com.yahoo.bullet.querying.evaluators.ValueEvaluator
-
- ValueExpression - Class in com.yahoo.bullet.query.expressions
-
An expression that requires a primitive or null value.
- ValueExpression(Serializable) - Constructor for class com.yahoo.bullet.query.expressions.ValueExpression
-
Constructor that creates a value expression.
- valueOf(String) - Static method in enum com.yahoo.bullet.pubsub.Metadata.Signal
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.pubsub.PubSub.Context
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.query.aggregations.AggregationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.query.aggregations.DistributionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.query.expressions.Operation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.query.postaggregations.OrderBy.Direction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.query.postaggregations.PostAggregationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.query.Projection.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.query.Window.Classification
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.query.Window.Unit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.querying.aggregations.grouping.GroupOperation.GroupOperationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.querying.Querier.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.querying.QueryManager.PartitionStat
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.yahoo.bullet.result.Meta.Concept
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.yahoo.bullet.pubsub.Metadata.Signal
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.pubsub.PubSub.Context
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.query.aggregations.AggregationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.query.aggregations.DistributionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.query.expressions.Operation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.query.postaggregations.OrderBy.Direction
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.query.postaggregations.PostAggregationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.query.Projection.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.query.Window.Classification
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.query.Window.Unit
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.querying.aggregations.grouping.GroupOperation.GroupOperationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.querying.Querier.Mode
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.querying.QueryManager.PartitionStat
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum com.yahoo.bullet.result.Meta.Concept
-
Returns an array containing the constants of this enum type, in
the order they are declared.