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

A

add(String, long) - Method in class com.yahoo.bullet.common.metrics.MetricCollector
Add the given total to the existing sum for the given key.
add(int) - Method in class com.yahoo.bullet.querying.RateLimiter
Increment the measure that this is counting by the given positive number.
add(BulletRecord) - Method in class com.yahoo.bullet.result.Clip
Adds a BulletRecord to the records in the Clip.
add(List<BulletRecord>) - Method in class com.yahoo.bullet.result.Clip
Adds all the BulletRecord to the records in the Clip.
add(Clip) - Method in class com.yahoo.bullet.result.Clip
Adds all the BulletRecord and the Meta from the given Clip to this.
add(Meta) - Method in class com.yahoo.bullet.result.Clip
Tags additional metadata.
add(String, Object) - Method in class com.yahoo.bullet.result.Meta
Add a piece of meta information.
addErrors(List<BulletError>) - Method in class com.yahoo.bullet.result.Meta
Add errors to the Meta.
addIfNonNull(Map<String, Object>, Map<String, String>, Meta.Concept, Supplier<Object>) - Static method in class com.yahoo.bullet.result.Meta
Utility function to add a concept with a configured name to a map representing metadata if both the name and and a value for the name produced by a given Supplier are not null.
AdditiveTumbling - Class in com.yahoo.bullet.windowing
 
AdditiveTumbling(Strategy, Window, BulletConfig) - Constructor for class com.yahoo.bullet.windowing.AdditiveTumbling
Creates an instance of this windowing scheme with the provided Strategy and BulletConfig.
addMetadata(Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
 
addMetadata(Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.KMVSketch
 
addMetadata(Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
addMetadata(Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
Adds the common metadata for this Sketch to Map.
addMetadata(Map<String, String>) - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
 
addQuery(String, Querier) - Method in class com.yahoo.bullet.querying.QueryManager
Adds a configured, initialized query instance Querier to the manager.
Aggregation - Class in com.yahoo.bullet.query.aggregations
 
Aggregation() - Constructor for class com.yahoo.bullet.query.aggregations.Aggregation
 
aggregation - Variable in class com.yahoo.bullet.windowing.Scheme
 
AGGREGATION_COMPOSITE_FIELD_SEPARATOR - Static variable in class com.yahoo.bullet.common.BulletConfig
 
AGGREGATION_DEFAULT_SIZE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
AGGREGATION_MAX_SIZE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
AggregationType - Enum in com.yahoo.bullet.query.aggregations
Represents the type of the Aggregation.
ALPHA_SKETCH_FAMILY - Static variable in class com.yahoo.bullet.common.BulletConfig
 
and(Predicate<Object>...) - Static method in class com.yahoo.bullet.common.Validator
Creates a Predicate that is true if and only if all the provided predicates are true and false otherwise.
APPLICATION_JSON - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPublisher
 
apply(Evaluator, Evaluator, BulletRecord) - Method in interface com.yahoo.bullet.querying.evaluators.BinaryOperations.BinaryOperator
 
apply(List<Evaluator>, BulletRecord) - Method in interface com.yahoo.bullet.querying.evaluators.NAryOperations.NAryOperator
 
apply(Evaluator, BulletRecord) - Method in interface com.yahoo.bullet.querying.evaluators.UnaryOperations.UnaryOperator
 
apply(BulletRecord, BulletRecordProvider) - Method in class com.yahoo.bullet.querying.tablefunctors.LateralViewFunctor
 
apply(BulletRecord, BulletRecordProvider) - Method in class com.yahoo.bullet.querying.tablefunctors.OuterableTableFunctor
 
apply(BulletRecord, BulletRecordProvider) - Method in class com.yahoo.bullet.querying.tablefunctors.TableFunctor
Applies this table functor to the given BulletRecord.
apply(StorageManager<V>, T) - Method in interface com.yahoo.bullet.storage.Criteria
Applies the criteria to the StorageManager.
apply(StorageManager<V>, List<String>) - Method in class com.yahoo.bullet.storage.MultiMemoryCountingCriteria
 
apply(Criteria<T, R>, T) - Method in class com.yahoo.bullet.storage.StorageManager
Applies the given Criteria to this storage.
asDouble(Object) - Static method in class com.yahoo.bullet.common.Validator
This casts a Number Object to an Double.
asFloat(Object) - Static method in class com.yahoo.bullet.common.Validator
This casts a Number Object to an Float.
asInt(Object) - Static method in class com.yahoo.bullet.common.Validator
This casts a Number Object to an Integer.
asJSON() - Method in class com.yahoo.bullet.common.BulletError
 
asJSON() - Method in class com.yahoo.bullet.common.metrics.MetricEvent
 
asJSON() - Method in class com.yahoo.bullet.pubsub.PubSubMessage
 
asJSON() - Method in class com.yahoo.bullet.result.Clip
 
asJSON(Object) - Static method in interface com.yahoo.bullet.result.JSONFormatter
Returns a JSON string representation of object.
asJSON() - Method in interface com.yahoo.bullet.result.JSONFormatter
Convert this object to a JSON string.
asLong(Object) - Static method in class com.yahoo.bullet.common.Validator
This casts a Number Object to an Long.
asMap() - Method in class com.yahoo.bullet.result.Meta
Returns a backing view of the meta information as a Map.
asString(Object) - Static method in class com.yahoo.bullet.common.Validator
This casts an Object to an String.
average(String, long) - Method in class com.yahoo.bullet.common.metrics.MetricCollector
Increment one instance of an average metric with the absolute total.
average(String, long, long) - Method in class com.yahoo.bullet.common.metrics.MetricCollector
Average the given absolute total and frequency total into the metric so far.

B

Basic - Class in com.yahoo.bullet.windowing
This is a scheme that does not do any windowing.
Basic(Strategy, Window, BulletConfig) - Constructor for class com.yahoo.bullet.windowing.Basic
Creates an instance of this windowing scheme with the provided Strategy and BulletConfig.
BINARY_OPERATIONS - Static variable in enum com.yahoo.bullet.query.expressions.Operation
 
BinaryEvaluator - Class in com.yahoo.bullet.querying.evaluators
An evaluator that applies a binary operator to the result of a left evaluator and the result of a right evaluator.
BinaryEvaluator(BinaryExpression) - Constructor for class com.yahoo.bullet.querying.evaluators.BinaryEvaluator
Constructor that creates a binary evaluator from a BinaryExpression.
BinaryExpression - Class in com.yahoo.bullet.query.expressions
An expression that requires two operands and a binary operation.
BinaryExpression(Expression, Expression, Operation) - Constructor for class com.yahoo.bullet.query.expressions.BinaryExpression
Constructor that creates a binary expression.
BinaryOperations - Class in com.yahoo.bullet.querying.evaluators
Binary operations used by BinaryEvaluator.
BinaryOperations() - Constructor for class com.yahoo.bullet.querying.evaluators.BinaryOperations
 
BinaryOperations.BinaryOperator - Interface in com.yahoo.bullet.querying.evaluators
 
BufferingSubscriber - Class in com.yahoo.bullet.pubsub
This implements a Subscriber that provides a base subscriber that buffers a fixed number of messages read.
BufferingSubscriber(int) - Constructor for class com.yahoo.bullet.pubsub.BufferingSubscriber
Creates an instance of this class with the given max for uncommitted messages and rate limiting disabled.
BufferingSubscriber(int, int, long) - Constructor for class com.yahoo.bullet.pubsub.BufferingSubscriber
Creates an instance of this class with the given max for uncommitted messages and the max messages and interval in milliseconds for rate limiting.
BulletConfig - Class in com.yahoo.bullet.common
 
BulletConfig(String) - Constructor for class com.yahoo.bullet.common.BulletConfig
Constructor that loads specific file augmented with defaults and validates itself.
BulletConfig() - Constructor for class com.yahoo.bullet.common.BulletConfig
Constructor that loads just the defaults.
BulletError - Class in com.yahoo.bullet.common
 
BulletError(String, String) - Constructor for class com.yahoo.bullet.common.BulletError
Creates a BulletError with the given error message and resolution.
BulletException - Exception in com.yahoo.bullet.common
 
BulletException(String, String) - Constructor for exception com.yahoo.bullet.common.BulletException
Creates a BulletException from an error and resolution.
BulletPubSubResponder - Class in com.yahoo.bullet.pubsub
Use this as a PubSubResponder if async results should be sent to a PubSub interface.
BulletPubSubResponder(BulletConfig) - Constructor for class com.yahoo.bullet.pubsub.BulletPubSubResponder
Constructor.
ByteArrayPubSubMessageSerDe - Class in com.yahoo.bullet.pubsub
This SerDe is used to convert a provided Query into its serialized bytes in the PubSubMessage.
ByteArrayPubSubMessageSerDe(BulletConfig) - Constructor for class com.yahoo.bullet.pubsub.ByteArrayPubSubMessageSerDe
Constructor.

C

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
Constructor that creates a cast evaluator from a CastExpression.
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.query.tablefunctions - package com.yahoo.bullet.query.tablefunctions
 
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.querying.tablefunctors - package com.yahoo.bullet.querying.tablefunctors
 
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
Since RawStrategy.getData() returns a List of BulletRecord, this method consumes that list.
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
This combines any data fed to it even if it is Basic.isClosed() or Basic.isClosedForPartition().
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.PubSubMessageSerDe
 
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
This consumes any data fed to it even if it is Basic.isClosed() or Basic.isClosedForPartition().
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 - Variable in class com.yahoo.bullet.pubsub.Metadata
 
content - Variable in class com.yahoo.bullet.pubsub.PubSubMessage
 
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
Creates a full copy of another GroupData.
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.
createBulletRecordProvider() - Method in class com.yahoo.bullet.common.BulletConfig
Create a BulletRecordProvider and store it in this BulletConfig instance.
createClient() - Method in class com.yahoo.bullet.common.metrics.HTTPMetricEventPublisher
Creates a CloseableHttpClient client to use for HTTP requests.
created - Variable in class com.yahoo.bullet.pubsub.Metadata
 
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.

D

Data() - Constructor for class com.yahoo.bullet.windowing.SlidingRecord.Data
 
DATA_POSITION - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummary
 
DEFAULT_AGGREGATION_COMPOSITE_FIELD_SEPARATOR - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_AGGREGATION_MAX_SIZE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_AGGREGATION_SIZE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_CONFIGURATION_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_COUNT_DISTINCT_AGGREGATION_SKETCH_ENTRIES - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_COUNT_DISTINCT_AGGREGATION_SKETCH_FAMILY - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_COUNT_DISTINCT_AGGREGATION_SKETCH_RESIZE_FACTOR - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_COUNT_DISTINCT_AGGREGATION_SKETCH_SAMPLING - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_DIMENSIONS - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
 
DEFAULT_DISTRIBUTION_AGGREGATION_GENERATED_POINTS_ROUNDING - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_DISTRIBUTION_AGGREGATION_MAX_POINTS - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_DISTRIBUTION_AGGREGATION_SKETCH_ENTRIES - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_EQUALITY_PARTITIONER_DELIMITER - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_GROUP - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
 
DEFAULT_GROUP - Static variable in class com.yahoo.bullet.common.metrics.MetricEventPublisher
 
DEFAULT_GROUP_AGGREGATION_MAX_SIZE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_GROUP_AGGREGATION_SKETCH_ENTRIES - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_GROUP_AGGREGATION_SKETCH_RESIZE_FACTOR - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_GROUP_AGGREGATION_SKETCH_SAMPLING - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_MAX_CONCURRENCY - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
 
DEFAULT_MAX_UNCOMMITTED_MESSAGES - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
DEFAULT_NAMESPACE - Static variable in class com.yahoo.bullet.storage.StorageConfig
 
DEFAULT_NAMESPACE - Static variable in class com.yahoo.bullet.storage.StorageManager
 
DEFAULT_NAMESPACES - Static variable in class com.yahoo.bullet.storage.StorageConfig
 
DEFAULT_NOMINAL_ENTRIES - Static variable in class com.yahoo.bullet.querying.aggregations.ThetaSketchingStrategy
 
DEFAULT_PARTITION_COUNT - Static variable in class com.yahoo.bullet.storage.StorageConfig
 
DEFAULT_PUBLISHER_CONNECT_TIMEOUT - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
DEFAULT_PUBSUB_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_PUBSUB_CONTEXT_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_PUBSUB_MESSAGE_SERDE_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_QUERY_DURATION - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_QUERY_MAX_DURATION - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_QUERY_MIN_WAIT - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
DEFAULT_QUERY_PARTITIONER_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_QUERY_PARTITIONER_ENABLE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_QUERY_URLS - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
DEFAULT_RATE_LIMIT_ENABLE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_RATE_LIMIT_MAX_EMIT_COUNT - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_RATE_LIMIT_TIME_INTERVAL - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_RAW_AGGREGATION_MAX_SIZE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_RECORD_PROVIDER_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_REST_PUBSUB_CONFIGURATION_NAME - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
DEFAULT_RESULT_METADATA_ENABLE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_RESULT_METADATA_METRICS - Static variable in class com.yahoo.bullet.common.BulletConfig
The mapping from Metadata concepts to the keys with which they should logged in the result metadata.
DEFAULT_RESULT_MIN_WAIT - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
DEFAULT_RESULT_URL - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
DEFAULT_RETRIES - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
 
DEFAULT_RETRY_INTERVAL_MS - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
 
DEFAULT_SUBSCRIBER_CONNECT_TIMEOUT - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
DEFAULT_TOP_K_AGGREGATION_SKETCH_ENTRIES - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_TOP_K_AGGREGATION_SKETCH_ERROR_TYPE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_UPDATE_SKETCH_FAMILY - Static variable in class com.yahoo.bullet.querying.aggregations.ThetaSketchingStrategy
 
DEFAULT_WINDOW_DISABLE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DEFAULT_WINDOW_MIN_EMIT_EVERY - Static variable in class com.yahoo.bullet.common.BulletConfig
 
defaultTo(Object) - Method in class com.yahoo.bullet.common.Validator.Entry
Use a default value for the field represented by this Entry.
define(String) - Method in class com.yahoo.bullet.common.Validator
Creates an instance of the Entry using the name of the field.
DELIMITER - Static variable in class com.yahoo.bullet.common.Config
 
DIMENSIONS - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
 
DISAMBIGUATOR - Static variable in class com.yahoo.bullet.querying.partitioning.SimpleEqualityPartitioner
 
Distribution - Class in com.yahoo.bullet.query.aggregations
 
Distribution(String, DistributionType, Integer) - Constructor for class com.yahoo.bullet.query.aggregations.Distribution
Constructor that creates a DISTRIBUTION aggregation with a specified max size.
DISTRIBUTION_AGGREGATION_GENERATED_POINTS_ROUNDING - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DISTRIBUTION_AGGREGATION_MAX_POINTS - Static variable in class com.yahoo.bullet.common.BulletConfig
 
DISTRIBUTION_AGGREGATION_SKETCH_ENTRIES - Static variable in class com.yahoo.bullet.common.BulletConfig
 
distributionType - Variable in class com.yahoo.bullet.query.aggregations.Distribution
 
DistributionType - Enum in com.yahoo.bullet.query.aggregations
 
DualSketch - Class in com.yahoo.bullet.querying.aggregations.sketches
This class wraps sketches that need a separate sketch for update and union operations.
DualSketch() - Constructor for class com.yahoo.bullet.querying.aggregations.sketches.DualSketch
 

E

END_EXCLUSIVE - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
EQUALITY_PARTITIONER_DELIMITER - Static variable in class com.yahoo.bullet.common.BulletConfig
 
EQUALITY_PARTITIONER_FIELDS - Static variable in class com.yahoo.bullet.common.BulletConfig
 
equals(Object) - Method in class com.yahoo.bullet.common.RandomPool
 
equals(Object) - Method in class com.yahoo.bullet.pubsub.PubSubMessage
 
equals(Object) - Method in class com.yahoo.bullet.query.expressions.BinaryExpression
 
equals(Object) - Method in class com.yahoo.bullet.query.expressions.CastExpression
 
equals(Object) - Method in class com.yahoo.bullet.query.expressions.Expression
 
equals(Object) - Method in class com.yahoo.bullet.query.expressions.FieldExpression
 
equals(Object) - Method in class com.yahoo.bullet.query.expressions.ListExpression
 
equals(Object) - Method in class com.yahoo.bullet.query.expressions.NAryExpression
 
equals(Object) - Method in class com.yahoo.bullet.query.expressions.UnaryExpression
 
equals(Object) - Method in class com.yahoo.bullet.query.expressions.ValueExpression
 
equals(Object) - Method in class com.yahoo.bullet.query.Field
 
equals(Object) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupOperation
 
ERROR_FORMAT - Static variable in class com.yahoo.bullet.querying.RateLimitError
 
ERROR_KEY - Static variable in class com.yahoo.bullet.common.BulletError
 
ERROR_KEY - Static variable in class com.yahoo.bullet.result.Meta
 
evaluate(String, String...) - Method in class com.yahoo.bullet.common.Validator
Create a state with a description for the given fields.
evaluate(BulletRecord) - Method in class com.yahoo.bullet.querying.evaluators.BinaryEvaluator
 
evaluate(BulletRecord) - Method in class com.yahoo.bullet.querying.evaluators.CastEvaluator
 
evaluate(BulletRecord) - Method in class com.yahoo.bullet.querying.evaluators.Evaluator
Evaluates this evaluator on the given BulletRecord.
evaluate(BulletRecord) - Method in class com.yahoo.bullet.querying.evaluators.FieldEvaluator
 
evaluate(BulletRecord) - Method in class com.yahoo.bullet.querying.evaluators.ListEvaluator
 
evaluate(BulletRecord) - Method in class com.yahoo.bullet.querying.evaluators.NAryEvaluator
 
evaluate(BulletRecord) - Method in class com.yahoo.bullet.querying.evaluators.UnaryEvaluator
 
evaluate(BulletRecord) - Method in class com.yahoo.bullet.querying.evaluators.ValueEvaluator
 
Evaluator - Class in com.yahoo.bullet.querying.evaluators
Evaluators are built from expressions.
Evaluator() - Constructor for class com.yahoo.bullet.querying.evaluators.Evaluator
 
execute(Clip) - Method in class com.yahoo.bullet.querying.postaggregations.ComputationStrategy
 
execute(Clip) - Method in class com.yahoo.bullet.querying.postaggregations.CullingStrategy
 
execute(Clip) - Method in class com.yahoo.bullet.querying.postaggregations.HavingStrategy
 
execute(Clip) - Method in class com.yahoo.bullet.querying.postaggregations.OrderByStrategy
 
execute(Clip) - Method in interface com.yahoo.bullet.querying.postaggregations.PostStrategy
Executes the post aggregation.
Explode - Class in com.yahoo.bullet.query.tablefunctions
A table function that requires either a list operand and a key alias or a map operand and both key and value aliases.
Explode(Expression, String, String, boolean) - Constructor for class com.yahoo.bullet.query.tablefunctions.Explode
Constructor that creates an EXPLODE table function.
ExplodeFunctor - Class in com.yahoo.bullet.querying.tablefunctors
A table functor that flattens the result of the given evaluator into a list of Bullet records.
ExplodeFunctor(Explode) - Constructor for class com.yahoo.bullet.querying.tablefunctors.ExplodeFunctor
Constructor that creates an explode table functor from a Explode.
Expression - Class in com.yahoo.bullet.query.expressions
Expressions are used in Bullet queries to filter on, project, and compute potentially complex values based on Bullet record fields.
Expression() - Constructor for class com.yahoo.bullet.query.expressions.Expression
 
extract(BulletRecord) - Method in interface com.yahoo.bullet.querying.evaluators.FieldEvaluator.FieldExtractor
 
extractFieldAsNumber(String, BulletRecord) - Static method in class com.yahoo.bullet.common.Utilities
Extracts the field from the given (@link BulletRecord} as a Number, if possible.
extractMetrics() - Method in class com.yahoo.bullet.common.metrics.MetricCollector
Gets and resets the metrics currently stored in the collector.

F

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
Constructor that creates a field evaluator from a FieldExpression.
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, Expression) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
Constructor that creates a field expression with a variable list index or 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 a map key and a map subkey.
FieldExpression(String, Expression, String) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
Constructor that creates a field expression with a variable list index or map key and a map subkey.
FieldExpression(String, Integer, Expression) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
Constructor that creates a field expression with a list index and a variable map subkey.
FieldExpression(String, String, Expression) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
Constructor that creates a field expression with a map key and a variable map subkey.
FieldExpression(String, Expression, Expression) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
Constructor that creates a field expression with map key and a map subkey.
FieldExpression(FieldExpression, Integer) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
Constructor that creates a subfield expression from a field expression and a list index.
FieldExpression(FieldExpression, String) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
Constructor that creates a subfield expression from a field expression and a map key.
FieldExpression(FieldExpression, Expression) - Constructor for class com.yahoo.bullet.query.expressions.FieldExpression
Constructor that creates a subfield expression from a field expression and a variable key.
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
Constructor that requires an Aggregation and a BulletConfig configuration.
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(BulletConfig) - Static method in class com.yahoo.bullet.pubsub.PubSubMessageSerDe
Create a PubSubMessageSerDe 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
Convenience method to deserialize an object into a type from raw serialized data produced by the method SerializerDeserializer.toBytes(Serializable).
fromJSON(String) - Static method in class com.yahoo.bullet.pubsub.PubSubMessage
Converts a json representation back to an instance.
fromJSON(String, Gson) - Static method in class com.yahoo.bullet.pubsub.PubSubMessage
Converts a JSON representation back to an instance using a specific Gson converter.
fromJSON(String, Class<T>) - Static method in interface com.yahoo.bullet.result.JSONFormatter
Returns a deserialized object from JSON using JSONFormatter.GSON.
fromMemory(Memory) - Static method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummary
Needed to deserialize an instance of this GroupDataSummary from a Memory.
fromMemory(Memory) - Static method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummaryFactory
Needed to deserialize an instance of this GroupDataSummaryFactory from a Memory.
fromMessage(PubSubMessage) - Method in class com.yahoo.bullet.pubsub.IdentityPubSubMessageSerDe
 
fromMessage(PubSubMessage) - Method in class com.yahoo.bullet.pubsub.PubSubMessageSerDe
Takes a converted PubSubMessage and returns the original format of the message.

G

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
Retrieves data from the given StorageManager as a CompletableFuture resolving to a key-value mapping of the raw data stored in the storage.
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, or create and store one first if there is none.
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
Returns the Serializable content in this metadata.
getContent() - Method in class com.yahoo.bullet.pubsub.PubSubMessage
Returns the Serializable content stored in the message.
getContentAsByteArray() - Method in class com.yahoo.bullet.pubsub.PubSubMessage
Returns the content stored in the message as a byte[].
getContentAsQuery() - Method in class com.yahoo.bullet.pubsub.PubSubMessage
Returns the content stored in the message as a Query.
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
Returns the serialized List of BulletRecord seen before the last call to RawStrategy.reset().
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
Get the group to use for the MetricEvent.
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
Get the Meta so far.
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
Return any Meta for this windowing scheme and the Strategy.
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
Get a Publisher instance wired to write to all allocated partitions in the appropriate queue (See PubSub.context).
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
Returns a RateLimitError if the rate limit had exceeded the rate from a prior call to Querier.isExceedingRateLimit().
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
Gets the aggregated records so far since the last call to RawStrategy.reset().
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
Gets the aggregated records so far since the last call to RawStrategy.reset().
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
Construct a Schema if configured.
getScheme(Strategy, BulletConfig) - Method in class com.yahoo.bullet.query.Window
Returns the appropriate window scheme based on the Window Window.Classification.
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
Get a Subscriber instance wired to read from all allocated partitions in the appropriate queue (See PubSub.context).
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
 
getTableFunctor() - Method in class com.yahoo.bullet.query.tablefunctions.Explode
 
getTableFunctor() - Method in class com.yahoo.bullet.query.tablefunctions.LateralView
 
getTableFunctor() - Method in class com.yahoo.bullet.query.tablefunctions.TableFunction
Gets a new instance of a table functor for this table function.
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
Constructor that requires an Aggregation.
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
Constructor that initializes the GroupData with a Set of GroupOperation.
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
 

H

hasContent() - Method in class com.yahoo.bullet.pubsub.Metadata
Check if Metadata has content.
hasContent() - Method in class com.yahoo.bullet.pubsub.PubSubMessage
Check if message has content.
hash(String, int) - Static method in class com.yahoo.bullet.storage.StorageManager
A default hash function for a given String that places the String into 0 to numberOfPartitions exclusive.
hashCode() - Method in class com.yahoo.bullet.common.RandomPool
 
hashCode() - Method in class com.yahoo.bullet.pubsub.PubSubMessage
 
hashCode() - Method in class com.yahoo.bullet.query.expressions.BinaryExpression
 
hashCode() - Method in class com.yahoo.bullet.query.expressions.CastExpression
 
hashCode() - Method in class com.yahoo.bullet.query.expressions.Expression
 
hashCode() - Method in class com.yahoo.bullet.query.expressions.FieldExpression
 
hashCode() - Method in class com.yahoo.bullet.query.expressions.ListExpression
 
hashCode() - Method in class com.yahoo.bullet.query.expressions.NAryExpression
 
hashCode() - Method in class com.yahoo.bullet.query.expressions.UnaryExpression
 
hashCode() - Method in class com.yahoo.bullet.query.expressions.ValueExpression
 
hashCode() - Method in class com.yahoo.bullet.query.Field
 
hashCode() - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupOperation
 
hasMaximumListSize(int) - Static method in class com.yahoo.bullet.common.Validator
Creates a Predicate that checks to see if the given object is a List and has at most n items in it.
hasMetadata() - Method in class com.yahoo.bullet.pubsub.PubSubMessage
Check if message has Metadata.
hasMinimumListSize(int) - Static method in class com.yahoo.bullet.common.Validator
Creates a Predicate that checks to see if the given object is a List and has at least n items in it.
hasNewData() - Method in class com.yahoo.bullet.querying.Querier
Returns whether there is any new data to emit at all since the last Querier.reset().
hasQuery(String) - Method in class com.yahoo.bullet.querying.QueryManager
Checks to see if the given ID is stored in the manager.
hasSignal() - Method in class com.yahoo.bullet.pubsub.Metadata
Check if Metadata has signal.
hasSignal(Metadata.Signal) - Method in class com.yahoo.bullet.pubsub.Metadata
Check if Metadata has the given signal.
hasSignal(Metadata.Signal) - Method in class com.yahoo.bullet.pubsub.PubSubMessage
Check if message has a given Metadata.Signal.
hasSignal() - Method in class com.yahoo.bullet.pubsub.PubSubMessage
Check if the message has a Metadata.Signal.
haveMessages() - Method in class com.yahoo.bullet.pubsub.BufferingSubscriber
Returns true if we already have messages to emit or if BufferingSubscriber.getMessages() returns non-null and non-empty List of messages.
Having - Class in com.yahoo.bullet.query.postaggregations
 
Having(Expression) - Constructor for class com.yahoo.bullet.query.postaggregations.Having
Constructor that creates a Having post-aggregation.
HAVING_REQUIRES_EXPRESSION - Static variable in class com.yahoo.bullet.query.postaggregations.Having
 
HavingStrategy - Class in com.yahoo.bullet.querying.postaggregations
 
HavingStrategy(Having) - Constructor for class com.yahoo.bullet.querying.postaggregations.HavingStrategy
Constructor that creates a Having post-strategy.
HTTPMetricEventPublisher - Class in com.yahoo.bullet.common.metrics
This class publishes a MetricEvent to a provided URL.
HTTPMetricEventPublisher(BulletConfig) - Constructor for class com.yahoo.bullet.common.metrics.HTTPMetricEventPublisher
Constructor taking a BulletConfig.
HTTPMetricPublisherConfig - Class in com.yahoo.bullet.common.metrics
 
HTTPMetricPublisherConfig(BulletConfig) - Constructor for class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
Create an instance of this configuration.

I

id - Variable in class com.yahoo.bullet.pubsub.PubSubMessage
 
IdentityPubSubMessageSerDe - Class in com.yahoo.bullet.pubsub
 
IdentityPubSubMessageSerDe(BulletConfig) - Constructor for class com.yahoo.bullet.pubsub.IdentityPubSubMessageSerDe
Constructor.
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
Returns a BiPredicate that checks to see if the first Predicate implies the second.
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
 

J

JSONFormatter - Interface in com.yahoo.bullet.result
 

K

KMVSketch - Class in com.yahoo.bullet.querying.aggregations.sketches
This class wraps some common metadata information for KMV Sketches - Theta and Tuple.
KMVSketch() - Constructor for class com.yahoo.bullet.querying.aggregations.sketches.KMVSketch
 
KNOWN_CONCEPTS - Static variable in class com.yahoo.bullet.result.Meta
 

L

LateralView - Class in com.yahoo.bullet.query.tablefunctions
A table function that requires another table function.
LateralView(TableFunction) - Constructor for class com.yahoo.bullet.query.tablefunctions.LateralView
Constructor that creates a LATERAL VIEW table function.
LateralViewFunctor - Class in com.yahoo.bullet.querying.tablefunctors
A table functor that joins the generated records of the nested table functor with the original input record.
LateralViewFunctor(LateralView) - Constructor for class com.yahoo.bullet.querying.tablefunctors.LateralViewFunctor
Constructor that creates a lateral view table functor from a LateralView.
LinearDistribution - Class in com.yahoo.bullet.query.aggregations
 
LinearDistribution(String, DistributionType, Integer, int) - Constructor for class com.yahoo.bullet.query.aggregations.LinearDistribution
Constructor that creates a DISTRIBUTION aggregation with a specified max size.
ListEvaluator - Class in com.yahoo.bullet.querying.evaluators
An evaluator that returns a list of the results of a list of evaluators.
ListEvaluator(ListExpression) - Constructor for class com.yahoo.bullet.querying.evaluators.ListEvaluator
Constructor that creates a list evaluator from a ListExpression.
ListExpression - Class in com.yahoo.bullet.query.expressions
An expression that holds a list of expressions.
ListExpression(List<Expression>) - Constructor for class com.yahoo.bullet.query.expressions.ListExpression
Constructor that creates a list expression.
loadConfiguredClass(String) - Method in class com.yahoo.bullet.common.BulletConfig
This method loads a given class name (stored in this config) with the class name key and creates an instance of it by using a constructor that has a single argument for a BulletConfig.
loadConfiguredClass(String, BulletConfig) - Static method in class com.yahoo.bullet.common.Utilities
This method loads a given class name with the class name key and creates an instance of it by using a constructor that has a single argument for a BulletConfig.

M

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
Creates a Map of GroupOperation to their numeric metric values from a Set of GroupOperation.
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
This method merges two GroupDataSummary into each other.
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
 
messageCount - Variable in class com.yahoo.bullet.pubsub.BufferingSubscriber
The number of messages received during the current rate limit interval.
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
Allows you to create an instance with a Metadata.Signal and a Serializable object.
metadata - Variable in class com.yahoo.bullet.pubsub.PubSubMessage
 
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
This class concretizes MetricPublisher with MetricEvent.
MetricEventPublisher(BulletConfig) - Constructor for class com.yahoo.bullet.common.metrics.MetricEventPublisher
Constructor taking a BulletConfig.
MetricPublisher<T> - Class in com.yahoo.bullet.common.metrics
 
MetricPublisher(BulletConfig) - Constructor for class com.yahoo.bullet.common.metrics.MetricPublisher
Constructor taking a BulletConfig.
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
An example of a simple criteria that counts the number of stored entries for the MultiMemoryCountingCriteria storage manager.
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.

N

N_ARY_OPERATIONS - Static variable in enum com.yahoo.bullet.query.expressions.Operation
 
NAME - Static variable in class com.yahoo.bullet.windowing.Basic
 
name() - Method in class com.yahoo.bullet.windowing.Basic
Gets the name of this windowing scheme.
NAME - Static variable in class com.yahoo.bullet.windowing.SlidingRecord
 
name() - Method in class com.yahoo.bullet.windowing.SlidingRecord
 
NAME - Static variable in class com.yahoo.bullet.windowing.Tumbling
 
name() - Method in class com.yahoo.bullet.windowing.Tumbling
 
NAMESPACES - Static variable in class com.yahoo.bullet.storage.StorageConfig
 
NARROW_FILTER - Static variable in class com.yahoo.bullet.querying.RateLimitError
 
NAryEvaluator - Class in com.yahoo.bullet.querying.evaluators
An evaluator that applies an n-ary operator to the results of a list of evaluators.
NAryEvaluator(NAryExpression) - Constructor for class com.yahoo.bullet.querying.evaluators.NAryEvaluator
Constructor that creates an n-ary evaluator from a NAryExpression.
NAryExpression - Class in com.yahoo.bullet.query.expressions
An expression that requires a list of operands and an n-ary operation.
NAryExpression(List<Expression>, Operation) - Constructor for class com.yahoo.bullet.query.expressions.NAryExpression
Constructor that creates an n-ary expression.
NAryOperations - Class in com.yahoo.bullet.querying.evaluators
 
NAryOperations() - Constructor for class com.yahoo.bullet.querying.evaluators.NAryOperations
 
NAryOperations.NAryOperator - Interface in com.yahoo.bullet.querying.evaluators
 
NEGATIVE_INFINITY - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
NEGATIVE_INFINITY_START - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
newSummary() - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummaryFactory
 
nextCloseTime - Variable in class com.yahoo.bullet.windowing.Tumbling
 
NO_CONTENT_204 - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSub
 
NO_FALSE_NEGATIVES - Static variable in class com.yahoo.bullet.querying.aggregations.FrequentItemsSketchingStrategy
 
NO_FALSE_POSITIVES - Static variable in class com.yahoo.bullet.querying.aggregations.FrequentItemsSketchingStrategy
 
NO_RECORD_ALL - Static variable in class com.yahoo.bullet.query.Window
 
not(Predicate<Object>) - Static method in class com.yahoo.bullet.common.Validator
Creates a Predicate that is true if the given predicate is false and false if the given predicate is true.
NullStorageManager<V extends Serializable> - Class in com.yahoo.bullet.storage
A default implementation that does nothing if you do not want to use a StorageManager.
NullStorageManager(BulletConfig) - Constructor for class com.yahoo.bullet.storage.NullStorageManager
Constructor.
numberOfPartitions(String) - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
 
numberOfPartitions() - Method in class com.yahoo.bullet.storage.StorageManager
Returns the number of partitions stored in this storage manager for the default namespace.

O

of(BulletRecord) - Static method in class com.yahoo.bullet.result.Clip
Construct a Clip with the given BulletRecord.
of(List<BulletRecord>) - Static method in class com.yahoo.bullet.result.Clip
Construct a Clip with the given List of BulletRecord.
of(Meta) - Static method in class com.yahoo.bullet.result.Clip
Construct a Clip with the given metadata.
of(BulletError...) - Static method in class com.yahoo.bullet.result.Meta
Static construction of Meta with some errors.
of(List<BulletError>) - Static method in class com.yahoo.bullet.result.Meta
Static construction of Meta with some errors.
OK_200 - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSub
 
Operation - Enum in com.yahoo.bullet.query.expressions
The operations in binary, unary, and n-ary expressions.
OPERATORS - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupOperation
 
or(Predicate<Object>...) - Static method in class com.yahoo.bullet.common.Validator
Creates a Predicate that is true if any of the provided predicates are true and false otherwise.
ORDER_BY_REQUIRES_FIELDS - Static variable in class com.yahoo.bullet.query.postaggregations.OrderBy
 
OrderBy - Class in com.yahoo.bullet.query.postaggregations
 
OrderBy(List<OrderBy.SortItem>) - Constructor for class com.yahoo.bullet.query.postaggregations.OrderBy
Constructor that creates an OrderBy post-aggregation.
OrderBy.Direction - Enum in com.yahoo.bullet.query.postaggregations
 
OrderBy.SortItem - Class in com.yahoo.bullet.query.postaggregations
 
OrderByStrategy - Class in com.yahoo.bullet.querying.postaggregations
 
OrderByStrategy(OrderBy) - Constructor for class com.yahoo.bullet.querying.postaggregations.OrderByStrategy
Constructor that creates an OrderBy post-strategy.
orElseUse(Object, Object) - Method in class com.yahoo.bullet.common.Validator.Relationship
Provide custom defaults for this Relationship if you do not want to use the defaults provided in their Entries.
orFail() - Method in class com.yahoo.bullet.common.Validator.Entry
Fail if this entry fails to hold.
orFail() - Method in class com.yahoo.bullet.common.Validator.Relationship
Fail if this relationship fails to hold.
orFail() - Method in class com.yahoo.bullet.common.Validator.State
Fail if this state check fails.
outer - Variable in class com.yahoo.bullet.query.tablefunctions.OuterableTableFunction
 
outer - Variable in class com.yahoo.bullet.querying.tablefunctors.OuterableTableFunctor
 
outerableApply(BulletRecord, BulletRecordProvider) - Method in class com.yahoo.bullet.querying.tablefunctors.ExplodeFunctor
 
outerableApply(BulletRecord, BulletRecordProvider) - Method in class com.yahoo.bullet.querying.tablefunctors.OuterableTableFunctor
Applies this table functor to the given BulletRecord.
OuterableTableFunction - Class in com.yahoo.bullet.query.tablefunctions
The OuterableTableFunction class adds the outer option.
OuterableTableFunction(boolean, TableFunctionType) - Constructor for class com.yahoo.bullet.query.tablefunctions.OuterableTableFunction
 
OuterableTableFunctor - Class in com.yahoo.bullet.querying.tablefunctors
The OuterableTableFunctor class adds an outer option.
OuterableTableFunctor() - Constructor for class com.yahoo.bullet.querying.tablefunctors.OuterableTableFunctor
 

P

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
Represents the type of the PostAggregation.
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
Instantiate a PubSub using parameters from BulletConfig.
PubSub.Context - Enum in com.yahoo.bullet.pubsub
The context determines how the Publisher and Subscriber returned by PubSub behave.
PUBSUB_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
PUBSUB_CONTEXT_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
PUBSUB_MESSAGE_SERDE_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
PubSubException - Exception in com.yahoo.bullet.pubsub
Exception to be thrown if there is an error in PubSub, Publisher or Subscriber.
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
Constructor for a message having only a Metadata.Signal.
PubSubMessage(String, Serializable) - Constructor for class com.yahoo.bullet.pubsub.PubSubMessage
Constructor for a message having only content.
PubSubMessage(String, Serializable, Metadata.Signal) - Constructor for class com.yahoo.bullet.pubsub.PubSubMessage
Constructor for a message having content and a Metadata.Signal.
PubSubMessage(String, Serializable, Metadata) - Constructor for class com.yahoo.bullet.pubsub.PubSubMessage
Constructor for a message having content and Metadata.
PubSubMessageSerDe - Class in com.yahoo.bullet.pubsub
This allows you to hook into the PubSubMessage serialization and deserialization - for instance, if you want to customize what is done to the message before it is sent to or read in the backend.
PubSubMessageSerDe(BulletConfig) - Constructor for class com.yahoo.bullet.pubsub.PubSubMessageSerDe
Constructor.
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.

Q

QUANTILE_FIELD - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
QUANTILE_MAX - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
QUANTILE_MIN - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
QUANTILE_STEP - Static variable in class com.yahoo.bullet.querying.QueryManager
 
QuantileSketch - Class in com.yahoo.bullet.querying.aggregations.sketches
Wraps operations for working with a DoublesSketch - Quantile Sketch.
QuantileSketch(int, DistributionType, double[], BulletRecordProvider) - Constructor for class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
Creates a quantile sketch with the given number of entries getting results with the given points.
QuantileSketch(int, int, DistributionType, int, BulletRecordProvider) - Constructor for class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
Creates a quantile sketch with the given number of entries generating results with the number of points (evenly-spaced).
QuantileSketchingStrategy - Class in com.yahoo.bullet.querying.aggregations
This Strategy uses QuantileSketch to find distributions of a numeric field.
QuantileSketchingStrategy(Distribution, BulletConfig) - Constructor for class com.yahoo.bullet.querying.aggregations.QuantileSketchingStrategy
Constructor that requires an Aggregation and a BulletConfig configuration.
Querier - Class in com.yahoo.bullet.querying
This manages a RunningQuery that is currently being executed.
Querier(RunningQuery, BulletConfig) - Constructor for class com.yahoo.bullet.querying.Querier
Constructor that takes a RunningQuery instance and a configuration to use.
Querier(Querier.Mode, RunningQuery, BulletConfig) - Constructor for class com.yahoo.bullet.querying.Querier
Constructor that takes a Querier.Mode, RunningQuery instance and a configuration to use.
Querier.Mode - Enum in com.yahoo.bullet.querying
This is used to determine if this operates in partitioned mode or not.
Query - Class in com.yahoo.bullet.query
This class is the top level Bullet query specification.
Query(TableFunction, Projection, Expression, Aggregation, List<PostAggregation>, Window, Long) - Constructor for class com.yahoo.bullet.query.Query
Constructor that creates the Bullet query.
Query(Projection, Expression, Aggregation, List<PostAggregation>, Window, Long) - Constructor for class com.yahoo.bullet.query.Query
Constructor that creates the Bullet query.
QUERY_DEFAULT_DURATION - Static variable in class com.yahoo.bullet.common.BulletConfig
 
QUERY_MAX_DURATION - Static variable in class com.yahoo.bullet.common.BulletConfig
 
QUERY_PARTITIONER_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
QUERY_PARTITIONER_ENABLE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
QUERY_SUBSCRIBER_MIN_WAIT - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
QUERY_URLS - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
QueryCategorizer - Class in com.yahoo.bullet.querying
This categorizes running queries into whether they are done, closed, have exceeded the rate limits or have new data.
QueryCategorizer() - Constructor for class com.yahoo.bullet.querying.QueryCategorizer
 
QueryManager - Class in com.yahoo.bullet.querying
This class wraps the concept of the Partitioner and allows you to control using your configured (or not) partitioner, what queries are seen for each BulletRecord.
QueryManager(BulletConfig) - Constructor for class com.yahoo.bullet.querying.QueryManager
The constructor that takes a non-null BulletConfig instance that contains partitioning settings.
QueryManager.PartitionStat - Enum in com.yahoo.bullet.querying
 
QUICKSELECT_SKETCH_FAMILY - Static variable in class com.yahoo.bullet.common.BulletConfig
 

R

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
 
rateLimitEnable - Variable in class com.yahoo.bullet.pubsub.BufferingSubscriber
Whether or not rate limiting is enabled.
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
Create an instance of this that uses a default time window of RateLimiter.SECOND ms.
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.
rateLimitIntervalMS - Variable in class com.yahoo.bullet.pubsub.BufferingSubscriber
The duration of a rate limit interval.
rateLimitMaxMessages - Variable in class com.yahoo.bullet.pubsub.BufferingSubscriber
The maximum number of PubSubMessages we can receive in a rate limit interval.
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
Constructor that takes in an Aggregation and a BulletConfig.
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
Throws a NullPointerException if the List is null or contains any null elements.
requireNonNull(Set<T>) - Static method in class com.yahoo.bullet.common.Utilities
Throws a NullPointerException if the Set is null or contains any null elements.
requireNonNull(Map<K, V>) - Static method in class com.yahoo.bullet.common.Utilities
Throws a NullPointerException if the Map is null or contains any null keys or null values.
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
Respond to a PubSubMessage.
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
Create a RESTPubSub from a BulletConfig.
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
Retrieves data from the given StorageManager as a CompletableFuture resolving to the specific return type of this 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.

S

Scheme - Class in com.yahoo.bullet.windowing
This represents the common parent for all windowing schemes.
Scheme(Strategy, Window, BulletConfig) - Constructor for class com.yahoo.bullet.windowing.Scheme
Creates an instance of this windowing scheme with the provided Strategy, Window and BulletConfig.
SECOND - Static variable in class com.yahoo.bullet.querying.RateLimiter
 
send(String, Serializable) - Method in interface com.yahoo.bullet.pubsub.Publisher
Send a message with an ID and content.
send(PubSubMessage) - Method in interface com.yahoo.bullet.pubsub.Publisher
Sends a PubSubMessage.
send(PubSubMessage) - Method in class com.yahoo.bullet.pubsub.rest.RESTQueryPublisher
 
send(PubSubMessage) - Method in class com.yahoo.bullet.pubsub.rest.RESTResultPublisher
 
sendToURL(String, PubSubMessage) - Method in class com.yahoo.bullet.pubsub.rest.RESTPublisher
Send the PubSubMessage to the given url.
SEPARATOR - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
separator - Variable in class com.yahoo.bullet.querying.aggregations.SketchingStrategy
 
serialize() - Method in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
 
serialize() - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
serialize() - Method in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
Serializes the sketch.
serialize() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
 
serialize() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
 
SERIALIZED - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummaryFactory
 
SERIALIZED_SIZE - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummaryFactory
 
SerializerDeserializer - Class in com.yahoo.bullet.common
 
SerializerDeserializer() - Constructor for class com.yahoo.bullet.common.SerializerDeserializer
 
serialVersionUID - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupData
 
set(String, Object) - Method in class com.yahoo.bullet.common.Config
Adds a key/value pair to the configuration.
setContent(Serializable) - Method in class com.yahoo.bullet.pubsub.Metadata
Set a Serializable content for this metadata.
setContent(Serializable) - Method in class com.yahoo.bullet.pubsub.PubSubMessage
Set a Serializable content for this message.
shouldBuffer() - Method in class com.yahoo.bullet.querying.Querier
Returns if this query should buffer before emitting the final results.
signal - Variable in class com.yahoo.bullet.pubsub.Metadata
 
SimpleEqualityPartitioner - Class in com.yahoo.bullet.querying.partitioning
This partitioner uses a list of fields to partition.
SimpleEqualityPartitioner(BulletConfig) - Constructor for class com.yahoo.bullet.querying.partitioning.SimpleEqualityPartitioner
Constructor that takes a BulletConfig instance with definitions for the various settings this needs.
size - Variable in class com.yahoo.bullet.query.aggregations.Aggregation
 
size() - Method in class com.yahoo.bullet.querying.QueryManager
Returns the size of the queries in the manager.
SIZE_POSITION - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummary
 
Sketch - Class in com.yahoo.bullet.querying.aggregations.sketches
This class encapsulates a type of Sketch.
Sketch() - Constructor for class com.yahoo.bullet.querying.aggregations.sketches.Sketch
 
sketch - Variable in class com.yahoo.bullet.querying.aggregations.SketchingStrategy
 
SketchingStrategy<S extends Sketch> - Class in com.yahoo.bullet.querying.aggregations
The parent class for all Strategy that use Sketches.
SketchingStrategy(Aggregation, BulletConfig) - Constructor for class com.yahoo.bullet.querying.aggregations.SketchingStrategy
The constructor for creating a Sketch based strategy.
SlidingRecord - Class in com.yahoo.bullet.windowing
 
SlidingRecord(Strategy, Window, BulletConfig) - Constructor for class com.yahoo.bullet.windowing.SlidingRecord
Creates an instance of this windowing scheme with the provided Strategy and BulletConfig.
SlidingRecord.Data - Class in com.yahoo.bullet.windowing
 
SortItem(Expression, OrderBy.Direction) - Constructor for class com.yahoo.bullet.query.postaggregations.OrderBy.SortItem
Constructor that creates an OrderBy item.
start() - Method in class com.yahoo.bullet.windowing.Basic
 
start() - Method in class com.yahoo.bullet.windowing.Scheme
Readies the window for querying.
start() - Method in class com.yahoo.bullet.windowing.Tumbling
 
START_EXCLUSIVE - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
START_INCLUSIVE - Static variable in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
startTime - Variable in class com.yahoo.bullet.pubsub.BufferingSubscriber
The start time of the current rate limit interval.
STORAGE_CLASS_NAME - Static variable in class com.yahoo.bullet.common.BulletConfig
 
StorageConfig - Class in com.yahoo.bullet.storage
 
StorageConfig(String) - Constructor for class com.yahoo.bullet.storage.StorageConfig
Constructor that loads specific file augmented with defaults.
StorageConfig(Config) - Constructor for class com.yahoo.bullet.storage.StorageConfig
Constructor that loads the defaults and augments it with defaults.
StorageManager<V extends Serializable> - Class in com.yahoo.bullet.storage
 
StorageManager(BulletConfig) - Constructor for class com.yahoo.bullet.storage.StorageManager
Constructor that takes a BulletConfig.
Strategy - Interface in com.yahoo.bullet.querying.aggregations
 
Subscriber - Interface in com.yahoo.bullet.pubsub
 
SUBSCRIBER_CONNECT_TIMEOUT - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSubConfig
 
SUM - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupOperation
 
SUMMARY_OPERATIONS - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummaryFactory
 
summaryFromMemory(Memory) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummaryFactory
 
SUPPORTED_GROUP_OPERATIONS - Static variable in class com.yahoo.bullet.querying.aggregations.grouping.GroupOperation
 
switchContext(PubSub.Context, BulletConfig) - Method in class com.yahoo.bullet.pubsub.PubSub
Use this method to switch the PubSub.Context to another one.

T

TableFunction - Class in com.yahoo.bullet.query.tablefunctions
Table functions are used in Bullet queries to generate virtual records from incoming Bullet records.
TableFunction() - Constructor for class com.yahoo.bullet.query.tablefunctions.TableFunction
 
TableFunctionType - Enum in com.yahoo.bullet.query.tablefunctions
Represents the type of the TableFunction.
TableFunctor - Class in com.yahoo.bullet.querying.tablefunctors
Table functors are built from table functions.
TableFunctor() - Constructor for class com.yahoo.bullet.querying.tablefunctors.TableFunctor
 
ThetaSketch - Class in com.yahoo.bullet.querying.aggregations.sketches
 
ThetaSketch(ResizeFactor, Family, float, int, BulletRecordProvider) - Constructor for class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
Constructor for creating a theta sketch.
ThetaSketchingStrategy - Class in com.yahoo.bullet.querying.aggregations
 
ThetaSketchingStrategy(CountDistinct, BulletConfig) - Constructor for class com.yahoo.bullet.querying.aggregations.ThetaSketchingStrategy
Constructor that requires an Aggregation and a BulletConfig configuration.
TIME_WINDOW - Static variable in class com.yahoo.bullet.querying.RateLimitError
 
toByteArray() - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummary
 
toByteArray() - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummaryFactory
 
toBytes(U) - Static method in class com.yahoo.bullet.common.SerializerDeserializer
Convenience method to serializes the given Serializable object to a raw byte[].
toMessage(String, Query, String) - Method in class com.yahoo.bullet.pubsub.ByteArrayPubSubMessageSerDe
 
toMessage(PubSubMessage) - Method in class com.yahoo.bullet.pubsub.IdentityPubSubMessageSerDe
 
toMessage(String, Query, String) - Method in class com.yahoo.bullet.pubsub.PubSubMessageSerDe
A helper to submit a query by converting it to a standard PubSubMessage and running it through PubSubMessageSerDe.toMessage(PubSubMessage).
toMessage(PubSubMessage) - Method in class com.yahoo.bullet.pubsub.PubSubMessageSerDe
Takes a PubSubMessage and returns the new format of the message.
TOP_K_AGGREGATION_SKETCH_ENTRIES - Static variable in class com.yahoo.bullet.common.BulletConfig
 
TOP_K_AGGREGATION_SKETCH_ERROR_TYPE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
TopK - Class in com.yahoo.bullet.query.aggregations
 
TopK(Map<String, String>, Integer, Long, String) - Constructor for class com.yahoo.bullet.query.aggregations.TopK
Constructor that creates a TOP_K aggregation with a specified max size.
toString() - Method in class com.yahoo.bullet.common.BulletError
 
toString() - Method in class com.yahoo.bullet.common.Config
 
toString() - Method in class com.yahoo.bullet.common.RandomPool
 
toString() - Method in class com.yahoo.bullet.pubsub.PubSubMessage
 
toString() - Method in class com.yahoo.bullet.query.aggregations.Aggregation
 
toString() - Method in class com.yahoo.bullet.query.aggregations.CountDistinct
 
toString() - Method in class com.yahoo.bullet.query.aggregations.GroupAll
 
toString() - Method in class com.yahoo.bullet.query.aggregations.GroupBy
 
toString() - Method in class com.yahoo.bullet.query.aggregations.LinearDistribution
 
toString() - Method in class com.yahoo.bullet.query.aggregations.ManualDistribution
 
toString() - Method in class com.yahoo.bullet.query.aggregations.RegionDistribution
 
toString() - Method in class com.yahoo.bullet.query.aggregations.TopK
 
toString() - Method in class com.yahoo.bullet.query.expressions.BinaryExpression
 
toString() - Method in class com.yahoo.bullet.query.expressions.CastExpression
 
toString() - Method in class com.yahoo.bullet.query.expressions.Expression
 
toString() - Method in class com.yahoo.bullet.query.expressions.FieldExpression
 
toString() - Method in class com.yahoo.bullet.query.expressions.ListExpression
 
toString() - Method in class com.yahoo.bullet.query.expressions.NAryExpression
 
toString() - Method in enum com.yahoo.bullet.query.expressions.Operation
 
toString() - Method in class com.yahoo.bullet.query.expressions.UnaryExpression
 
toString() - Method in class com.yahoo.bullet.query.expressions.ValueExpression
 
toString() - Method in class com.yahoo.bullet.query.Field
 
toString() - Method in class com.yahoo.bullet.query.postaggregations.Computation
 
toString() - Method in class com.yahoo.bullet.query.postaggregations.Culling
 
toString() - Method in class com.yahoo.bullet.query.postaggregations.Having
 
toString() - Method in class com.yahoo.bullet.query.postaggregations.OrderBy.SortItem
 
toString() - Method in class com.yahoo.bullet.query.postaggregations.OrderBy
 
toString() - Method in class com.yahoo.bullet.query.Projection
 
toString() - Method in class com.yahoo.bullet.query.Query
 
toString() - Method in class com.yahoo.bullet.query.tablefunctions.Explode
 
toString() - Method in class com.yahoo.bullet.query.tablefunctions.LateralView
 
toString() - Method in class com.yahoo.bullet.query.Window
 
toString() - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupOperation
 
toString() - Method in class com.yahoo.bullet.querying.Querier
 
toString() - Method in class com.yahoo.bullet.querying.RunningQuery
 
TRY_AGAIN_LATER - Static variable in class com.yahoo.bullet.querying.Querier
 
Tumbling - Class in com.yahoo.bullet.windowing
 
Tumbling(Strategy, Window, BulletConfig) - Constructor for class com.yahoo.bullet.windowing.Tumbling
Creates an instance of this windowing scheme with the provided Strategy and BulletConfig.
TupleSketch - Class in com.yahoo.bullet.querying.aggregations.sketches
 
TupleSketch(ResizeFactor, float, int, int, BulletRecordProvider) - Constructor for class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
Initialize a tuple sketch for summarizing group data.
TupleSketchingStrategy - Class in com.yahoo.bullet.querying.aggregations
This Strategy implements a Tuple Sketch based approach to doing a group by.
TupleSketchingStrategy(GroupBy, BulletConfig) - Constructor for class com.yahoo.bullet.querying.aggregations.TupleSketchingStrategy
Constructor that requires an Aggregation and a BulletConfig configuration.
type - Variable in class com.yahoo.bullet.query.aggregations.Aggregation
 
type - Variable in class com.yahoo.bullet.query.expressions.Expression
 
type - Variable in class com.yahoo.bullet.query.postaggregations.PostAggregation
 
type - Variable in class com.yahoo.bullet.query.tablefunctions.TableFunction
 

U

UNARY_OPERATIONS - Static variable in enum com.yahoo.bullet.query.expressions.Operation
 
UnaryEvaluator - Class in com.yahoo.bullet.querying.evaluators
An evaluator that applies a unary operator to the result of an evaluator.
UnaryEvaluator(UnaryExpression) - Constructor for class com.yahoo.bullet.querying.evaluators.UnaryEvaluator
Constructor that creates a unary evaluator from a UnaryExpression.
UnaryExpression - Class in com.yahoo.bullet.query.expressions
An expression that requires an operand and a unary operation.
UnaryExpression(Expression, Operation) - Constructor for class com.yahoo.bullet.query.expressions.UnaryExpression
Constructor that creates a unary expression.
UnaryOperations - Class in com.yahoo.bullet.querying.evaluators
Unary operations used by UnaryEvaluator.
UnaryOperations() - Constructor for class com.yahoo.bullet.querying.evaluators.UnaryOperations
 
UnaryOperations.UnaryOperator - Interface in com.yahoo.bullet.querying.evaluators
 
uncommittedMessages - Variable in class com.yahoo.bullet.pubsub.BufferingSubscriber
A Map of messages that have not been committed so far.
union(GroupDataSummary, GroupDataSummary) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummarySetOperations
 
union() - Method in class com.yahoo.bullet.querying.aggregations.sketches.DualSketch
This method must be called after a Sketch.union(byte[]).
union(byte[]) - Method in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
 
union(byte[]) - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
union(byte[]) - Method in class com.yahoo.bullet.querying.aggregations.sketches.Sketch
Union a sketch serialized using Sketch.serialize() into this.
union(byte[]) - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
 
union(byte[]) - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
 
unionedExistingResults() - Method in class com.yahoo.bullet.querying.aggregations.sketches.DualSketch
Merge the existing result into the union sketch if needed and return a boolean if the union was done.
unionedExistingResults() - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
 
unionedExistingResults() - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
 
unionedExistingResults() - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
 
unless(Predicate<Object>) - Method in class com.yahoo.bullet.common.Validator.Entry
Add a Predicate to guard the checks in this entry.
update(CachingGroupData) - Method in class com.yahoo.bullet.querying.aggregations.grouping.GroupDataSummary
 
update() - Method in class com.yahoo.bullet.querying.aggregations.sketches.DualSketch
This method must be called after an update operation.
update(String) - Method in class com.yahoo.bullet.querying.aggregations.sketches.FrequentItemsSketch
Inserts an item into the Sketch.
update(double) - Method in class com.yahoo.bullet.querying.aggregations.sketches.QuantileSketch
Updates the sketch with a double.
update(String) - Method in class com.yahoo.bullet.querying.aggregations.sketches.ThetaSketch
Update the sketch with a String field.
update(String, CachingGroupData) - Method in class com.yahoo.bullet.querying.aggregations.sketches.TupleSketch
Update the sketch with a key representing a group and the data for it.
URL - Static variable in class com.yahoo.bullet.common.metrics.HTTPMetricPublisherConfig
 
UTF_8 - Static variable in class com.yahoo.bullet.pubsub.rest.RESTPubSub
 
Utilities - Class in com.yahoo.bullet.common
 
Utilities() - Constructor for class com.yahoo.bullet.common.Utilities
 

V

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
This class validates instances of BulletConfig.
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
Constructor that creates a value evaluator from a ValueExpression.
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.tablefunctions.TableFunctionType
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.tablefunctions.TableFunctionType
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.

W

Window - Class in com.yahoo.bullet.query
 
Window(Integer, Window.Unit) - Constructor for class com.yahoo.bullet.query.Window
Constructor that creates a window with only emit fields.
Window(Integer, Window.Unit, Window.Unit, Integer) - Constructor for class com.yahoo.bullet.query.Window
Constructor that creates a window with emit and include fields.
window - Variable in class com.yahoo.bullet.windowing.Scheme
 
Window.Classification - Enum in com.yahoo.bullet.query
Represents the type of window.
Window.Unit - Enum in com.yahoo.bullet.query
Represents the type of the window unit for either emit or include.
WINDOW_DISABLE - Static variable in class com.yahoo.bullet.common.BulletConfig
 
WINDOW_MIN_EMIT_EVERY - Static variable in class com.yahoo.bullet.common.BulletConfig
 
windowCount - Variable in class com.yahoo.bullet.windowing.Basic
 
windowLength - Variable in class com.yahoo.bullet.windowing.Tumbling
 
wipe() - Method in class com.yahoo.bullet.storage.MemoryStorageManager
 
wipe() - Method in class com.yahoo.bullet.storage.MultiMemoryStorageManager
 
wipe() - Method in class com.yahoo.bullet.storage.NullStorageManager
 
A B C D E F G H I J K L M N O P Q R S T U V W 
Skip navigation links

Copyright © 2021. All rights reserved.