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 X Z 

A

AbstractBinderFactory - Class in com.yahoo.bard.webservice.application
Abstract Binder factory implements the standard buildBinder functionality.
AbstractBinderFactory() - Constructor for class com.yahoo.bard.webservice.application.AbstractBinderFactory
Constructor.
AbstractDruidAggregationQuery<Q extends AbstractDruidAggregationQuery<? super Q>> - Class in com.yahoo.bard.webservice.druid.model.query
Base class for druid aggregation queries.
AbstractDruidAggregationQuery(QueryType, DataSource, Granularity, Collection<Dimension>, Filter, Collection<Aggregation>, Collection<PostAggregation>, Collection<Interval>, QueryContext, boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.query.AbstractDruidAggregationQuery
Constructor.
AbstractDruidFactQuery<Q extends AbstractDruidFactQuery<? super Q>> - Class in com.yahoo.bard.webservice.druid.model.query
Base class for druid aggregation queries.
AbstractDruidFactQuery(QueryType, DataSource, Granularity, Filter, Collection<Interval>, QueryContext, boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.query.AbstractDruidFactQuery
Constructor.
AbstractDruidQuery<Q extends AbstractDruidQuery<? super Q>> - Class in com.yahoo.bard.webservice.druid.model.query
Base class for druid queries.
AbstractDruidQuery(QueryType, DataSource, QueryContext, boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.query.AbstractDruidQuery
Constructor.
AbstractResponse<T> - Class in com.yahoo.bard.webservice.web
Formats data of a response as JSON.
AbstractResponse(Stream<T>, Pagination<?>, UriInfo, ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.AbstractResponse
Constructor.
ACCEPT_HEADER_CSV - Static variable in class com.yahoo.bard.webservice.web.DefaultResponseFormatResolver
 
ACCEPT_HEADER_JSON - Static variable in class com.yahoo.bard.webservice.web.DefaultResponseFormatResolver
 
ACCEPT_HEADER_JSONAPI - Static variable in class com.yahoo.bard.webservice.web.DefaultResponseFormatResolver
 
ACCEPTING_FIELDS - Static variable in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
acceptJsonFormatVisitor(JsonFormatVisitorWrapper, JavaType) - Method in class com.yahoo.bard.webservice.druid.serializers.HasDruidNameSerializer
 
accepts(Collection<Interval>) - Method in class com.yahoo.bard.webservice.data.time.AllGranularity
 
accepts(Collection<Interval>) - Method in interface com.yahoo.bard.webservice.data.time.Granularity
Determine if all intervals align with a granularity.
accepts(Collection<Interval>) - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
 
accumulate(RequestLog) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Accumulates timings and threads to current thread's request log context.
add(FeatureFlag) - Method in class com.yahoo.bard.webservice.config.FeatureFlagRegistry
Register the feature flag.
add(Dimension) - Method in class com.yahoo.bard.webservice.data.dimension.DimensionDictionary
Adds the specified element to the dictionary if it is not already present.
add(LogicalMetric) - Method in class com.yahoo.bard.webservice.data.metric.MetricDictionary
Add a logical metric to the dictionary.
add(LogInfo) - Method in class com.yahoo.bard.webservice.logging.LogBlock
Append a part of logging information defined in this LogBlock.
add(Class<? extends LogInfo>) - Method in class com.yahoo.bard.webservice.logging.LogBlock
Add an entry of given class in this LogBlock that holds no information.
add(Interval) - Method in class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Only internal calls to linked list mutators should be used to change the list.
addAll(Collection<FeatureFlag>) - Method in class com.yahoo.bard.webservice.config.FeatureFlagRegistry
Register all of the feature flags.
addAll(Collection<? extends Dimension>) - Method in class com.yahoo.bard.webservice.data.dimension.DimensionDictionary
Adds all of the dimensions in the specified collection to the dictionary.
addAllDimensionRows(Set<DimensionRow>) - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Add all dimension rows to the dimension's set of rows.
addAllDimensionRows(Set<DimensionRow>) - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
addDataSegment(DataSegment) - Method in class com.yahoo.wiki.webservice.data.config.auto.TableConfig
Add a DataSegment to the existing known datasegments for this table.
addDimension(String) - Method in class com.yahoo.wiki.webservice.data.config.auto.TableConfig
Add a dimension to the datasource.
addDimensionRow(DimensionRow) - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Add a dimension row to the dimension's set of rows.
addDimensionRow(DimensionRow) - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
addIdPrefix(String) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Prepend an id prefix to generated druid query id.
addLink(PaginationLink, Pagination<?>, UriBuilder, Map<String, URI>) - Static method in class com.yahoo.bard.webservice.web.AbstractResponse
Adds the specified link to the headers and body of the response.
addLink(PaginationLink, Pagination<?>, UriBuilder, MappingResponseProcessor, Map<String, URI>) - Static method in class com.yahoo.bard.webservice.web.AbstractResponse
Adds the specified link to the headers and body of the response.
addLink(PaginationLink, int, int, UriBuilder, MappingResponseProcessor, Map<String, URI>) - Static method in class com.yahoo.bard.webservice.web.AbstractResponse
Adds the specified link to the headers and to the map of links that will be added to the body of the response.
addLinks(Pagination<?>, UriBuilder) - Static method in class com.yahoo.bard.webservice.web.AbstractResponse
Returns all required pagination links.
addLinks(Pagination<?>, UriBuilder, MappingResponseProcessor) - Static method in class com.yahoo.bard.webservice.web.AbstractResponse
Adds all the required pagination links to the headers and body of the response.
addMetric(String) - Method in class com.yahoo.wiki.webservice.data.config.auto.TableConfig
Add a metric to the datasource.
addPageLink(PaginationLink, Pagination<?>) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Add page links to the header of the response builder.
addPageLink(PaginationLink, int) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Add page links to the header of the response builder.
addPaginationInfoToResponseContext(ResponseContext, UriInfo, Pagination<Result>) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Add pagination details to ResponseContext.
addReplaceDimensionRows(String, String) - Method in class com.yahoo.bard.webservice.web.endpoints.DimensionCacheLoaderServlet
Endpoint to add/replace dimension rows.
addSatisfyingGrain(TimeGrain) - Method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
Notifies this grain that it can be decomposed to another grain.
addTimeGrain(DateTime, TimeGrain) - Static method in class com.yahoo.bard.webservice.util.DateTimeUtils
Adds timeGrain to a given dateTime.
addToMetricDictionary(MetricDictionary, List<MetricInstance>) - Static method in class com.yahoo.bard.webservice.util.Utils
Create metrics from instance descriptors and store in the metric dictionary.
addUpdateDimensionRows(String, String) - Method in class com.yahoo.bard.webservice.web.endpoints.DimensionCacheLoaderServlet
Endpoint to add/update dimension rows, with update semantics.
addWriter(ResponseFormatType, ResponseWriter) - Method in class com.yahoo.bard.webservice.web.FiliResponseWriterSelector
Add a customized format writer pair to the Map.
afterBinding(AbstractBinder) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Allows additional app-specific binding.
afterRegistration(ResourceConfig) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
afterRegistration(ResourceConfig) - Method in interface com.yahoo.bard.webservice.application.BinderFactory
Allows additional app-specific Jersey feature registration and config.
AggregatableDimensionsMatcher - Class in com.yahoo.bard.webservice.table.resolver
Use the granularity and columns of a query to determine whether or not tables can satisfy this query.
AggregatableDimensionsMatcher(QueryPlanningConstraint) - Constructor for class com.yahoo.bard.webservice.table.resolver.AggregatableDimensionsMatcher
Constructor saves metrics, dimensions, coarsest time grain, and logical table name (for logging).
Aggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Base type for aggregations.
Aggregation(String, String) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
Constructor.
AggregationAverageMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Makes a LogicalMetric that wraps existing metrics and average them across a coarser time grain.
AggregationAverageMaker(MetricDictionary, ZonelessTimeGrain) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.AggregationAverageMaker
Constructor.
aggregations - Variable in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidAggregationQuery
 
ALIGNMENT_EPOCH_STRING - Static variable in class com.yahoo.bard.webservice.util.IntervalUtils
 
aligns(DateTime) - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
Determines if this dateTime falls on a time grain boundary.
aligns(Interval) - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
Determines if this interval corresponds with time grain boundaries.
aligns(DateTime) - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
aligns(DateTime) - Method in interface com.yahoo.bard.webservice.data.time.ZonelessTimeGrain
Determines if this dateTime falls on a time grain boundary.
ALL_NAME - Static variable in class com.yahoo.bard.webservice.data.time.AllGranularity
 
AllDimensionsLoadedHealthCheck - Class in com.yahoo.bard.webservice.application.healthchecks
HealthCheck that verifies all dimensions have had a lastUpdated time set.
AllDimensionsLoadedHealthCheck(DimensionDictionary) - Constructor for class com.yahoo.bard.webservice.application.healthchecks.AllDimensionsLoadedHealthCheck
Construct a new AllDimensionsLoadedHealthCheck.
AllGranularity - Class in com.yahoo.bard.webservice.data.time
All granularity buckets any number and length of intervals into a single bucket.
AllPagesPagination<T> - Class in com.yahoo.bard.webservice.util
Pagination class that contains all matching results of a query.
AllPagesPagination(Collection<T>, PaginationParameters) - Constructor for class com.yahoo.bard.webservice.util.AllPagesPagination
Constructor.
AndFilter - Class in com.yahoo.bard.webservice.druid.model.filter
Filter for logical AND applied to a set of druid filter expressions.
AndFilter(List<Filter>) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.AndFilter
Constructor.
AndHaving - Class in com.yahoo.bard.webservice.druid.model.having
Having clause model for logical AND applied to a set of druid having expressions.
AndHaving(List<Having>) - Constructor for class com.yahoo.bard.webservice.druid.model.having.AndHaving
Constructor.
any() - Method in class com.yahoo.bard.webservice.logging.LogBlock
JSON serialization-focused getter that will "un wrap" the map, making it's entries appear to be those of the parent class.
anyRowsMatch(Dimension, Set<ApiFilter>) - Method in class com.yahoo.bard.webservice.table.resolver.DimensionIdFilter
Check if for a given set of request filters, adding in the filters for this `DataSourceFilter` there is a corresponding row.
ApiFilter - Class in com.yahoo.bard.webservice.web
ApiFilter object.
ApiFilter(Dimension, DimensionField, FilterOperation, Set<String>) - Constructor for class com.yahoo.bard.webservice.web.ApiFilter
Constructor.
ApiFilter(String, DimensionDictionary) - Constructor for class com.yahoo.bard.webservice.web.ApiFilter
Parses the URL filter Query and generates the ApiFilter object.
ApiFilters - Class in com.yahoo.bard.webservice.web.filters
ApiFilters specializes the type of the ApiFilterMap.
ApiFilters() - Constructor for class com.yahoo.bard.webservice.web.filters.ApiFilters
Constructor.
ApiFilters(Map<Dimension, Set<ApiFilter>>) - Constructor for class com.yahoo.bard.webservice.web.filters.ApiFilters
Constructor.
ApiHaving - Class in com.yahoo.bard.webservice.web
The Bard-level representation of a Druid Having clause.
ApiHaving(String, Map<String, LogicalMetric>) - Constructor for class com.yahoo.bard.webservice.web.ApiHaving
Parses the URL having Query and generates the ApiHaving object.
ApiHaving(LogicalMetric, HavingOperation, List<Double>) - Constructor for class com.yahoo.bard.webservice.web.ApiHaving
Constructor for an ApiHaving object whose data has already been parsed.
ApiJobStore - Interface in com.yahoo.bard.webservice.async.jobs.stores
An ApiJobStore is responsible for storing the metadata about Bard jobs.
ApiJobStoreException - Exception in com.yahoo.bard.webservice.async.jobs.stores
Class for exception thrown while saving a record in ApiJobStore.
ApiJobStoreException(JobRow) - Constructor for exception com.yahoo.bard.webservice.async.jobs.stores.ApiJobStoreException
build an ApiJobStoreException associated with the given JobRow.
ApiJobStoreException(Exception, JobRow) - Constructor for exception com.yahoo.bard.webservice.async.jobs.stores.ApiJobStoreException
Build an ApiJobStoreException with the cause and the JobRow on which the exception is thrown.
apiMetricColumns - Variable in class com.yahoo.bard.webservice.web.ResponseData
 
ApiMetricName - Interface in com.yahoo.bard.webservice.data.config.names
Interface to mark metric names.
ApiRequest - Interface in com.yahoo.bard.webservice.web.apirequest
Interface offering default implementations for the common components of API request objects.
apiRequest - Variable in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
 
ApiRequestImpl - Class in com.yahoo.bard.webservice.web.apirequest
API Request.
ApiRequestImpl(String, String, String, String, UriInfo) - Constructor for class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Parses the API request URL and generates the API request object.
ApiRequestImpl(String, String, String, UriInfo) - Constructor for class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Parses the API request URL and generates the API request object.
ApiRequestImpl(ResponseFormatType, long, Optional<PaginationParameters>, UriInfo, Response.ResponseBuilder) - Constructor for class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
All argument constructor, meant to be used for rewriting apiRequest.
ApiToFieldMapper - Class in com.yahoo.bard.webservice.sql
Maps between logical and physical column names given a table schema.
ApiToFieldMapper(PhysicalTableSchema) - Constructor for class com.yahoo.bard.webservice.sql.ApiToFieldMapper
Construct the alias maker with the given schema.
append(Set<T>, T) - Static method in class com.yahoo.bard.webservice.util.StreamUtils
Copy a set, add a value to it and return the new set.
apply(Response) - Method in class com.yahoo.bard.webservice.druid.client.impl.HeaderNestingJsonBuilderStrategy
 
apply(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery.LookbackQueryRequestedIntervalsFunction
 
apply(Aggregation, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.aggregation.DruidSqlAggregationConverter
Finds the corresponding SqlAggregation from a druid aggregation.
apply(String) - Method in class com.yahoo.bard.webservice.sql.ApiToFieldMapper
 
apply(DataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.resolver.DimensionIdFilter
 
apply(DataApiRequest, TemplateDruidQuery) - Method in class com.yahoo.bard.webservice.table.resolver.RequestQueryGranularityResolver
 
apply(String, Set<LogicalMetric>) - Method in class com.yahoo.bard.webservice.web.apirequest.DefaultHavingApiGenerator
Generates having objects based on the having query in the api request.
apply(String, Set<LogicalMetric>) - Method in class com.yahoo.bard.webservice.web.apirequest.PerRequestDictionaryHavingGenerator
Wrap the enclosed having generator in a query scoped metric dictionary.
apply(String, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.DefaultResponseFormatResolver
 
apply(DimensionsApiRequest, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.DimensionApiRequestMapper
Validate that dimensionApiRequest should not contain filter whose dimensions do not match requested dimension.
apply(T, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.NoOpRequestMapper
 
apply(T, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.RequestMapper
Rewrite and Validate the ApiRequest(e.g.
apply(String, ContainerRequestContext) - Method in interface com.yahoo.bard.webservice.web.ResponseFormatResolver
Resolve desirable format from URI and ContainerRequestContext.
apply(T, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.security.ChainingRequestMapper
Rewrite and Validate the ApiRequest(e.g.
apply(T, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.security.RoleBasedRoutingRequestMapper
 
ArithmeticMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker for performing binary arithmetic operations on metrics.
ArithmeticMaker(MetricDictionary, ArithmeticPostAggregation.ArithmeticPostAggregationFunction, Function<String, ResultSetMapper>) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.ArithmeticMaker
Constructor.
ArithmeticMaker(MetricDictionary, ArithmeticPostAggregation.ArithmeticPostAggregationFunction, ColumnMapper) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.ArithmeticMaker
Deprecated.
to override default mapping, use the Function constructor
ArithmeticMaker(MetricDictionary, ArithmeticPostAggregation.ArithmeticPostAggregationFunction) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.ArithmeticMaker
Build an ArithmeticMaker with SketchRoundUpMapper as the ResultSetMapper for building the LogicalMetric.
ArithmeticPostAggregation - Class in com.yahoo.bard.webservice.druid.model.postaggregation
Model representing arithmetic post aggregations.
ArithmeticPostAggregation(String, ArithmeticPostAggregation.ArithmeticPostAggregationFunction, List<PostAggregation>) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation
Constructor.
ArithmeticPostAggregation.ArithmeticPostAggregationFunction - Enum in com.yahoo.bard.webservice.druid.model.postaggregation
The defined arithmetic functions for post aggregation.
aroundWriteTo(WriterInterceptorContext) - Method in class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
This allows us to compute the length of the output stream when stream is closed.
AS_NAME_COMPARATOR - Static variable in interface com.yahoo.bard.webservice.data.config.names.DataSourceName
Comparator to order DataSourceNames by their asName methods, using the native String comparator.
AS_NAME_COMPARATOR - Static variable in interface com.yahoo.bard.webservice.data.config.names.TableName
Comparator to order TableNames by their asName methods, using the native String comparator.
asInnerSketch(SketchAggregation) - Method in interface com.yahoo.bard.webservice.druid.util.FieldConverters
Get the inner SketchAggregation when nesting.
asInnerSketch(SketchAggregation) - Method in class com.yahoo.bard.webservice.druid.util.SketchFieldConverter
Deprecated.
 
asInnerSketch(SketchAggregation) - Method in class com.yahoo.bard.webservice.druid.util.ThetaSketchFieldConverter
 
asLinkedHashSet(E...) - Static method in class com.yahoo.bard.webservice.util.Utils
Easily turn a few instances of an object into a LinkedHashSet.
asList() - Method in class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Method to convert SimplifiedIntervalList as regular list to address the deserialization issues.
asName() - Method in interface com.yahoo.bard.webservice.data.config.names.DataSourceName
Return a string representation of a table name.
asName() - Method in interface com.yahoo.bard.webservice.data.config.names.DimensionName
The logical name of this dimension as used in the api query.
asName() - Method in interface com.yahoo.bard.webservice.data.config.names.FieldName
Get the name as it should be used in Druid Queries.
asName() - Method in interface com.yahoo.bard.webservice.data.config.names.TableName
Return a string representation of a table name.
asName() - Method in class com.yahoo.wiki.webservice.data.config.metric.DruidMetricName
 
asName() - Method in class com.yahoo.wiki.webservice.data.config.metric.FiliApiMetricName
 
asName() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiDimensionConfigInfo
View the dimension name.
asName() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiMetricName
 
asName() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiDruidMetricName
 
asName() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiDruidTableName
View this table name as a string.
asName() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiLogicalTableName
This logical table as a String.
asOuterSketch(SketchAggregation) - Method in interface com.yahoo.bard.webservice.druid.util.FieldConverters
Get the outer SketchAggregation when nesting.
asOuterSketch(SketchAggregation) - Method in class com.yahoo.bard.webservice.druid.util.SketchFieldConverter
Deprecated.
 
asOuterSketch(SketchAggregation) - Method in class com.yahoo.bard.webservice.druid.util.ThetaSketchFieldConverter
 
assertDependentMetricsExist(List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.CardinalityMaker
Cardinality metrics depend on dimensions not metrics.
assertDependentMetricsExist(List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Checks that the dependent metrics are in the dictionary, and throws an exception if any are not.
assertDependentMetricsExist(List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.RawAggregationMetricMaker
Aggregation columns are not expected to be in the metric Dictionary.
assertRequiredDependentMetricCount(String, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.ArithmeticMaker
Unlike most other metrics, Arithmetic metrics require at least DEPENDENT_METRICS_REQUIRED dependent metrics, rather than exactly DEPENDENT_METRICS_REQUIRED.
assertRequiredDependentMetricCount(String, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Checks that we have the right number of metrics, and throws an exception if we don't.
asSketchEstimate(SketchAggregation) - Method in interface com.yahoo.bard.webservice.druid.util.FieldConverters
Get the candidate SketchAggregation as a SketchEstimatePostAggregation.
asSketchEstimate(MetricField) - Method in interface com.yahoo.bard.webservice.druid.util.FieldConverters
Get the candidate MetricField as a PostAggregation.
asSketchEstimate(SketchAggregation) - Method in class com.yahoo.bard.webservice.druid.util.SketchFieldConverter
Deprecated.
 
asSketchEstimate(MetricField) - Method in class com.yahoo.bard.webservice.druid.util.SketchFieldConverter
Deprecated.
 
asSketchEstimate(SketchAggregation) - Method in class com.yahoo.bard.webservice.druid.util.ThetaSketchFieldConverter
 
asSketchEstimate(MetricField) - Method in class com.yahoo.bard.webservice.druid.util.ThetaSketchFieldConverter
 
asyncAfter - Variable in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
AsyncDruidWebServiceImpl - Class in com.yahoo.bard.webservice.druid.client.impl
Represents the druid web service endpoint.
AsyncDruidWebServiceImpl(DruidServiceConfig, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
AsyncDruidWebServiceImpl(DruidServiceConfig, AsyncHttpClient, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
AsyncDruidWebServiceImpl(DruidServiceConfig, ObjectMapper, Supplier<Map<String, String>>) - Constructor for class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
Friendly non-DI constructor useful for manual tests.
AsyncDruidWebServiceImpl(DruidServiceConfig, ObjectMapper, Supplier<Map<String, String>>, Function<Response, JsonNode>) - Constructor for class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
Friendly non-DI constructor useful for manual tests.
AsyncDruidWebServiceImpl(DruidServiceConfig, AsyncHttpClient, ObjectMapper, Supplier<Map<String, String>>) - Constructor for class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
IOC constructor.
AsyncDruidWebServiceImpl(DruidServiceConfig, AsyncHttpClient, ObjectMapper, Supplier<Map<String, String>>, Function<Response, JsonNode>) - Constructor for class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
IOC constructor.
ASYNCHRONOUS_ASYNC_AFTER_VALUE - Static variable in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
 
AsynchronousWorkflows - Class in com.yahoo.bard.webservice.async.workflows
A bean containing the Observables for each of the message flows needed to support asynchronous processing: The flow that emits the results to be sent to the user if they are ready within the asynchronous timeout.
AsynchronousWorkflows(Observable<PreResponse>, Observable<String>, Observable<String>, Observable<JobRow>) - Constructor for class com.yahoo.bard.webservice.async.workflows.AsynchronousWorkflows
Builds a bean containing all the message flows that support asynchronous processing.
AsynchronousWorkflowsBuilder - Interface in com.yahoo.bard.webservice.async.workflows
A SAM that sets up the workflow for shipping query results back to the user, and saving query results for later querying if necessary.
AsyncUtils - Class in com.yahoo.bard.webservice.async
Contains a collection of utility functions for asynchronous processing.
AsyncUtils() - Constructor for class com.yahoo.bard.webservice.async.AsyncUtils
 
AsyncWebServiceRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Request handler to submit the response to the druid web service.
AsyncWebServiceRequestHandler(DruidWebService, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.AsyncWebServiceRequestHandler
Build the request handler.
Availability - Interface in com.yahoo.bard.webservice.table.availability
Availability describes the intervals available by column for a table.
AvroDimensionRowParser - Class in com.yahoo.bard.webservice.data.dimension
Parses an AVRO file into Dimension Rows.
AvroDimensionRowParser(DimensionFieldNameMapper) - Constructor for class com.yahoo.bard.webservice.data.dimension.AvroDimensionRowParser
Constructs an AvroDimensionRowParser object based on the DimensionFieldNameMapper object.

B

BadApiRequestException - Exception in com.yahoo.bard.webservice.web
Unchecked exception for a bad API request.
BadApiRequestException(String) - Constructor for exception com.yahoo.bard.webservice.web.BadApiRequestException
Constructor.
BadApiRequestException(Throwable) - Constructor for exception com.yahoo.bard.webservice.web.BadApiRequestException
Constructor.
BadApiRequestException(String, Throwable) - Constructor for exception com.yahoo.bard.webservice.web.BadApiRequestException
Constructor.
BadFilterException - Exception in com.yahoo.bard.webservice.web
Bad filter exception is an exception encountered when the filter object cannot be built.
BadFilterException(String) - Constructor for exception com.yahoo.bard.webservice.web.BadFilterException
Constructor.
BadFilterException(String, Throwable) - Constructor for exception com.yahoo.bard.webservice.web.BadFilterException
Constructor.
BadHavingException - Exception in com.yahoo.bard.webservice.web
Bad having exception is an exception encountered when the having object cannot be built.
BadHavingException(String) - Constructor for exception com.yahoo.bard.webservice.web.BadHavingException
Constructor.
BadHavingException(String, Throwable) - Constructor for exception com.yahoo.bard.webservice.web.BadHavingException
Constructor.
BadPaginationException - Exception in com.yahoo.bard.webservice.web
Marks that we have experienced a problem with binding and parsing pagination parameters.
BadPaginationException(String) - Constructor for exception com.yahoo.bard.webservice.web.BadPaginationException
Constructor.
BardConfigResources - Interface in com.yahoo.bard.webservice.web.util
Configuration used in the java servlet interface.
BardFeatureFlag - Enum in com.yahoo.bard.webservice.config
Feature flags bind an object to a system configuration name.
BardLoggingFilter - Class in com.yahoo.bard.webservice.web.filters
Logs request/response in this format.
BardLoggingFilter() - Constructor for class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
 
BardQueryInfo - Class in com.yahoo.bard.webservice.logging.blocks
Main log of a request served by the TablesServlet.
BardQueryInfo(String) - Constructor for class com.yahoo.bard.webservice.logging.blocks.BardQueryInfo
Constructor.
BaseCompositeAvailability - Class in com.yahoo.bard.webservice.table.availability
A class implementing common capabilities for availabilities backed by a collection of other availabilities.
BaseCompositeAvailability(Stream<Availability>) - Constructor for class com.yahoo.bard.webservice.table.availability.BaseCompositeAvailability
Constructor.
BaseCompositePhysicalTable - Class in com.yahoo.bard.webservice.table
An implementation of BasePhysicalTable that contains multiple tables.
BaseCompositePhysicalTable(TableName, ZonedTimeGrain, Set<Column>, Set<? extends PhysicalTable>, Map<String, String>, Availability) - Constructor for class com.yahoo.bard.webservice.table.BaseCompositePhysicalTable
Constructor.
BaseDataRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Base class for request handlers.
BaseDataRequestHandler(ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.BaseDataRequestHandler
Capture the ObjectMapper and build an ObjectWriter for JSON.
BaseMetadataAvailability - Class in com.yahoo.bard.webservice.table.availability
An availability based on a DataSourceMetadataService backed by a single data source.
BaseMetadataAvailability(DataSourceName, DataSourceMetadataService) - Constructor for class com.yahoo.bard.webservice.table.availability.BaseMetadataAvailability
Constructor.
BasePhysicalTable - Class in com.yahoo.bard.webservice.table
Base implementation of physical table that are shared across various types of physical tables.
BasePhysicalTable(TableName, ZonedTimeGrain, Iterable<Column>, Map<String, String>, Availability) - Constructor for class com.yahoo.bard.webservice.table.BasePhysicalTable
Create a physical table.
BasePhysicalTableResolver - Class in com.yahoo.bard.webservice.table.resolver
Abstract parent to with business rule agnostic implementations of core methods.
BasePhysicalTableResolver() - Constructor for class com.yahoo.bard.webservice.table.resolver.BasePhysicalTableResolver
 
BaseSchema - Class in com.yahoo.bard.webservice.table
A parent class for most schema implementations.
BaseSchema(Granularity, Iterable<Column>) - Constructor for class com.yahoo.bard.webservice.table.BaseSchema
Constructor.
BaseTableLoader - Class in com.yahoo.bard.webservice.data.config.table
Provides commonly-needed methods for loading tables.
BaseTableLoader(DataSourceMetadataService) - Constructor for class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
A table loader using a standard time context and UTC default time zone.
BaseTableLoader(DateTimeZone, DataSourceMetadataService) - Constructor for class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
A table loader using a time context and a default time zone.
bind() - Method in class com.yahoo.bard.webservice.web.ratelimit.BypassRateLimitRequestToken
 
bind() - Method in class com.yahoo.bard.webservice.web.ratelimit.CallbackRateLimitRequestToken
 
bind() - Method in interface com.yahoo.bard.webservice.web.ratelimit.RateLimitRequestToken
Bind the counters to the token.
BinderFactory - Interface in com.yahoo.bard.webservice.application
A binder factory builds a custom binder for the jersey application.
BouncerAuthorizationStatus - Enum in com.yahoo.bard.webservice.web.filters
Bouncer pass through status enum.
BroadcastChannel<T> - Interface in com.yahoo.bard.webservice.async.broadcastchannels
Bard may exist in a system where multiple Bard hosts exist, it is possible that a user may submit a query on one box, and then come back later and perform a long poll on a separate box.
build(ResourceDictionaries, DataSourceMetadataService) - Method in class com.yahoo.bard.webservice.data.config.table.ConcretePhysicalTableDefinition
 
build(ResourceDictionaries, DataSourceMetadataService) - Method in class com.yahoo.bard.webservice.data.config.table.ConcreteSqlPhysicalTableDefinition
 
build(ResourceDictionaries, DataSourceMetadataService) - Method in class com.yahoo.bard.webservice.data.config.table.DimensionListPartitionTableDefinition
 
build(ResourceDictionaries, DataSourceMetadataService) - Method in class com.yahoo.bard.webservice.data.config.table.MetricUnionCompositeTableDefinition
 
build(ResourceDictionaries, DataSourceMetadataService) - Method in class com.yahoo.bard.webservice.data.config.table.PermissivePhysicalTableDefinition
 
build(ResourceDictionaries, DataSourceMetadataService) - Method in class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
Given the resource dictionaries and a data source metadata service, build the corresponding physical table.
build(DataApiRequest, Subject<PreResponse, PreResponse>, DruidResponseParser, ObjectMappersSuite, HttpResponseMaker) - Method in interface com.yahoo.bard.webservice.web.responseprocessors.ResponseProcessorFactory
Constructs a custom ResponseProcessor.
build(DataApiRequest, Subject<PreResponse, PreResponse>, DruidResponseParser, ObjectMappersSuite, HttpResponseMaker) - Method in class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessorFactory
 
buildApiJobStore() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Builds an instance of the interface to the storage system to use to store metadata about asynchronous requests.
buildApiRequest(String, String, List<PathSegment>, String, String, String, String, String, String, String, String, String, String, String, String, UriInfo, BardConfigResources) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequestFactory
Factory method for building DataApiRequest objects.
buildApiRequest(String, String, List<PathSegment>, String, String, String, String, String, String, String, String, String, String, String, String, UriInfo, BardConfigResources) - Method in class com.yahoo.bard.webservice.web.apirequest.DefaultDataApiRequestFactory
 
buildAsynchronousWorkflows(Observable<PreResponse>, Observable<Either<PreResponse, JobRow>>, JobRow, Function<JobRow, String>) - Method in interface com.yahoo.bard.webservice.async.workflows.AsynchronousWorkflowsBuilder
Builds the asynchronous workflows.
buildAsynchronousWorkflows(Observable<PreResponse>, Observable<Either<PreResponse, JobRow>>, JobRow, Function<JobRow, String>) - Method in class com.yahoo.bard.webservice.async.workflows.DefaultAsynchronousWorkflowsBuilder
 
buildBinder() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
buildBinder() - Method in interface com.yahoo.bard.webservice.application.BinderFactory
Build an hk2 Binder instance.
buildBroadcastChannel() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Builds an instance of a BroadcastChannel that broadcasts the tickets of asynchronous jobs that have been successfully stored in the PreResponseStore .
buildCache() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Build a cache for data requests and matching responses.
buildColumns(DimensionDictionary) - Method in class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
Helper method for sub-classes to convert dimension configs into dimension columns and create metric columns.
buildConfigurationLoader(DimensionLoader, MetricLoader, TableLoader) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Extension point for building custom Configuration Loaders.
buildCsvHeaders(ResponseData) - Method in class com.yahoo.bard.webservice.web.CsvResponseWriter
Builds the CSV header.
buildDataApiRequestFactory() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Creates an factory that constructs DataApiRequests .
buildDataSourceMetadataLoader(DruidWebService, PhysicalTableDictionary, DataSourceMetadataService, ObjectMapper) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Build a datasource metadata loader.
buildDataSourceMetadataSuccessCallback(SingleDataSourcePhysicalTable) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
Deprecated.
Pass the DataSourceName directly, rather than via the PhysicalTable
buildDataSourceMetadataSuccessCallback(DataSourceName) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
Callback to parse druid datasource metadata response.
buildDefaultGranularityToDateFunctionsMap() - Static method in class com.yahoo.bard.webservice.sql.helper.SqlTimeConverter
Builds the default mapping between Granularity and the SqlDatePartFunctions needed to group on and read into a DateTime.
buildDimensionFilter(Dimension, Set<ApiFilter>) - Method in class com.yahoo.bard.webservice.data.filterbuilders.ConjunctionDruidFilterBuilder
Take the conjunction of all the filters on a single dimension.
buildDimensionFilter(Dimension, Set<ApiFilter>) - Method in class com.yahoo.bard.webservice.data.filterbuilders.ConsolidatingDruidFilterBuilder
 
buildDimensionFilter(Dimension, Set<ApiFilter>) - Method in class com.yahoo.bard.webservice.data.filterbuilders.DefaultDruidFilterBuilder
 
buildDimensionSpanningTableGroup(Set<TableName>, Set<PhysicalTableDefinition>, ResourceDictionaries, Set<ApiMetricName>) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Builds a table group that derive its dimensions by taking the union of all the underlying physical dimensions.
buildDimensionSpanningTableGroup(Set<ApiMetricName>, Set<FieldName>, Set<PhysicalTableDefinition>, ResourceDictionaries) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Deprecated.
does not load table with external dependency, use the other buildDimensionSpanningTableGroup instead
buildDruidDimensionsLoader(DruidWebService, PhysicalTableDictionary, DimensionDictionary) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Build a DimensionValueLoadTask.
buildDruidDimensionsLoader(DruidWebService, PhysicalTableDictionary, DimensionDictionary) - Method in class com.yahoo.wiki.webservice.application.GenericBinderFactory
 
buildDruidFilterBuilder() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Creates an object that constructs Druid dimension filters from Bard dimension filters.
buildDruidQueryBuilder() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Initializes the factory that builds druid queries.
buildDruidResponse() - Method in class com.yahoo.bard.webservice.sql.SqlResultSetProcessor
Processes the results from the sql ResultSet and writes them out as the json format returned for a GroupByQuery.
buildDruidResponseParser() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Initializes the class that parses responses from Druid.
buildDruidSqlTypeConverter() - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Builds a converter between druid and sql aggregations.
buildDruidWebService(DruidServiceConfig, ObjectMapper) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Create a DruidWebService.
buildDruidWebService(ObjectMapper) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Create a DruidWebService for the UI connection.
buildDruidWebServiceHeaderSupplier() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Build the Supplier for Druid data request headers.
builder - Variable in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
buildErrorPreResponse(Throwable) - Static method in class com.yahoo.bard.webservice.async.AsyncUtils
Builds the PreResponse that stores the error message.
buildErrorResponse(int, String, String, DruidQuery<?>) - Method in class com.yahoo.bard.webservice.data.HttpResponseMaker
Prepare Response object from error details with reason and description.
buildFilters(Map<Dimension, Set<ApiFilter>>) - Method in class com.yahoo.bard.webservice.data.filterbuilders.ConjunctionDruidFilterBuilder
 
buildFilters(Map<Dimension, Set<ApiFilter>>) - Method in interface com.yahoo.bard.webservice.data.filterbuilders.DruidFilterBuilder
Combines the filters for a set of dimensions into a single Druid filter.
buildGroupBy(RelBuilder, Granularity, String) - Method in class com.yahoo.bard.webservice.sql.helper.SqlTimeConverter
Builds a list of RexNode which will effectively groupBy the given Granularity.
buildGroupByQuery(TemplateDruidQuery, ConstrainedTable, Granularity, DateTimeZone, Set<Dimension>, Filter, Having, Set<Interval>, LimitSpec) - Method in class com.yahoo.bard.webservice.data.DruidQueryBuilder
Builds a druid groupBy query recursively nesting dataSource based on the TemplateDruidQuery.
buildHaving(LogicalMetric, ApiHaving) - Static method in class com.yahoo.bard.webservice.data.DruidHavingBuilder
Create a list of NumericHavings for the values specified and OR them together.
buildHavingGenerator(ConfigurationLoader) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Creates an object that generates map of Api Having from having string.
buildHavings(Map<LogicalMetric, Set<ApiHaving>>) - Static method in class com.yahoo.bard.webservice.data.DruidHavingBuilder
Build a having model that ANDs together having queries for each of the metrics.
buildHeaderList() - Method in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
Create headers which belong in the response.
buildIntervalStringList(Collection<Interval>) - Method in class com.yahoo.bard.webservice.web.ResponseData
Build a list of interval strings.
buildJobPayloadBuilder() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
The Builder to be used to serialize a JobRow into the the job to be returned to the user.
buildJobRow(UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobRowBuilder
Builds a JobRow with values for every field defined in DefaultJobField.
buildJobRow(UriInfo, ContainerRequestContext) - Method in interface com.yahoo.bard.webservice.async.jobs.jobrows.JobRowBuilder
Builds the bean holding the metadata about an asynchronous job.
buildJobRowBuilder() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Initializes the service for building JobRows based on the information in a query.
buildJobStoreFilter(String) - Method in class com.yahoo.bard.webservice.web.apirequest.JobsApiRequestImpl
Given a filter String, generates a Set of ApiJobStoreFilters.
buildLogicalTable(String, Granularity, TableGroup, MetricDictionary) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Deprecated.
use new LogicalTable(...) by preferences
buildLogicalTable(String, Granularity, String, String, ReadablePeriod, String, TableGroup, MetricDictionary) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Deprecated.
The LogicalTable constructor is being mirrored here, can be referenced directly
buildLogicalToPhysicalNames(Set<? extends DimensionConfig>) - Method in class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
Builds the dimension logical name to physical name mapping from dimension configs.
buildLookupMetaDataLoader(DruidWebService, DimensionDictionary) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Builds a lookup metadata loader.
buildLookupSuccessCallback() - Method in class com.yahoo.bard.webservice.metadata.RegisteredLookupMetadataLoadTask
Returns a callback that has actions on lookup metadata from a successful Druid response.
buildMetadataDruidWebService(ObjectMapper) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Create a DruidWebService for metadata.
buildMetricHaving(LogicalMetric, Set<ApiHaving>) - Static method in class com.yahoo.bard.webservice.data.DruidHavingBuilder
Build a Having for all the having queries for a single metric, ANDing them together.
buildMetricMakers(MetricDictionary) - Method in class com.yahoo.wiki.webservice.data.config.metric.GenericMetricLoader
Initialize the metric makers with the given metric dictionary.
buildMetricMakers(MetricDictionary) - Method in class com.yahoo.wiki.webservice.data.config.metric.WikiMetricLoader
(Re)Initialize the metric makers with the given metric dictionary.
buildNonUiDruidWebService(ObjectMapper) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Deprecated.
removed non-ui webservice, this method is no longer used
buildPayload(JobRow, UriInfo) - Method in class com.yahoo.bard.webservice.async.jobs.payloads.DefaultJobPayloadBuilder
 
buildPayload(JobRow, UriInfo) - Method in interface com.yahoo.bard.webservice.async.jobs.payloads.JobPayloadBuilder
Given a Map containing job metadata, return a map representing job payload to be sent to the user.
buildPhysicalTableWithDependency(String, Map<String, PhysicalTableDefinition>, ResourceDictionaries) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Build and return the current physical table given its table name and definition, if dependency exists, build its dependencies and load the dependencies into physical table dictionary.
buildPreResponseStore(ResourceDictionaries) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Builds an instance of the interface to the storage system to use to store PreResponses of asynchronous requests.
buildQuery(DataApiRequest, TemplateDruidQuery) - Method in class com.yahoo.bard.webservice.data.DruidQueryBuilder
Build a druid query object from an API request and it's templateDruidQuery.
buildQuerySigningService(PhysicalTableDictionary, DataSourceMetadataService) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Build a QuerySigningService.
buildRateLimiter() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Creates a new RateLimiter for the RateLimitFilter.
buildResponse(PreResponse, ApiRequest) - Method in class com.yahoo.bard.webservice.data.HttpResponseMaker
Build complete response.
buildResponseData(ResultSet, LinkedHashSet<String>, LinkedHashMap<Dimension, LinkedHashSet<DimensionField>>, SimplifiedIntervalList, SimplifiedIntervalList, Pagination, Map<String, URI>) - Method in class com.yahoo.bard.webservice.data.HttpResponseMaker
Builds a ResponseData object.
buildResponseFormatResolver() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Create a ResponseFormatResolver for Servlet objects.
buildResponseProcessorFactory() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Returns the class to bind to ResponseProcessorFactory.
buildResponseWriter(ObjectMappersSuite) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Builder for ResponseWriter, a serializer allowing customized response from Fili.
buildResultRow(Result) - Method in class com.yahoo.bard.webservice.web.ResponseData
Builds map of result row from a result.
buildResultRowWithSidecars(Result, Map<Dimension, Set<Map<DimensionField, String>>>) - Method in class com.yahoo.bard.webservice.web.ResponseData
Builds map of result row from a result and loads the dimension rows into the sidecar map.
buildResultSet(JsonNode, DruidAggregationQuery<?>, DateTimeZone) - Method in class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessor
Build a result set using the api request time grain.
buildResultSetMapperList(DataApiRequest) - Method in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
Extract all ResultSetMappers from the api request.
buildSchemaColumns(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.data.DruidResponseParser
Produce the schema-defining columns for a given druid query.
buildSchemaColumns() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidAggregationQuery
Produce the schema-defining columns for a given druid query.
buildSecurityFilters(SecurityContext) - Method in class com.yahoo.bard.webservice.web.security.RoleDimensionApiFilterRequestMapper
Collect all the whitelist filters generated by roles in this security context.
buildSelectorFilters(Dimension, Set<DimensionRow>) - Method in class com.yahoo.bard.webservice.data.filterbuilders.ConjunctionDruidFilterBuilder
Builds a list of Druid selector or extraction filters.
buildSigningFunctions() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Build a Map of Class to Function that should be used to get requestedIntervals from the DruidQuery.
buildSqlQuery(DruidAggregationQuery<?>, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Builds the druid query as sql and returns it as a string.
buildSqlTimeConverter() - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Builds a time converter to designating how to translate between druid and sql time information.
buildSuccessCallback(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor, long) - Method in class com.yahoo.bard.webservice.web.handlers.WeightCheckRequestHandler
Build a callback which continues the original request or refuses it with an HTTP INSUFFICIENT_STORAGE (507) status based on the cardinality of the requester 's query as measured by the weight check query.
buildTableGroup(String, Set<ApiMetricName>, Set<FieldName>, Set<PhysicalTableDefinition>, ResourceDictionaries) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Deprecated.
logicalTableName is not used in TableGroup, use buildDimensionSpanningTableGroup instead
buildTimeFilters(RelBuilder, DruidAggregationQuery<?>, String) - Method in class com.yahoo.bard.webservice.sql.helper.SqlTimeConverter
Builds the time filters to only select rows that occur within the intervals of the query.
buildTimeSeriesQuery(TemplateDruidQuery, ConstrainedTable, Granularity, DateTimeZone, Filter, Set<Interval>) - Method in class com.yahoo.bard.webservice.data.DruidQueryBuilder
Builds a druid TimeSeries query.
buildTopNQuery(TemplateDruidQuery, ConstrainedTable, Granularity, DateTimeZone, Set<Dimension>, Filter, Set<Interval>, TopNMetric, int) - Method in class com.yahoo.bard.webservice.data.DruidQueryBuilder
Builds a druid topN query.
buildWorkflow() - Method in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
buildWorkflow() - Method in interface com.yahoo.bard.webservice.web.handlers.workflow.RequestWorkflowProvider
Construct a workflow instance with a starting point request handler.
buildWorkflow() - Method in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
buildZonedTimeGrain(DateTimeZone) - Method in interface com.yahoo.bard.webservice.data.time.ZonelessTimeGrain
Apply a timezone to a time grain.
BYPASS_HEADER_NAME - Static variable in class com.yahoo.bard.webservice.web.DataApiRequestTypeIdentifier
 
BYPASS_HEADER_VALUE - Static variable in class com.yahoo.bard.webservice.web.DataApiRequestTypeIdentifier
 
BYPASS_TOKEN - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
BypassRateLimitRequestToken - Class in com.yahoo.bard.webservice.web.ratelimit
RateLimitRequestToken for bypass request.
BypassRateLimitRequestToken() - Constructor for class com.yahoo.bard.webservice.web.ratelimit.BypassRateLimitRequestToken
 
BYTES_PER_KILOBYTE - Static variable in class com.yahoo.wiki.webservice.data.config.metric.WikiMetricLoader
 

C

CACHE_HITS - Static variable in class com.yahoo.bard.webservice.web.handlers.CacheRequestHandler
 
CACHE_HITS - Static variable in class com.yahoo.bard.webservice.web.handlers.CacheV2RequestHandler
 
CACHE_MISSES - Static variable in class com.yahoo.bard.webservice.web.handlers.CacheRequestHandler
 
CACHE_MISSES - Static variable in class com.yahoo.bard.webservice.web.handlers.CacheV2RequestHandler
 
CACHE_POTENTIAL_HITS - Static variable in class com.yahoo.bard.webservice.web.handlers.CacheV2RequestHandler
 
CACHE_REQUESTS - Static variable in class com.yahoo.bard.webservice.web.handlers.CacheRequestHandler
 
CACHE_REQUESTS - Static variable in class com.yahoo.bard.webservice.web.handlers.CacheV2RequestHandler
 
CacheFeatureFlag - Enum in com.yahoo.bard.webservice.config
Binds a caching strategy to a system configuration name.
CacheLastObserver<T> - Class in com.yahoo.bard.webservice.util
A thread-safe observable that caches the last message it received, and caches the last error (if any) it receives.
CacheLastObserver() - Constructor for class com.yahoo.bard.webservice.util.CacheLastObserver
 
CacheRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Request handler to check the cache for a matching request and either return the cached result or send the next handler.
CacheRequestHandler(DataRequestHandler, DataCache<?>, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.CacheRequestHandler
Build a Cache request handler.
CacheV2RequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Request handler to check the cache for a matching request and either return the cached result or send the next handler.
CacheV2RequestHandler(DataRequestHandler, DataCache<?>, QuerySigningService<?>, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.CacheV2RequestHandler
Build a Cache request handler.
CacheV2ResponseProcessor - Class in com.yahoo.bard.webservice.web.responseprocessors
A response processor which caches the results if appropriate after completing a query.
CacheV2ResponseProcessor(ResponseProcessor, String, TupleDataCache<String, Long, String>, QuerySigningService<Long>, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.CacheV2ResponseProcessor
Constructor.
CachingResponseProcessor - Class in com.yahoo.bard.webservice.web.responseprocessors
A response processor which caches the results if appropriate after completing a query.
CachingResponseProcessor(ResponseProcessor, String, DataCache<String>, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.CachingResponseProcessor
Constructor.
CalciteHelper - Class in com.yahoo.bard.webservice.sql.helper
Small utility class to help with connection to databases, building, and writing sql.
CalciteHelper(DataSource) - Constructor for class com.yahoo.bard.webservice.sql.helper.CalciteHelper
Initialize the helper with a datasource and it's schema.
calculate(PostAggregation, Function<String, String>) - Method in class com.yahoo.bard.webservice.sql.evaluator.PostAggregationEvaluator
Calculates the value of a post aggregation.
CallbackRateLimitRequestToken - Class in com.yahoo.bard.webservice.web.ratelimit
Request token that takes a rateLimitCleanup object on creation, and calls that to handle the cleanup when the request transaction is completed.
CallbackRateLimitRequestToken(boolean, RateLimitCleanupOnRequestComplete) - Constructor for class com.yahoo.bard.webservice.web.ratelimit.CallbackRateLimitRequestToken
Constructor.
camelCase(String) - Static method in class com.yahoo.bard.webservice.util.EnumUtils
Converts the string value to a camel case string.
canOptimizeTimeSeries(DataApiRequest, TemplateDruidQuery) - Method in class com.yahoo.bard.webservice.data.DruidQueryBuilder
Determine if the optimization to a Timeseries query can be done.
canOptimizeTopN(DataApiRequest, TemplateDruidQuery) - Method in class com.yahoo.bard.webservice.data.DruidQueryBuilder
Determine if the optimization to a TopN query can be done.
CARDINALITY_COMPARATOR - Static variable in class com.yahoo.bard.webservice.table.resolver.DefaultPhysicalTableResolver
 
CardinalityAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Creates a Druid cardinality aggregation.
CardinalityAggregation(String, Set<Dimension>, boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
Constructor.
CardinalityMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric Maker to calculate the cardinality.
CardinalityMaker(MetricDictionary, DimensionDictionary, boolean) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.CardinalityMaker
Constructor.
CascadeExtractionFunction - Class in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
Cascade ExtractionFunction that chains an array of ExtractionFunctions to be executed in array index order.
CascadeExtractionFunction(List<ExtractionFunction>) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.CascadeExtractionFunction
Constructor.
ChainingComparator<T> - Class in com.yahoo.bard.webservice.util
A comparator which accepts a list of other comparators to apply in order until an imbalance is found.
ChainingComparator(List<Comparator<T>>) - Constructor for class com.yahoo.bard.webservice.util.ChainingComparator
Constructor.
ChainingRequestMapper<T extends ApiRequest> - Class in com.yahoo.bard.webservice.web.security
An abstract ApiRequest Mapper that allows delegation to a subsequent mapper.
ChainingRequestMapper(ResourceDictionaries) - Constructor for class com.yahoo.bard.webservice.web.security.ChainingRequestMapper
Constructor.
ChainingRequestMapper(ResourceDictionaries, RequestMapper<T>) - Constructor for class com.yahoo.bard.webservice.web.security.ChainingRequestMapper
Constructor.
check() - Method in class com.yahoo.bard.webservice.application.healthchecks.AllDimensionsLoadedHealthCheck
 
check() - Method in class com.yahoo.bard.webservice.application.healthchecks.DataSourceMetadataLoaderHealthCheck
 
check() - Method in class com.yahoo.bard.webservice.application.healthchecks.DruidDimensionsLoaderHealthCheck
 
check() - Method in class com.yahoo.bard.webservice.application.healthchecks.KeyValueStoreHealthCheck
 
check() - Method in class com.yahoo.bard.webservice.application.healthchecks.LookupHealthCheck
 
check() - Method in class com.yahoo.bard.webservice.application.healthchecks.SearchProviderHealthCheck
 
check() - Method in class com.yahoo.bard.webservice.application.healthchecks.VersionHealthCheck
 
cleanup() - Method in interface com.yahoo.bard.webservice.web.ratelimit.RateLimitCleanupOnRequestComplete
Perform the cleanup.
clear() - Method in interface com.yahoo.bard.webservice.data.cache.DataCache
Removes all of the mappings from this cache.
clear() - Method in class com.yahoo.bard.webservice.data.cache.HashDataCache
 
clear() - Method in class com.yahoo.bard.webservice.data.cache.MemDataCache
 
clear() - Method in class com.yahoo.bard.webservice.data.cache.StubDataCache
 
clear() - Method in class com.yahoo.bard.webservice.util.DelegatingMap
Removes are not allowed: Delegating Map should be changed in a put-only fashion.
clearDimension() - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
Clears the dimension cache, and resets the indices, effectively resetting the SearchProvider to a clean state.
clearDimension() - Method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
 
clearDimension() - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
clearDimension() - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Clears the dimension cache, and resets the indices, effectively resetting the SearchProvider to a clean state.
clearLocal() - Method in class com.yahoo.bard.webservice.util.DelegatingMap
Clear the local map.
clearProperty(String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Remove property from the user-defined runtime configuration.
CLIENT_HEADER_NAME - Static variable in class com.yahoo.bard.webservice.web.DataApiRequestTypeIdentifier
 
CLIENT_HEADER_VALUE - Static variable in class com.yahoo.bard.webservice.web.DataApiRequestTypeIdentifier
 
CLIENT_TOTAL_TIMER - Static variable in class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
 
close() - Method in class com.yahoo.bard.webservice.async.broadcastchannels.RedisBroadcastChannel
 
close() - Method in class com.yahoo.bard.webservice.async.broadcastchannels.SimpleBroadcastChannel
 
close() - Method in interface com.yahoo.bard.webservice.data.dimension.KeyValueStore
Close the store.
close() - Method in class com.yahoo.bard.webservice.data.dimension.MapStore
 
close() - Method in class com.yahoo.bard.webservice.data.dimension.RedisStore
 
close() - Method in class com.yahoo.bard.webservice.logging.TimedPhase
Stops the timer, and registers the timer with the RequestLog.
close() - Method in interface com.yahoo.bard.webservice.web.ratelimit.RateLimitRequestToken
By default, close will trigger unbind.
code - Variable in class com.yahoo.bard.webservice.logging.blocks.Epilogue
 
code - Variable in class com.yahoo.bard.webservice.logging.blocks.Response
 
collectBucketedIntervalsIntersectingIntervalList(SimplifiedIntervalList, SimplifiedIntervalList, Granularity) - Static method in class com.yahoo.bard.webservice.util.IntervalUtils
Collect all subintervals of an interval list of a grain bucketed size which are subintervals of another supply list of intervals.
collectBucketedIntervalsNotInIntervalList(SimplifiedIntervalList, SimplifiedIntervalList, Granularity) - Static method in class com.yahoo.bard.webservice.data.PartialDataHandler
Collect all subintervals from a bucketed collection that are not subintervals of a supply.
collectFeatureFlags() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Asks for the valid feature flags that are expected to be defined in the system.
collectFeatureFlags(Class<? extends FeatureFlag>...) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Given specific enumeration classes containing feature flags it returns a list with all the valid enumerations.
collectFeatureFlags(List<Class<? extends FeatureFlag>>) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Given a list of enumeration classes containing feature flags it returns a list with all the valid enumerations.
Column - Class in com.yahoo.bard.webservice.table
Column.
Column(String) - Constructor for class com.yahoo.bard.webservice.table.Column
Constructor.
ColumnMapper - Interface in com.yahoo.bard.webservice.data.metric.mappers
Deprecated.
with-like functionality no longer needed because delayed construction is being used instead
Columns - Enum in com.yahoo.bard.webservice.data
A generic, high level enumeration to distinguish between dimensions and metrics.
com.yahoo.bard.webservice - package com.yahoo.bard.webservice
 
com.yahoo.bard.webservice.application - package com.yahoo.bard.webservice.application
 
com.yahoo.bard.webservice.application.healthchecks - package com.yahoo.bard.webservice.application.healthchecks
 
com.yahoo.bard.webservice.async - package com.yahoo.bard.webservice.async
 
com.yahoo.bard.webservice.async.broadcastchannels - package com.yahoo.bard.webservice.async.broadcastchannels
 
com.yahoo.bard.webservice.async.jobs.jobrows - package com.yahoo.bard.webservice.async.jobs.jobrows
 
com.yahoo.bard.webservice.async.jobs.payloads - package com.yahoo.bard.webservice.async.jobs.payloads
 
com.yahoo.bard.webservice.async.jobs.stores - package com.yahoo.bard.webservice.async.jobs.stores
 
com.yahoo.bard.webservice.async.preresponses.stores - package com.yahoo.bard.webservice.async.preresponses.stores
 
com.yahoo.bard.webservice.async.workflows - package com.yahoo.bard.webservice.async.workflows
 
com.yahoo.bard.webservice.config - package com.yahoo.bard.webservice.config
 
com.yahoo.bard.webservice.data - package com.yahoo.bard.webservice.data
 
com.yahoo.bard.webservice.data.cache - package com.yahoo.bard.webservice.data.cache
 
com.yahoo.bard.webservice.data.config - package com.yahoo.bard.webservice.data.config
 
com.yahoo.bard.webservice.data.config.dimension - package com.yahoo.bard.webservice.data.config.dimension
 
com.yahoo.bard.webservice.data.config.metric - package com.yahoo.bard.webservice.data.config.metric
 
com.yahoo.bard.webservice.data.config.metric.makers - package com.yahoo.bard.webservice.data.config.metric.makers
 
com.yahoo.bard.webservice.data.config.names - package com.yahoo.bard.webservice.data.config.names
 
com.yahoo.bard.webservice.data.config.table - package com.yahoo.bard.webservice.data.config.table
 
com.yahoo.bard.webservice.data.dimension - package com.yahoo.bard.webservice.data.dimension
 
com.yahoo.bard.webservice.data.dimension.impl - package com.yahoo.bard.webservice.data.dimension.impl
 
com.yahoo.bard.webservice.data.dimension.metadata - package com.yahoo.bard.webservice.data.dimension.metadata
 
com.yahoo.bard.webservice.data.filterbuilders - package com.yahoo.bard.webservice.data.filterbuilders
 
com.yahoo.bard.webservice.data.metric - package com.yahoo.bard.webservice.data.metric
 
com.yahoo.bard.webservice.data.metric.mappers - package com.yahoo.bard.webservice.data.metric.mappers
 
com.yahoo.bard.webservice.data.time - package com.yahoo.bard.webservice.data.time
 
com.yahoo.bard.webservice.data.volatility - package com.yahoo.bard.webservice.data.volatility
 
com.yahoo.bard.webservice.druid.client - package com.yahoo.bard.webservice.druid.client
 
com.yahoo.bard.webservice.druid.client.impl - package com.yahoo.bard.webservice.druid.client.impl
 
com.yahoo.bard.webservice.druid.model - package com.yahoo.bard.webservice.druid.model
 
com.yahoo.bard.webservice.druid.model.aggregation - package com.yahoo.bard.webservice.druid.model.aggregation
 
com.yahoo.bard.webservice.druid.model.datasource - package com.yahoo.bard.webservice.druid.model.datasource
 
com.yahoo.bard.webservice.druid.model.dimension - package com.yahoo.bard.webservice.druid.model.dimension
 
com.yahoo.bard.webservice.druid.model.dimension.extractionfunction - package com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
 
com.yahoo.bard.webservice.druid.model.filter - package com.yahoo.bard.webservice.druid.model.filter
 
com.yahoo.bard.webservice.druid.model.having - package com.yahoo.bard.webservice.druid.model.having
 
com.yahoo.bard.webservice.druid.model.metadata - package com.yahoo.bard.webservice.druid.model.metadata
 
com.yahoo.bard.webservice.druid.model.orderby - package com.yahoo.bard.webservice.druid.model.orderby
 
com.yahoo.bard.webservice.druid.model.postaggregation - package com.yahoo.bard.webservice.druid.model.postaggregation
 
com.yahoo.bard.webservice.druid.model.query - package com.yahoo.bard.webservice.druid.model.query
 
com.yahoo.bard.webservice.druid.serializers - package com.yahoo.bard.webservice.druid.serializers
 
com.yahoo.bard.webservice.druid.util - package com.yahoo.bard.webservice.druid.util
 
com.yahoo.bard.webservice.exception - package com.yahoo.bard.webservice.exception
 
com.yahoo.bard.webservice.logging - package com.yahoo.bard.webservice.logging
 
com.yahoo.bard.webservice.logging.blocks - package com.yahoo.bard.webservice.logging.blocks
 
com.yahoo.bard.webservice.metadata - package com.yahoo.bard.webservice.metadata
 
com.yahoo.bard.webservice.sql - package com.yahoo.bard.webservice.sql
 
com.yahoo.bard.webservice.sql.aggregation - package com.yahoo.bard.webservice.sql.aggregation
 
com.yahoo.bard.webservice.sql.evaluator - package com.yahoo.bard.webservice.sql.evaluator
 
com.yahoo.bard.webservice.sql.helper - package com.yahoo.bard.webservice.sql.helper
 
com.yahoo.bard.webservice.table - package com.yahoo.bard.webservice.table
 
com.yahoo.bard.webservice.table.availability - package com.yahoo.bard.webservice.table.availability
 
com.yahoo.bard.webservice.table.resolver - package com.yahoo.bard.webservice.table.resolver
 
com.yahoo.bard.webservice.util - package com.yahoo.bard.webservice.util
 
com.yahoo.bard.webservice.web - package com.yahoo.bard.webservice.web
 
com.yahoo.bard.webservice.web.apirequest - package com.yahoo.bard.webservice.web.apirequest
 
com.yahoo.bard.webservice.web.endpoints - package com.yahoo.bard.webservice.web.endpoints
 
com.yahoo.bard.webservice.web.exceptionmappers - package com.yahoo.bard.webservice.web.exceptionmappers
 
com.yahoo.bard.webservice.web.filters - package com.yahoo.bard.webservice.web.filters
 
com.yahoo.bard.webservice.web.handlers - package com.yahoo.bard.webservice.web.handlers
 
com.yahoo.bard.webservice.web.handlers.workflow - package com.yahoo.bard.webservice.web.handlers.workflow
 
com.yahoo.bard.webservice.web.ratelimit - package com.yahoo.bard.webservice.web.ratelimit
 
com.yahoo.bard.webservice.web.responseprocessors - package com.yahoo.bard.webservice.web.responseprocessors
 
com.yahoo.bard.webservice.web.security - package com.yahoo.bard.webservice.web.security
 
com.yahoo.bard.webservice.web.util - package com.yahoo.bard.webservice.web.util
 
com.yahoo.wiki.webservice.application - package com.yahoo.wiki.webservice.application
 
com.yahoo.wiki.webservice.data.config.auto - package com.yahoo.wiki.webservice.data.config.auto
 
com.yahoo.wiki.webservice.data.config.dimension - package com.yahoo.wiki.webservice.data.config.dimension
 
com.yahoo.wiki.webservice.data.config.metric - package com.yahoo.wiki.webservice.data.config.metric
 
com.yahoo.wiki.webservice.data.config.names - package com.yahoo.wiki.webservice.data.config.names
 
com.yahoo.wiki.webservice.data.config.table - package com.yahoo.wiki.webservice.data.config.table
 
combinedDimensions - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
COMMA_AFTER_BRACKET_PATTERN - Static variable in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
COMPARATOR - Static variable in interface com.yahoo.bard.webservice.data.config.names.TableName
Deprecated.
due to name change. Use AS_NAME_COMPARATOR instead.
compare(PhysicalTable, PhysicalTable) - Method in class com.yahoo.bard.webservice.table.resolver.DimensionCardinalityComparator
Compare two Physical Tables based on their number of dimensions.
compare(PhysicalTable, PhysicalTable) - Method in class com.yahoo.bard.webservice.table.resolver.GranularityComparator
Compare two physical tables identifying which one has fewer time buckets.
compare(PhysicalTable, PhysicalTable) - Method in class com.yahoo.bard.webservice.table.resolver.PartialTimeComparator
Compare two Physical Tables based on how much missing time they have.
compare(PhysicalTable, PhysicalTable) - Method in class com.yahoo.bard.webservice.table.resolver.VolatileTimeComparator
Performs a comparison based on how much data each table has within their volatile intervals.
compare(T, T) - Method in class com.yahoo.bard.webservice.util.ChainingComparator
 
compare(Interval, Interval) - Method in class com.yahoo.bard.webservice.util.IntervalStartComparator
 
COMPARE_GRANULARITY - Static variable in class com.yahoo.bard.webservice.table.resolver.DefaultPhysicalTableResolver
 
compareTo(Delayed) - Method in class com.yahoo.bard.webservice.application.SchedulableTask
 
compareTo(DimensionRow) - Method in class com.yahoo.bard.webservice.data.dimension.DimensionRow
 
compareTo(Filter) - Method in class com.yahoo.bard.webservice.logging.blocks.Filter
 
compareTo(LogicalTable) - Method in class com.yahoo.bard.webservice.table.LogicalTable
 
CompletedFuture - Class in com.yahoo.bard.webservice.util
A utility class to create futures which have already been completed and will return as soon as it is called.
ComplexFilter - Interface in com.yahoo.bard.webservice.druid.model.filter
A Druid filter that is defined by applying an operation to at least one other filter.
ConcretePhysicalTableDefinition - Class in com.yahoo.bard.webservice.data.config.table
Holds the fields needed to define a Concrete Physical Table.
ConcretePhysicalTableDefinition(TableName, ZonedTimeGrain, Set<FieldName>, Set<? extends DimensionConfig>) - Constructor for class com.yahoo.bard.webservice.data.config.table.ConcretePhysicalTableDefinition
Define a physical table using a zoned time grain.
ConcretePhysicalTableDefinition(TableName, ZonedTimeGrain, Set<FieldName>, Set<? extends DimensionConfig>, Map<String, String>) - Constructor for class com.yahoo.bard.webservice.data.config.table.ConcretePhysicalTableDefinition
Define a physical table with provided logical to physical column name mappings.
ConcreteSqlPhysicalTableDefinition - Class in com.yahoo.bard.webservice.data.config.table
An implementation of ConcretePhysicalTableDefinition specific to SQL backed datasources.
ConcreteSqlPhysicalTableDefinition(String, String, TableName, ZonedTimeGrain, Set<FieldName>, Set<? extends DimensionConfig>) - Constructor for class com.yahoo.bard.webservice.data.config.table.ConcreteSqlPhysicalTableDefinition
Define a sql backed physical table using a zoned time grain.
ConcreteSqlPhysicalTableDefinition(String, String, TableName, ZonedTimeGrain, Set<FieldName>, Set<? extends DimensionConfig>, Map<String, String>) - Constructor for class com.yahoo.bard.webservice.data.config.table.ConcreteSqlPhysicalTableDefinition
Define a physical table with provided logical to physical column name mappings.
ConfigMessageFormat - Enum in com.yahoo.bard.webservice.config
Formatting messages for the Configuration System.
ConfigPhysicalTable - Interface in com.yahoo.bard.webservice.table
This interface limits direct access to availability to tables intended for use during the configuration lifecycle.
ConfigResourceLoader - Class in com.yahoo.bard.webservice.config
Utilities to help load resources for the system configuration.
ConfigResourceLoader() - Constructor for class com.yahoo.bard.webservice.config.ConfigResourceLoader
 
ConfigurationGraph - Class in com.yahoo.bard.webservice.config
Graph representing a set of module configurations with dependencies mapped by name inside the configuration.
ConfigurationGraph(Map<Configuration, String>, Consumer<String>) - Constructor for class com.yahoo.bard.webservice.config.ConfigurationGraph
Create a configuration graph from a collection of Configuration, resource name pairs and a name validation function.
ConfigurationLoader - Class in com.yahoo.bard.webservice.data.config
Connects the resource dictionaries with the loaders.
ConfigurationLoader(DimensionLoader, MetricLoader, TableLoader) - Constructor for class com.yahoo.bard.webservice.data.config.ConfigurationLoader
Constructor.
ConjunctionDruidFilterBuilder - Class in com.yahoo.bard.webservice.data.filterbuilders
A ConjunctionDruidFilterBuilder builds a Druid filter by taking the conjunction of filter clauses, one for each dimension being filtered on.
ConjunctionDruidFilterBuilder() - Constructor for class com.yahoo.bard.webservice.data.filterbuilders.ConjunctionDruidFilterBuilder
 
ConsolidatingDruidFilterBuilder - Class in com.yahoo.bard.webservice.data.filterbuilders
Builds Dimension filters in a way to keep the size of filter clauses in Druid small.
ConsolidatingDruidFilterBuilder() - Constructor for class com.yahoo.bard.webservice.data.filterbuilders.ConsolidatingDruidFilterBuilder
 
ConstantMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to create a constant value in the post aggregations.
ConstantMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.ConstantMaker
Constructor.
ConstantPostAggregation - Class in com.yahoo.bard.webservice.druid.model.postaggregation
Model representing post aggregations with a constant value.
ConstantPostAggregation(String, double) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.ConstantPostAggregation
Constructor.
ConstrainedTable - Class in com.yahoo.bard.webservice.table
Constrained table caches the results of applying a DataSourceConstraint to a Physical table's availability.
ConstrainedTable(ConfigPhysicalTable, DataSourceConstraint) - Constructor for class com.yahoo.bard.webservice.table.ConstrainedTable
Constructor.
ConstrainedTable(ConfigPhysicalTable, QueryPlanningConstraint) - Constructor for class com.yahoo.bard.webservice.table.ConstrainedTable
Constructor.
containerRequestContext - Variable in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
containsFilterOperation(TreeSet<DimensionRow>, ApiFilter) - Method in interface com.yahoo.bard.webservice.data.dimension.FilterDimensionRows
Contains filter operation.
containsFilterOperation(TreeSet<DimensionRow>, ApiFilter) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
Contains filter operation.
containsKey(Object) - Method in class com.yahoo.bard.webservice.util.DelegatingMap
 
containsLogicalName(String) - Method in class com.yahoo.bard.webservice.table.PhysicalTableSchema
Returns true if the mapping of names is populated for this logical name.
containsValue(Object) - Method in class com.yahoo.bard.webservice.util.DelegatingMap
 
context - Variable in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidQuery
 
contextInitialized(ServletContextEvent) - Method in class com.yahoo.bard.webservice.application.MetricServletContextListener
 
contextMap - Variable in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
convert(Dimension, DimensionField) - Method in interface com.yahoo.bard.webservice.data.dimension.DimensionFieldNameMapper
A converter function for the dimension field Mapping.
copy() - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Exports a snapshot of the request log of the current thread without resetting the request log for that thread.
CORSPreflightServlet - Class in com.yahoo.bard.webservice.web.endpoints
Class to handle Preflighted requests.
CORSPreflightServlet() - Constructor for class com.yahoo.bard.webservice.web.endpoints.CORSPreflightServlet
 
COUNT_FIELD_OUTER - Static variable in class com.yahoo.bard.webservice.data.config.metric.makers.AggregationAverageMaker
 
COUNT_INNER - Static variable in class com.yahoo.bard.webservice.data.config.metric.makers.AggregationAverageMaker
 
COUNT_OUTER - Static variable in class com.yahoo.bard.webservice.data.config.metric.makers.AggregationAverageMaker
 
CountAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Aggregation for counts.
CountAggregation(String) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.CountAggregation
Constructor.
CountMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to count rows that match the filters.
CountMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.CountMaker
Constructor.
countSlicedIntervals(Collection<Interval>, Granularity) - Static method in class com.yahoo.bard.webservice.util.IntervalUtils
Count the intervals after simplifying raw intervals and splitting by grain.
create(DataApiRequest) - Static method in class com.yahoo.bard.webservice.table.TableIdentifier
Builder.
createChunk(T) - Method in class com.yahoo.bard.webservice.druid.model.metadata.NumberedShardSpec
 
createEmptyDimensionRow(String) - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Create an empty DimensionRow for this dimension.
createEmptyDimensionRow(String) - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
createNewRateLimitRequestToken(AtomicInteger, String, boolean, int, Meter, Meter) - Method in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
Creates a new RateLimitRequestToken.
createParentDirectories(String) - Static method in class com.yahoo.bard.webservice.util.Utils
Create parent directories if they don't exist in a given file path.
CsvResponse<T> - Class in com.yahoo.bard.webservice.web
Formats data of a response as CSV.
CsvResponse(Stream<T>, Pagination<?>, UriInfo, List<String>, ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.CsvResponse
Constructor.
CsvResponseWriter - Class in com.yahoo.bard.webservice.web
Serializer for CSV format.
CsvResponseWriter(ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.CsvResponseWriter
Constructor.
CurrentMacroCalculation - Class in com.yahoo.bard.webservice.web
A Class to compute the current DateTime for the current macro.
CurrentMacroCalculation() - Constructor for class com.yahoo.bard.webservice.web.CurrentMacroCalculation
 

D

DataApiRequest - Interface in com.yahoo.bard.webservice.web.apirequest
DataApiRequest Request binds, validates, and models the parts of a request to the data endpoint.
DataApiRequestFactory - Interface in com.yahoo.bard.webservice.web.apirequest
Layer of injection to provide preprocessing of BardConfig in response to request parameters and transformation of request parameters before performing binding in the ApiRequest constructors.
DataApiRequestImpl - Class in com.yahoo.bard.webservice.web.apirequest
Data API Request Implementation binds, validates, and models the parts of a request to the data endpoint.
DataApiRequestImpl(String, String, List<PathSegment>, String, String, String, String, String, String, String, String, String, String, String, String, UriInfo, BardConfigResources) - Constructor for class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Parses the API request URL and generates the Api Request object.
DataApiRequestImpl(String, String, List<PathSegment>, String, String, String, String, String, String, String, String, String, String, String, String, UriInfo, DimensionDictionary, MetricDictionary, LogicalTableDictionary, DateTimeZone, GranularityParser, DruidFilterBuilder, HavingGenerator) - Constructor for class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Parses the API request URL and generates the Api Request object.
DataApiRequestImpl(ResponseFormatType, Optional<PaginationParameters>, UriInfo, Response.ResponseBuilder, LogicalTable, Granularity, Set<Dimension>, LinkedHashMap<Dimension, LinkedHashSet<DimensionField>>, Set<LogicalMetric>, Set<Interval>, ApiFilters, Map<LogicalMetric, Set<ApiHaving>>, Having, LinkedHashSet<OrderByColumn>, int, int, long, DateTimeZone, DruidFilterBuilder, HavingGenerator, Optional<OrderByColumn>) - Constructor for class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
All argument constructor, meant to be used for rewriting apiRequest.
DataApiRequestMapperUtils - Class in com.yahoo.bard.webservice.web.security
A set of methods for generating utility mappers for ApiRequestMapping chains.
DataApiRequestMapperUtils() - Constructor for class com.yahoo.bard.webservice.web.security.DataApiRequestMapperUtils
 
DataApiRequestTypeIdentifier - Class in com.yahoo.bard.webservice.web
Identifies the type of API request (UI, bypass, CORS pre-flight).
DataApiRequestTypeIdentifier() - Constructor for class com.yahoo.bard.webservice.web.DataApiRequestTypeIdentifier
 
DATABASE_DRIVER - Static variable in class com.yahoo.bard.webservice.web.handlers.SqlRequestHandler
 
DATABASE_PASSWORD - Static variable in class com.yahoo.bard.webservice.web.handlers.SqlRequestHandler
 
DATABASE_URL - Static variable in class com.yahoo.bard.webservice.web.handlers.SqlRequestHandler
 
DATABASE_USERNAME - Static variable in class com.yahoo.bard.webservice.web.handlers.SqlRequestHandler
 
DataCache<T extends Serializable> - Interface in com.yahoo.bard.webservice.data.cache
A very thin wrapper around key value storage.
dataCache - Variable in class com.yahoo.bard.webservice.web.handlers.CacheRequestHandler
 
dataCache - Variable in class com.yahoo.bard.webservice.web.handlers.CacheV2RequestHandler
 
dataCache - Variable in class com.yahoo.bard.webservice.web.handlers.EtagCacheRequestHandler
 
dataCache - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
dataCache - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
DataEntry(String, T, V) - Constructor for class com.yahoo.bard.webservice.data.cache.MemTupleDataCache.DataEntry
Constructor.
DataRequest - Class in com.yahoo.bard.webservice.logging.blocks
Corresponds mainly to the requesting part of a request served by the DataServlet.
DataRequest(LogicalTable, Set<Interval>, Collection<Set<ApiFilter>>, Set<LogicalMetric>, Set<Dimension>, Set<String>, boolean, String) - Constructor for class com.yahoo.bard.webservice.logging.blocks.DataRequest
Constructor.
DataRequestHandler - Interface in com.yahoo.bard.webservice.web.handlers
Data Request Handlers are links in a processing chain for Data requests.
DataServlet - Class in com.yahoo.bard.webservice.web.endpoints
Data Servlet responds to the data endpoint which allows for data query requests to the Druid brokers/router.
DataServlet(ResourceDictionaries, DruidQueryBuilder, TemplateDruidQueryMerger, DruidResponseParser, RequestWorkflowProvider, RequestMapper, ObjectMappersSuite, DruidFilterBuilder, HavingGenerator, GranularityParser, JobPayloadBuilder, JobRowBuilder, AsynchronousWorkflowsBuilder, BroadcastChannel<String>, HttpResponseMaker, ResponseFormatResolver, DataApiRequestFactory, ResponseProcessorFactory) - Constructor for class com.yahoo.bard.webservice.web.endpoints.DataServlet
Constructor.
DataSource - Class in com.yahoo.bard.webservice.druid.model.datasource
DataSource base class.
DataSource(DataSourceType, ConstrainedTable) - Constructor for class com.yahoo.bard.webservice.druid.model.datasource.DataSource
Constructor.
dataSource - Variable in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidQuery
 
DATASOURCE_METADATA_QUERY_FORMAT - Static variable in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
 
DataSourceConfiguration - Interface in com.yahoo.wiki.webservice.data.config.auto
Holds the minimum necessary configuration to set up fili to make requests to druid.
DataSourceConstraint - Class in com.yahoo.bard.webservice.table.resolver
Constraints for retrieving potential table availability for a given query.
DataSourceConstraint(DataApiRequest, DruidAggregationQuery<?>) - Constructor for class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
Constructor.
DataSourceConstraint(Set<Dimension>, Set<Dimension>, Set<Dimension>, Set<String>, ApiFilters) - Constructor for class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
Constructor.
DataSourceConstraint(Set<Dimension>, Set<Dimension>, Set<Dimension>, Set<String>, Set<Dimension>, Set<String>, Set<String>, ApiFilters) - Constructor for class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
Deprecated.
"allDimensions", "allDimensionNames", and "allColumnNames" can be generated by other arguments. Use DataSourceConstraint.DataSourceConstraint(Set, Set, Set, Set, ApiFilters) instead, which saves caller argument-passing efforts.
DataSourceConstraint(DataSourceConstraint) - Constructor for class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
Copy Constructor.
DataSourceFilter - Interface in com.yahoo.bard.webservice.table.resolver
A function which filters based on a data source constraint.
DataSourceMetadata - Class in com.yahoo.bard.webservice.metadata
The segment metadata from a particular physical table/druid data source.
DataSourceMetadata(String, Map<String, String>, List<DataSegment>) - Constructor for class com.yahoo.bard.webservice.metadata.DataSourceMetadata
Store the full metadata for a druid data source, mainly as a list of segments.
DataSourceMetadataLoaderHealthCheck - Class in com.yahoo.bard.webservice.application.healthchecks
Check to verify if the loader runs as scheduled.
DataSourceMetadataLoaderHealthCheck(DataSourceMetadataLoadTask, long) - Constructor for class com.yahoo.bard.webservice.application.healthchecks.DataSourceMetadataLoaderHealthCheck
Creates a health check for a datasource metadata loader.
DataSourceMetadataLoadTask - Class in com.yahoo.bard.webservice.metadata
Datasource metadata loader sends requests to the druid datasource metadata endpoint ('datasources') and returns the lists of available data segments for each datasource.
DataSourceMetadataLoadTask(PhysicalTableDictionary, DataSourceMetadataService, DruidWebService, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
Datasource metadata loader fetches data from the druid coordinator and updates the datasource metadata service.
DataSourceMetadataService - Class in com.yahoo.bard.webservice.metadata
Defines a wrapper class around the container that holds the segment metadata of all the physical tables.
DataSourceMetadataService() - Constructor for class com.yahoo.bard.webservice.metadata.DataSourceMetadataService
Creates a service to store segment metadata.
DataSourceName - Interface in com.yahoo.bard.webservice.data.config.names
Marker interface for objects that can be treated as a data source name in druid.
dataSources - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
DataSourceType - Interface in com.yahoo.bard.webservice.druid.model.datasource
Interface for types of DataSources.
DATE_TIME_STRING - Static variable in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
DateTimeFormatterFactory - Class in com.yahoo.bard.webservice.util
Holder for the system-wide date-time formatters.
DateTimeFormatterFactory() - Constructor for class com.yahoo.bard.webservice.util.DateTimeFormatterFactory
 
DateTimeSortMapper - Class in com.yahoo.bard.webservice.data.metric.mappers
Mapper to sort the result set based on dateTime column sort direction.
DateTimeSortMapper(SortDirection) - Constructor for class com.yahoo.bard.webservice.data.metric.mappers.DateTimeSortMapper
Constructor.
DateTimeSortRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Injects the result set mapper for dateTime based sort request.
DateTimeSortRequestHandler(DataRequestHandler) - Constructor for class com.yahoo.bard.webservice.web.handlers.DateTimeSortRequestHandler
Constructor.
DateTimeUtils - Class in com.yahoo.bard.webservice.util
Util functions to perform operations on JodaTime objects.
DateTimeUtils() - Constructor for class com.yahoo.bard.webservice.util.DateTimeUtils
 
DebugRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Handler to return debugging of the request query without sending to druid.
DebugRequestHandler(DataRequestHandler, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.DebugRequestHandler
Build a debugging handler.
decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class com.yahoo.bard.webservice.application.TaskScheduler
 
decorateTask(Callable<V>, RunnableScheduledFuture<V>) - Method in class com.yahoo.bard.webservice.application.TaskScheduler
 
DEFAULT_CATEGORY - Static variable in interface com.yahoo.bard.webservice.data.dimension.Dimension
 
DEFAULT_CATEGORY - Static variable in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
DEFAULT_CATEGORY - Static variable in class com.yahoo.bard.webservice.table.LogicalTable
 
DEFAULT_CLASS_TYPE - Static variable in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
DEFAULT_DRUID_TOP_N_THRESHOLD - Static variable in class com.yahoo.bard.webservice.druid.model.query.WeightEvaluationQuery
 
DEFAULT_JSON_NODE_BUILDER_STRATEGY - Static variable in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
The default JSON builder puts only response body in the JSON response.
DEFAULT_KILOBYTES_PER_SKETCH - Static variable in class com.yahoo.wiki.webservice.data.config.metric.WikiMetricLoader
 
DEFAULT_REQUEST_LIMIT_GLOBAL - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
DEFAULT_REQUEST_LIMIT_PER_USER - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
DEFAULT_REQUEST_LIMIT_UI - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
DEFAULT_RETENTION - Static variable in class com.yahoo.bard.webservice.table.LogicalTable
 
DEFAULT_SECURITY_MESSAGE - Static variable in class com.yahoo.bard.webservice.web.security.RoleDimensionApiFilterRequestMapper
 
DEFAULT_SKETCH_SIZE_IN_BYTES - Static variable in class com.yahoo.wiki.webservice.data.config.metric.WikiMetricLoader
 
DefaultAsynchronousWorkflowsBuilder - Class in com.yahoo.bard.webservice.async.workflows
Builds an Asynchronous process that only saves the results of a query if the query is asynchronous.
DefaultAsynchronousWorkflowsBuilder(ApiJobStore, PreResponseStore, Clock) - Constructor for class com.yahoo.bard.webservice.async.workflows.DefaultAsynchronousWorkflowsBuilder
A factory for constructing the asynchronous response building workflow.
DefaultDataApiRequestFactory - Class in com.yahoo.bard.webservice.web.apirequest
An implementation of DataApiRequestFactory that does not modify the initial parameters at all.
DefaultDataApiRequestFactory() - Constructor for class com.yahoo.bard.webservice.web.apirequest.DefaultDataApiRequestFactory
 
DefaultDataSourceType - Enum in com.yahoo.bard.webservice.druid.model.datasource
Legal data source types in Druid.
DefaultDimensionField - Enum in com.yahoo.bard.webservice.data.config.dimension
DimensionField enum.
DefaultDimensionFieldTag - Enum in com.yahoo.bard.webservice.data.dimension.impl
Default dimension field tag provided to match fili core concepts.
DefaultDimensionSpec - Class in com.yahoo.bard.webservice.druid.model.dimension
The Default type DimensionSpec.
DefaultDimensionSpec(String, String) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.DefaultDimensionSpec
Constructor.
DefaultDruidFilterBuilder - Class in com.yahoo.bard.webservice.data.filterbuilders
A DefaultDruidFilterBuilder builds a conjunction of disjunctions for each Dimension, where each disjunction corresponds to a filter term.
DefaultDruidFilterBuilder() - Constructor for class com.yahoo.bard.webservice.data.filterbuilders.DefaultDruidFilterBuilder
 
DefaultHavingApiGenerator - Class in com.yahoo.bard.webservice.web.apirequest
Generates having objects based on the having query in the api request.
DefaultHavingApiGenerator(ConfigurationLoader) - Constructor for class com.yahoo.bard.webservice.web.apirequest.DefaultHavingApiGenerator
Constructor.
DefaultHavingApiGenerator(Map<String, LogicalMetric>) - Constructor for class com.yahoo.bard.webservice.web.apirequest.DefaultHavingApiGenerator
Constructor.
DefaultingDictionary<K,V> - Class in com.yahoo.bard.webservice.util
DefaultingDictionary is a Map that returns a default value if a given key is not present in the map, or returns the value associated with the given key.
DefaultingDictionary(V) - Constructor for class com.yahoo.bard.webservice.util.DefaultingDictionary
Construct the defaultingDictionary using the defaultValue provided.
DefaultingDictionary(V, Map<K, V>) - Constructor for class com.yahoo.bard.webservice.util.DefaultingDictionary
Construct DefaultingDictionary using the given defaultValue and entries from the given defaultingDictionaryMap.
DefaultingVolatileIntervalsService - Class in com.yahoo.bard.webservice.data.volatility
An implementation of VolatileIntervalsService.
DefaultingVolatileIntervalsService() - Constructor for class com.yahoo.bard.webservice.data.volatility.DefaultingVolatileIntervalsService
Use the no op interval function with no customized functions.
DefaultingVolatileIntervalsService(VolatileIntervalsFunction) - Constructor for class com.yahoo.bard.webservice.data.volatility.DefaultingVolatileIntervalsService
Use a single default function for all physical tables.
DefaultingVolatileIntervalsService(DefaultingDictionary<PhysicalTable, VolatileIntervalsFunction>) - Constructor for class com.yahoo.bard.webservice.data.volatility.DefaultingVolatileIntervalsService
Deprecated.
Simply use maps and default values
DefaultingVolatileIntervalsService(VolatileIntervalsFunction, Map<PhysicalTable, VolatileIntervalsFunction>) - Constructor for class com.yahoo.bard.webservice.data.volatility.DefaultingVolatileIntervalsService
Use a default function with overrides for particular tables.
DefaultJobField - Enum in com.yahoo.bard.webservice.async.jobs.jobrows
The default fields for job metadata.
DefaultJobPayloadBuilder - Class in com.yahoo.bard.webservice.async.jobs.payloads
The default implementation of JobPayloadBuilder using DefaultJobField to generate the job payload to be returned to the user.
DefaultJobPayloadBuilder() - Constructor for class com.yahoo.bard.webservice.async.jobs.payloads.DefaultJobPayloadBuilder
 
DefaultJobRowBuilder - Class in com.yahoo.bard.webservice.async.jobs.jobrows
A JobRowBuilder that populates a JobRow with the information for all the job fields defined in DefaultJobField.
DefaultJobRowBuilder(Function<Map<JobField, String>, String>, Function<SecurityContext, String>, Clock) - Constructor for class com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobRowBuilder
Builds a factory for generating JobRows with a custom function for extracting a userid from a request's SecurityContext.
DefaultJobRowBuilder(Function<Map<JobField, String>, String>) - Constructor for class com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobRowBuilder
Builds a factory for generating JobRows containing values for every DefaultJobField.
DefaultJobStatus - Enum in com.yahoo.bard.webservice.async.jobs.jobrows
Provides an enumeration of the standard job statuses that Bard supports.
DefaultKeyValueStoreDimensionConfig - Class in com.yahoo.bard.webservice.data.config.dimension
A Default Key Value Store Dimension holds all of the information needed to construct a Dimension.
DefaultKeyValueStoreDimensionConfig(DimensionName, String, String, String, String, LinkedHashSet<DimensionField>, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider) - Constructor for class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
Construct a DefaultKeyValueStoreDimensionConfig instance from dimension name, dimension fields and default dimension fields.
DefaultKeyValueStoreDimensionConfig(DimensionName, String, String, String, String, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider) - Constructor for class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
Construct a DefaultKeyValueStoreDimensionConfig instance from dimension name and only using default dimension fields.
DefaultLookupDimensionConfig - Class in com.yahoo.bard.webservice.data.config.dimension
A Default Lookup Dimension holds all of the information needed to construct a Lookup Dimension.
DefaultLookupDimensionConfig(DimensionName, String, String, String, String, LinkedHashSet<DimensionField>, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider, List<String>) - Constructor for class com.yahoo.bard.webservice.data.config.dimension.DefaultLookupDimensionConfig
Construct a LookupDefaultDimensionConfig instance from dimension name, dimension fields and default dimension fields.
DefaultLookupDimensionConfig(DimensionName, String, String, String, String, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider, List<String>) - Constructor for class com.yahoo.bard.webservice.data.config.dimension.DefaultLookupDimensionConfig
Construct a LookupDefaultDimensionConfig instance from dimension name and only using default dimension fields.
DefaultPhysicalTableResolver - Class in com.yahoo.bard.webservice.table.resolver
A physical table resolver which implements core bard filters and comparator functions
DefaultPhysicalTableResolver(PartialDataHandler, VolatileIntervalsService) - Constructor for class com.yahoo.bard.webservice.table.resolver.DefaultPhysicalTableResolver
Constructor.
DefaultQueryType - Enum in com.yahoo.bard.webservice.druid.model
Druid queries that Fili supports out of the box.
DefaultRateLimiter - Class in com.yahoo.bard.webservice.web.ratelimit
This is the default implementation of a rate limiter.
DefaultRateLimiter() - Constructor for class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
Loads defaults and creates DefaultRateLimiter.
DefaultRegisteredLookupDimensionConfig - Class in com.yahoo.bard.webservice.data.config.dimension
A Default Registered Lookup Dimension holds all of the information needed to construct a Registered Lookup Dimension.
DefaultRegisteredLookupDimensionConfig(DimensionName, String, String, String, String, LinkedHashSet<DimensionField>, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider, List<String>) - Constructor for class com.yahoo.bard.webservice.data.config.dimension.DefaultRegisteredLookupDimensionConfig
Construct a RegisteredLookupDefaultDimensionConfig instance from dimension name , dimension fields and default dimension fields.
DefaultRegisteredLookupDimensionConfig(DimensionName, String, String, String, String, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider, List<String>) - Constructor for class com.yahoo.bard.webservice.data.config.dimension.DefaultRegisteredLookupDimensionConfig
Construct a RegisteredLookupDefaultDimensionConfig instance from Dimension Name , and only using default dimension fields.
DefaultResponseFormatResolver - Class in com.yahoo.bard.webservice.web
A Fili default implementation of ResponseFormatResolver.
DefaultResponseFormatResolver() - Constructor for class com.yahoo.bard.webservice.web.DefaultResponseFormatResolver
Constructor.
DefaultSearchQueryType - Enum in com.yahoo.bard.webservice.druid.model.query
Enum for specifying the type of SearchQuerySpec.
DefaultSearchSortDirection - Enum in com.yahoo.bard.webservice.druid.model.orderby
Default implementation for SearchSortDirection.
DefaultSqlAggregationType - Enum in com.yahoo.bard.webservice.sql.aggregation
All the default aggregation types supported for use with a sql backend.
DefaultSqlBackedClient - Class in com.yahoo.bard.webservice.sql
Converts druid queries to sql, executes it, and returns a druid like response.
DefaultSqlBackedClient(DataSource, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.sql.DefaultSqlBackedClient
Creates a sql converter using the given database and datasource.
DefaultSqlBackedClient(String, String, String, String, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.sql.DefaultSqlBackedClient
Creates a sql converter using the given database and datasource.
DefaultTimeGrain - Enum in com.yahoo.bard.webservice.data.time
DefaultTimeGrain are a set of concrete TimeGrain implementations which support 'natural', simple to describe time blocks corresponding to standard rounding rules.
defaultTimeZone - Variable in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
 
DefaultWebServiceHandlerSelector - Class in com.yahoo.bard.webservice.web.handlers
A no-op web service selector.
DefaultWebServiceHandlerSelector(DruidWebService, DataRequestHandler) - Constructor for class com.yahoo.bard.webservice.web.handlers.DefaultWebServiceHandlerSelector
Constructor.
delay - Variable in class com.yahoo.bard.webservice.application.LoadTask
 
DelegatingMap<K,V> - Class in com.yahoo.bard.webservice.util
A delegating map has a local copy (self) of keys and values and a next map to which it delegates lookups for values which it doesn't contain.
DelegatingMap() - Constructor for class com.yahoo.bard.webservice.util.DelegatingMap
Constructor.
DelegatingMap(Map<K, V>) - Constructor for class com.yahoo.bard.webservice.util.DelegatingMap
Constructor.
deleteAllDimensionRows() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
Internal method for cleaning the dimension rows.
deleteDataCache() - Method in class com.yahoo.bard.webservice.web.endpoints.DimensionCacheLoaderServlet
clears cache.
deleteFiles(String) - Static method in class com.yahoo.bard.webservice.util.Utils
Delete files or directories in the specified path.
DEPENDENT_MODULE_KEY - Static variable in class com.yahoo.bard.webservice.config.ConfigurationGraph
The special property which identifies dependent modules.
DEPRECATED_PERMISSIVE_AVAILABILITY_FLAG - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
depth() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Returns the depth of the query nesting.
DeserializationException - Exception in com.yahoo.bard.webservice.data
Exception during deserialization.
DeserializationException(String) - Constructor for exception com.yahoo.bard.webservice.data.DeserializationException
Constructor.
DeserializationException(Throwable) - Constructor for exception com.yahoo.bard.webservice.data.DeserializationException
Constructor.
DeserializationException(String, Throwable) - Constructor for exception com.yahoo.bard.webservice.data.DeserializationException
Constructor.
deserialize(String) - Method in class com.yahoo.bard.webservice.data.PreResponseDeserializer
Deserialize the custom serialized PreResponse.
dictionaries - Variable in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
 
dimension - Variable in class com.yahoo.bard.webservice.data.config.ResourceDictionaries
 
Dimension - Interface in com.yahoo.bard.webservice.data.dimension
Dimension interface.
dimension - Variable in class com.yahoo.bard.webservice.logging.blocks.DimensionRequest
 
dimension - Variable in class com.yahoo.bard.webservice.logging.blocks.Filter
 
DIMENSION_FIELD_COLUMN_NAMES - Static variable in class com.yahoo.bard.webservice.web.ResponseData
 
DIMENSION_VALUES_KEY - Static variable in class com.yahoo.bard.webservice.data.ResultSerializationProxy
 
DimensionalFilter<T extends DimensionalFilter<? super T>> - Class in com.yahoo.bard.webservice.druid.model.filter
Filter for matching a dimension.
DimensionalFilter(Dimension, FilterType) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.DimensionalFilter
Constructor, default extraction function to the one on dimension if it has one.
DimensionalFilter(Dimension, FilterType, ExtractionFunction) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.DimensionalFilter
Constructor, with explicit extraction function provided.
DimensionApiRequestMapper - Class in com.yahoo.bard.webservice.web
Default RequestMapper implementation for DimensionApiRequests.
DimensionApiRequestMapper(ResourceDictionaries) - Constructor for class com.yahoo.bard.webservice.web.DimensionApiRequestMapper
Constructor.
DimensionCacheLoaderServlet - Class in com.yahoo.bard.webservice.web.endpoints
Web service endpoint to update the Dimension rows and dimension lastUpdated field.
DimensionCacheLoaderServlet(DimensionDictionary, DataCache<?>, ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.endpoints.DimensionCacheLoaderServlet
Constructor.
DimensionCardinalityComparator - Class in com.yahoo.bard.webservice.table.resolver
Comparator to prefer fewer dimensions in physical tables (for the purpose of preferring fewer rows).
DimensionCardinalityComparator() - Constructor for class com.yahoo.bard.webservice.table.resolver.DimensionCardinalityComparator
 
DimensionColumn - Class in com.yahoo.bard.webservice.data.dimension
Result DimensionColumn definition.
DimensionColumn(Dimension) - Constructor for class com.yahoo.bard.webservice.data.dimension.DimensionColumn
Constructor.
DimensionColumn(Dimension, String) - Constructor for class com.yahoo.bard.webservice.data.dimension.DimensionColumn
Deprecated.
LogicalDimensionColumn is the only caller of this, and since it's deprecated, so is this constructor
DimensionConfig - Interface in com.yahoo.bard.webservice.data.config.dimension
Defines the core information needed to define a dimension.
DimensionDictionary - Class in com.yahoo.bard.webservice.data.dimension
Dimension dictionary.
DimensionDictionary() - Constructor for class com.yahoo.bard.webservice.data.dimension.DimensionDictionary
Constructor.
DimensionDictionary(Set<Dimension>) - Constructor for class com.yahoo.bard.webservice.data.dimension.DimensionDictionary
Constructor.
dimensionDictionary - Variable in class com.yahoo.bard.webservice.data.HttpResponseMaker
 
dimensionExistsInDataSource(Dimension, DataSource) - Method in interface com.yahoo.bard.webservice.application.DimensionValueLoader
Checks if a Dimension exists in a DataSource.
DimensionField - Interface in com.yahoo.bard.webservice.data.dimension
Dimension field.
DimensionFieldNameMapper - Interface in com.yahoo.bard.webservice.data.dimension
Maps a Dimension Field value to a string.
DimensionFieldSpecifierKeywords - Enum in com.yahoo.bard.webservice.web
Keywords for the "show" clause in the API.
DimensionIdFilter - Class in com.yahoo.bard.webservice.table.resolver
An implementation of DataSourceFilter which uses dimensionApiFilters to match partition data sources.
DimensionIdFilter(Map<Dimension, Set<String>>) - Constructor for class com.yahoo.bard.webservice.table.resolver.DimensionIdFilter
Constructor.
DimensionListPartitionTableDefinition - Class in com.yahoo.bard.webservice.data.config.table
Holds the fields needed to define a partition physical table.
DimensionListPartitionTableDefinition(TableName, ZonedTimeGrain, Set<FieldName>, Set<? extends DimensionConfig>, Map<TableName, Map<String, Set<String>>>) - Constructor for class com.yahoo.bard.webservice.data.config.table.DimensionListPartitionTableDefinition
Constructor.
dimensionLoader - Variable in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
 
DimensionLoader - Interface in com.yahoo.bard.webservice.data.config.dimension
Defines the core interactions for loading dimensions into a dimension dictionary.
DimensionName - Interface in com.yahoo.bard.webservice.data.config.names
Defines the logical name of a Dimension as used in the api query.
DimensionRequest - Class in com.yahoo.bard.webservice.logging.blocks
Main log of a request served by the DimensionsServlet.
DimensionRequest(String, String) - Constructor for class com.yahoo.bard.webservice.logging.blocks.DimensionRequest
Constructor.
DimensionRow - Class in com.yahoo.bard.webservice.data.dimension
DimensionRow is the model for a row in a Dimension lookup table.
DimensionRow(DimensionField, Map<DimensionField, String>) - Constructor for class com.yahoo.bard.webservice.data.dimension.DimensionRow
Build a dimension row with a key field value and a map of field values.
DimensionRowNotFoundException - Exception in com.yahoo.bard.webservice.data.dimension
Exception when a dimension row is not found.
DimensionRowNotFoundException(String) - Constructor for exception com.yahoo.bard.webservice.data.dimension.DimensionRowNotFoundException
Constructor that accepts a message.
dimensions - Variable in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidAggregationQuery
 
DimensionsApiRequest - Interface in com.yahoo.bard.webservice.web.apirequest
Dimensions API Request.
DimensionsApiRequestImpl - Class in com.yahoo.bard.webservice.web.apirequest
Dimension API Request Implementation binds, validates, and models the parts of a request to the dimension endpoint.
DimensionsApiRequestImpl(String, String, String, String, String, DimensionDictionary, UriInfo) - Constructor for class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
Parses the API request URL and generates the Api Request object.
DimensionSpec - Class in com.yahoo.bard.webservice.druid.model.dimension
Base class model for DimensionSpecs.
DimensionSpec(DimensionSpecType) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.DimensionSpec
Constructor.
DimensionSpec.DefaultDimensionSpecType - Enum in com.yahoo.bard.webservice.druid.model.dimension
Enumaration of possible DimensionSpec types.
DimensionSpecType - Interface in com.yahoo.bard.webservice.druid.model.dimension
An interface for DimensionSpec types.
DimensionsServlet - Class in com.yahoo.bard.webservice.web.endpoints
Resource code for dimension resource endpoints.
DimensionsServlet(DimensionDictionary, LogicalTableDictionary, RequestMapper, ObjectMappersSuite, ResponseFormatResolver) - Constructor for class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Constructor.
DimensionStoreKeyUtils - Class in com.yahoo.bard.webservice.util
Provider for magic strings used in dimension keystore key generation.
DimensionStoreKeyUtils() - Constructor for class com.yahoo.bard.webservice.util.DimensionStoreKeyUtils
 
DimensionToDefaultDimensionSpec - Class in com.yahoo.bard.webservice.druid.serializers
Serializer to map Dimensions to DimensionSpec or api name for Abstract Druid Fact Queries.
DimensionToDefaultDimensionSpec() - Constructor for class com.yahoo.bard.webservice.druid.serializers.DimensionToDefaultDimensionSpec
 
DimensionToNameSerializer - Class in com.yahoo.bard.webservice.druid.serializers
Serializer to map Dimensions to Physical names for Abstract Druid Fact Queries.
DimensionToNameSerializer() - Constructor for class com.yahoo.bard.webservice.druid.serializers.DimensionToNameSerializer
 
DimensionUpdateDate - Class in com.yahoo.bard.webservice.data.dimension
The model object for the Json DimensionUpdateDate data.
DimensionUpdateDate(String) - Constructor for class com.yahoo.bard.webservice.data.dimension.DimensionUpdateDate
A constructor used to capture dimension update dates.
DimensionUpdateDate(String, DateTime) - Constructor for class com.yahoo.bard.webservice.data.dimension.DimensionUpdateDate
A constructor for use by the web service client to build data objects carrying data from the web service.
DimensionValueLoader - Interface in com.yahoo.bard.webservice.application
The DimensionValueLoader provides a way to update dimension values.
DimensionValueLoadTask - Class in com.yahoo.bard.webservice.application
DimensionLoaderTask takes a collection of DimensionValueLoader to update the values for dimensions.
DimensionValueLoadTask(Collection<DimensionValueLoader>) - Constructor for class com.yahoo.bard.webservice.application.DimensionValueLoadTask
DimensionLoaderTask tells all of the DimensionValueLoaders to update and add values to the dimension cache.
DISABLED_RATE - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
dispatch(Throwable) - Method in interface com.yahoo.bard.webservice.druid.client.FailureCallback
Stop the request timer, start the response timer, and then invoke the failure callback code.
dispatch(int, String, String) - Method in interface com.yahoo.bard.webservice.druid.client.HttpErrorCallback
Stop the request timer, start the response timer, and then invoke the error callback code.
DoubleMaxAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Aggregation for the maximum of doubles.
DoubleMaxAggregation(String, String) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.DoubleMaxAggregation
Constructor.
DoubleMaxMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to get the max of double metrics.
DoubleMaxMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.DoubleMaxMaker
Constructor.
DoubleMinAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Aggregation for the minimum of doubles.
DoubleMinAggregation(String, String) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.DoubleMinAggregation
Constructor.
DoubleMinMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to get the min of double metrics.
DoubleMinMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.DoubleMinMaker
Constructor.
DoubleSumAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Aggregation for the sum of doubles.
DoubleSumAggregation(String, String) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.DoubleSumAggregation
Constructor.
DoubleSumMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to sum over numeric metrics.
DoubleSumMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.DoubleSumMaker
Constructor.
DRUID_DIM_LOADER_DIMENSIONS - Static variable in class com.yahoo.bard.webservice.application.DruidDimensionValueLoader
 
DRUID_DIM_LOADER_HC_LAST_RUN_PERIOD_MILLIS - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
DRUID_DIM_LOADER_ROW_LIMIT - Static variable in class com.yahoo.bard.webservice.application.DruidDimensionValueLoader
 
DRUID_QUERY_ALL_TIMER - Static variable in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
DRUID_QUERY_MAX_TIMER - Static variable in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
DRUID_QUERY_TIMER - Static variable in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
DRUID_SEG_LOADER_TIMER_DELAY_KEY - Static variable in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
Parameter specifying the delay before the first run of the segment metadata loader, in milliseconds.
DRUID_SEG_LOADER_TIMER_DURATION_KEY - Static variable in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
Parameter specifying the period of the segment metadata loader, in milliseconds.
DRUID_SEGMENT_METADATA_TIMER - Static variable in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
DRUID_TIMER - Static variable in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
DRUID_UNCOVERED_INTERVAL_LIMIT - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
DRUID_WEIGHTED_QUERY_TIMER - Static variable in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
DruidAggregationQuery<Q extends DruidAggregationQuery<? super Q>> - Interface in com.yahoo.bard.webservice.druid.model.query
Common interface for Druid Query classes.
DruidClientConfigHelper - Class in com.yahoo.bard.webservice.druid.client
Helper to fetch druid url and timeout settings.
DruidClientConfigHelper() - Constructor for class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
 
DruidDimensionsLoaderHealthCheck - Class in com.yahoo.bard.webservice.application.healthchecks
Check to verify if the loader runs as scheduled.
DruidDimensionsLoaderHealthCheck(DimensionValueLoadTask, long) - Constructor for class com.yahoo.bard.webservice.application.healthchecks.DruidDimensionsLoaderHealthCheck
Constructor.
DruidDimensionValueLoader - Class in com.yahoo.bard.webservice.application
The DruidDimensionRowProvider sends requests to the druid search query interface to get a list of dimension values to add to the dimension cache.
DruidDimensionValueLoader(PhysicalTableDictionary, DimensionDictionary, DruidWebService) - Constructor for class com.yahoo.bard.webservice.application.DruidDimensionValueLoader
DruidDimensionRowProvider fetches data from Druid and adds it to the dimension cache.
DruidDimensionValueLoader(PhysicalTableDictionary, DimensionDictionary, List<String>, DruidWebService) - Constructor for class com.yahoo.bard.webservice.application.DruidDimensionValueLoader
DruidDimensionRowProvider fetches data from Druid and adds it to the dimension cache.
DruidFactQuery<Q extends DruidFactQuery<? super Q>> - Interface in com.yahoo.bard.webservice.druid.model.query
Common interface for Druid Fact Query classes.
DruidFilterBuilder - Interface in com.yahoo.bard.webservice.data.filterbuilders
Builds druid query model objects from ApiFilters.
DruidFilterInfo - Class in com.yahoo.bard.webservice.logging.blocks
Logs some structural data about the filter sent to Druid, without actually logging the entire (potentially massive) filter.
DruidFilterInfo(Filter) - Constructor for class com.yahoo.bard.webservice.logging.blocks.DruidFilterInfo
Constructor.
DruidHavingBuilder - Class in com.yahoo.bard.webservice.data
Class to hold static methods to build druid query model objects from ApiHaving.
DruidHavingBuilder() - Constructor for class com.yahoo.bard.webservice.data.DruidHavingBuilder
 
DruidJsonRequestContentKeys - Enum in com.yahoo.bard.webservice.web.responseprocessors
Enumerates the list of keys expected to be found in the FullResponseProcessor.
DruidJsonResponseContentKeys - Enum in com.yahoo.bard.webservice.web.responseprocessors
Enumerates the list of keys expected to be found in the FullResponseProcessor.
DruidMetadataQuery<Q extends DruidMetadataQuery<? super Q>> - Interface in com.yahoo.bard.webservice.druid.model.query
Common interface for Druid Query classes.
DruidMetricName - Class in com.yahoo.wiki.webservice.data.config.metric
Holds a metric name which is stored in druid.
DruidMetricName(String) - Constructor for class com.yahoo.wiki.webservice.data.config.metric.DruidMetricName
Constructs a DruidMetricName.
DruidNavigator - Class in com.yahoo.wiki.webservice.data.config.auto
Searches for all datasources and their dimensions, metrics, and timegrains from druid.
DruidNavigator(DruidWebService, ObjectMapper) - Constructor for class com.yahoo.wiki.webservice.data.config.auto.DruidNavigator
Constructs a DruidNavigator to load datasources from druid.
DruidPartialDataRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
A request handler that builds responses for Druid partial data
DruidPartialDataRequestHandler(DataRequestHandler) - Constructor for class com.yahoo.bard.webservice.web.handlers.DruidPartialDataRequestHandler
Constructor.
DruidPartialDataResponseProcessor - Class in com.yahoo.bard.webservice.web.responseprocessors
Response processor for finding missing partial data in Druid
DruidPartialDataResponseProcessor(ResponseProcessor) - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.DruidPartialDataResponseProcessor
Constructor.
DruidQuery<Q extends DruidQuery<? super Q>> - Interface in com.yahoo.bard.webservice.druid.model.query
Common interface for Druid Query classes.
DruidQueryBuilder - Class in com.yahoo.bard.webservice.data
Druid Query builder class.
DruidQueryBuilder(LogicalTableDictionary, PhysicalTableResolver) - Constructor for class com.yahoo.bard.webservice.data.DruidQueryBuilder
Constructor.
druidQueryId - Variable in class com.yahoo.bard.webservice.logging.blocks.DruidResponse
 
DruidQueryToSqlConverter - Class in com.yahoo.bard.webservice.sql
Default implementation of converting a DruidQuery into a sql query.
DruidQueryToSqlConverter(CalciteHelper) - Constructor for class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Constructs the default converter.
DruidResponse - Class in com.yahoo.bard.webservice.logging.blocks
Corresponds mainly to the responding part of a request served by the DataServlet.
DruidResponse(String) - Constructor for class com.yahoo.bard.webservice.logging.blocks.DruidResponse
Constructor.
DruidResponseParser - Class in com.yahoo.bard.webservice.data
A class for building result sets from Druid Responses.
DruidResponseParser() - Constructor for class com.yahoo.bard.webservice.data.DruidResponseParser
 
druidResponseParser - Variable in class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessor
 
DruidSearchQuery - Class in com.yahoo.bard.webservice.druid.model.query
Class model for making Druid search queries.
DruidSearchQuery(DataSource, Granularity, Filter, Collection<Interval>, Collection<Dimension>, SearchQuerySpec, SearchSortDirection, Integer, QueryContext, boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
Constructor.
DruidSearchQuery(DataSource, Granularity, Filter, Collection<Interval>, Collection<Dimension>, SearchQuerySpec, SearchSortDirection, Integer) - Constructor for class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
Constructor.
DruidServiceConfig - Class in com.yahoo.bard.webservice.druid.client
This class represents the configurable parameters for a particular Druid service endpoint.
DruidServiceConfig(String, String, Integer, Integer) - Constructor for class com.yahoo.bard.webservice.druid.client.DruidServiceConfig
Build the Druid Service Config.
DruidSqlAggregationConverter - Class in com.yahoo.bard.webservice.sql.aggregation
The default implementation of mapping from Druid's Aggregation to a SqlAggregation.
DruidSqlAggregationConverter() - Constructor for class com.yahoo.bard.webservice.sql.aggregation.DruidSqlAggregationConverter
Constructors a map from druid to sql aggregations using DruidSqlAggregationConverter.getDefaultDruidToSqlAggregation().
DruidSqlAggregationConverter(Map<String, SqlAggregationType>) - Constructor for class com.yahoo.bard.webservice.sql.aggregation.DruidSqlAggregationConverter
Use the given map for converting from druid to sql aggregations.
DruidWebService - Interface in com.yahoo.bard.webservice.druid.client
Represents the druid web service endpoint.
druidWebService - Variable in class com.yahoo.bard.webservice.web.handlers.AsyncWebServiceRequestHandler
 
DruidWorkflow - Class in com.yahoo.bard.webservice.web.handlers.workflow
The Druid Workflow proceeds until a druid data request is returned or an error response is written.
DruidWorkflow(DataCache<?>, DruidWebService, QueryWeightUtil, PhysicalTableDictionary, PartialDataHandler, QuerySigningService<?>, VolatileIntervalsService, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
Constructor.
dump() - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Exports a snapshot of the request log of the current thread and also resets the request log for that thread.
DUPLICATE_METRIC_FORMAT - Static variable in class com.yahoo.bard.webservice.data.config.table.MetricUnionCompositeTableDefinition
 
Durations - Class in com.yahoo.bard.webservice.logging.blocks
Records the durations of each timed phase of the request processing.
Durations(Map<String, Float>) - Constructor for class com.yahoo.bard.webservice.logging.blocks.Durations
Constructor.
durations - Variable in class com.yahoo.bard.webservice.logging.blocks.Durations
 

E

Either<L,R> - Class in com.yahoo.bard.webservice.util
An Either is a bean that contains one of two possible values, referred to generically as Left or Right.
EndpointServlet - Class in com.yahoo.bard.webservice.web.endpoints
Abstract class making available the common code between the servlets that serve the endpoints.
EndpointServlet(ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.endpoints.EndpointServlet
Constructor.
entries - Variable in class com.yahoo.bard.webservice.web.AbstractResponse
 
entrySet() - Method in class com.yahoo.bard.webservice.util.DelegatingMap
 
enumJsonName(Enum<?>) - Static method in class com.yahoo.bard.webservice.util.EnumUtils
Converts the enum value to a camel case string.
EnumUtils - Class in com.yahoo.bard.webservice.util
Helper methods for enums.
EnumUtils() - Constructor for class com.yahoo.bard.webservice.util.EnumUtils
 
Epilogue - Class in com.yahoo.bard.webservice.logging.blocks
Common information for every request that is saved when the logging of a request is finalized.
Epilogue(String, Response.StatusType, CacheLastObserver<Long>) - Constructor for class com.yahoo.bard.webservice.logging.blocks.Epilogue
Builds the block containing the common information for every request that is saved when the logging of a request is finalized.
equals(Object) - Method in class com.yahoo.bard.webservice.async.jobs.jobrows.JobRow
 
equals(Object) - Method in class com.yahoo.bard.webservice.async.jobs.stores.JobRowFilter
 
equals(Object) - Method in class com.yahoo.bard.webservice.config.ConfigurationGraph
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.dimension.DimensionDictionary
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.dimension.DimensionUpdateDate
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.dimension.impl.LookupDimension
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.dimension.impl.RegisteredLookupDimension
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.metric.mappers.PartialDataResultSetMapper
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.metric.mappers.ResultSetMapper
Since a ResultSetMapper has no state associated with it, we consider two ResultSetMappers to be the same iff they are of the same class.
equals(Object) - Method in class com.yahoo.bard.webservice.data.metric.mappers.SketchRoundUpMapper
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.Result
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.time.AllGranularity
 
equals(Object) - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchAggregation
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.DefaultDimensionSpec
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.DimensionSpec
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.ExtractionDimensionSpec
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.CascadeExtractionFunction
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.ExtractionFunction
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.Lookup
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.MapLookup
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.NamespaceLookup
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.PartialExtractionFunction
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegularExpressionExtractionFunction
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.ListFilteredDimensionSpec
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.dimension.RegexFilteredDimensionSpec
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.filter.DimensionalFilter
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.filter.ExtractionFilter
Deprecated.
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.filter.Filter
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.filter.InFilter
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.filter.MultiClauseFilter
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.filter.NotFilter
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.filter.RegularExpressionFilter
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.filter.SearchFilter
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.filter.SelectorFilter
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.orderby.LimitSpec
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.orderby.OrderByColumn
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ConstantPostAggregation
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FuzzySetPostAggregation
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
 
equals(Object) - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
equals(Object) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadata
 
equals(Object) - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
 
equals(Object) - Method in class com.yahoo.bard.webservice.metadata.SegmentMetadata
 
equals(Object) - Method in class com.yahoo.bard.webservice.table.availability.BaseMetadataAvailability
 
equals(Object) - Method in class com.yahoo.bard.webservice.table.availability.MetricUnionAvailability
 
equals(Object) - Method in class com.yahoo.bard.webservice.table.availability.PartitionAvailability
 
equals(Object) - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
equals(Object) - Method in class com.yahoo.bard.webservice.table.BaseSchema
 
equals(Object) - Method in class com.yahoo.bard.webservice.table.Column
Allows comparison based solely on the name between objects of the base class and/or any of the derived classes.
equals(Object) - Method in class com.yahoo.bard.webservice.table.PhysicalTableSchema
 
equals(Object) - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
 
equals(Object) - Method in class com.yahoo.bard.webservice.table.resolver.DimensionIdFilter
 
equals(Object) - Method in class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
 
equals(Object) - Method in class com.yahoo.bard.webservice.table.TableGroup
 
equals(Object) - Method in class com.yahoo.bard.webservice.util.DelegatingMap
Are these two delegating maps the same in terms of the current layer and their delegates are equal under the definition of equality for that delegate.
equals(Object) - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
equals(Object) - Method in class com.yahoo.bard.webservice.web.ApiHaving
 
equals(Object) - Method in class com.yahoo.bard.webservice.web.PreResponse
 
equals(Object) - Method in class com.yahoo.bard.webservice.web.responseprocessors.ResponseContext
 
equals(Object) - Method in class com.yahoo.bard.webservice.web.util.PaginationParameters
 
ErrorMessageFormat - Enum in com.yahoo.bard.webservice.web
Common message formats for errors.
ErrorUtils - Class in com.yahoo.bard.webservice.async
The util method to compute and hold error message attributes based on error type.
ErrorUtils() - Constructor for class com.yahoo.bard.webservice.async.ErrorUtils
 
EtagCacheRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Request handler to check the cache for a matching eTag.
EtagCacheRequestHandler(DataRequestHandler, TupleDataCache<String, String, String>, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.EtagCacheRequestHandler
Build a Cache request handler.
EtagCacheResponseProcessor - Class in com.yahoo.bard.webservice.web.responseprocessors
A response processor which caches the results if appropriate after completing a query according to etag value.
EtagCacheResponseProcessor(ResponseProcessor, String, TupleDataCache<String, String, String>, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.EtagCacheResponseProcessor
Constructor.
evaluate(Filter, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.FilterEvaluator
Top level evaluate call meant to capture Filter which could not be mapped to a specific "evaluate" method.
evaluate(RegularExpressionFilter, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.FilterEvaluator
Evaluates a regular expression filter.
evaluate(SelectorFilter, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.FilterEvaluator
Evaluates a Selector filter.
evaluate(SearchFilter, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.FilterEvaluator
Evaluates a SearchFilter filter.
evaluate(InFilter, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.FilterEvaluator
Evaluates an Infilter filter.
evaluate(OrFilter, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.FilterEvaluator
Evaluates an OrFilter.
evaluate(AndFilter, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.FilterEvaluator
Evaluates an AndFilter.
evaluate(NotFilter, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.FilterEvaluator
Evaluates an NotFilter.
evaluate(Having, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.HavingEvaluator
Top level evaluate function meant to capture Having which could not be mapped to a specific "evaluate" method.
evaluate(NumericHaving, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.HavingEvaluator
Evaluates a NumericHaving.
evaluate(NotHaving, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.HavingEvaluator
Evaluates a NotHaving filter.
evaluate(OrHaving, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.HavingEvaluator
Evaluates a OrHaving.
evaluate(AndHaving, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.HavingEvaluator
Evaluates a AndHaving.
evaluate(PostAggregation, Function<String, String>) - Method in class com.yahoo.bard.webservice.sql.evaluator.PostAggregationEvaluator
Top level evaluation of a postAggregation which evaluates all inner PostAggregation and returns the value.
evaluate(FieldAccessorPostAggregation, Function<String, String>) - Method in class com.yahoo.bard.webservice.sql.evaluator.PostAggregationEvaluator
Evaluates a fieldAccessorPostAggregation by parsing the value from the aggregatedValues map.
evaluate(ArithmeticPostAggregation, Function<String, String>) - Method in class com.yahoo.bard.webservice.sql.evaluator.PostAggregationEvaluator
Evaluates an arithmeticPostAggregation by performing it's operation over other postAggregations.
evaluate(ConstantPostAggregation, Function<String, String>) - Method in class com.yahoo.bard.webservice.sql.evaluator.PostAggregationEvaluator
Evaluates a constantPostAggregation by reading it's value.
evaluateFilter(Filter, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.FilterEvaluator
Evaluates and builds a filter and finds all the dimension names used in all filters.
evaluateHaving(Having, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.HavingEvaluator
Creates an RexNode which contains the given Having.
EVERYTHING_IN_ONE_PAGE - Static variable in class com.yahoo.bard.webservice.web.util.PaginationParameters
The common pagination parameter object used by non-paginating method in search providers.
executeQuery(DruidQuery<?>, SuccessCallback, FailureCallback) - Method in class com.yahoo.bard.webservice.sql.DefaultSqlBackedClient
 
executeQuery(DruidQuery<?>, SuccessCallback, FailureCallback) - Method in interface com.yahoo.bard.webservice.sql.SqlBackedClient
Uses a DruidQuery to fetch results from a Sql client, parses the results from Sql and returns an equivalent JsonNode to what druid would respond with.
export() - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Exports current thread's request log object as a formatted string without resetting it.
EXTRA_RETURN_FORMAT - Static variable in class com.yahoo.bard.webservice.web.responseprocessors.SplitQueryResponseProcessor
 
ExtractionDimensionSpec - Class in com.yahoo.bard.webservice.druid.model.dimension
DimensionSpec using ExtractionFunctions.
ExtractionDimensionSpec(String, String, ExtractionFunction) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.ExtractionDimensionSpec
Constructor.
ExtractionFilter - Class in com.yahoo.bard.webservice.druid.model.filter
Deprecated.
Use SelectorFilter dimensional filters with extractionFn specified instead
ExtractionFilter(Dimension, String, ExtractionFunction) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.ExtractionFilter
Deprecated.
Constructor.
ExtractionFunction - Class in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
Extraction functions define the transformation applied to each dimension value.
ExtractionFunction(ExtractionFunctionType) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.ExtractionFunction
Constructor.
ExtractionFunction.DefaultExtractionFunctionType - Enum in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
Enumeration of possible extraction function types.
ExtractionFunctionDimension - Interface in com.yahoo.bard.webservice.data.dimension.impl
A dimension that supports extraction functions.
ExtractionFunctionType - Interface in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
Allowed values for Extraction function in druid.

F

FACT_QUERIES - Static variable in class com.yahoo.bard.webservice.logging.blocks.BardQueryInfo
 
FACT_QUERY_CACHE_HIT - Static variable in class com.yahoo.bard.webservice.logging.blocks.BardQueryInfo
 
factory(MetricDictionary) - Method in class com.yahoo.bard.webservice.data.metric.MetricDictionary
 
factory(T) - Method in class com.yahoo.bard.webservice.util.ScopeMap
Used to construct child scopes.
FailureCallback - Interface in com.yahoo.bard.webservice.druid.client
Callback from the async HTTP client on error.
FAR_FUTURE - Static variable in class com.yahoo.bard.webservice.data.volatility.TimeOffsetVolatileIntervalsFunction
Arbitrary future date for unbounded volatility.
FeatureFlag - Interface in com.yahoo.bard.webservice.config
Feature flags bind an object to a system configuration name.
FeatureFlagRegistry - Class in com.yahoo.bard.webservice.config
Feature flags registry to keep mappings between feature flag names and enumerations.
FeatureFlagRegistry(IterableProvider<FeatureFlag>) - Constructor for class com.yahoo.bard.webservice.config.FeatureFlagRegistry
Constructor.
FeatureFlagRequest - Class in com.yahoo.bard.webservice.logging.blocks
Main log of a request served by the FeatureFlagServlet.
FeatureFlagRequest(String) - Constructor for class com.yahoo.bard.webservice.logging.blocks.FeatureFlagRequest
Constructor.
FeatureFlagsServlet - Class in com.yahoo.bard.webservice.web.endpoints
Web service endpoint to return the current status of feature flags.
FeatureFlagsServlet(FeatureFlagRegistry, ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.endpoints.FeatureFlagsServlet
Constructor.
field - Variable in class com.yahoo.bard.webservice.druid.model.postaggregation.FuzzySetPostAggregation
 
field - Variable in class com.yahoo.bard.webservice.logging.blocks.Filter
 
FieldAccessorPostAggregation - Class in com.yahoo.bard.webservice.druid.model.postaggregation
Model representing lookups of aggregation values.
FieldAccessorPostAggregation(MetricField) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
Constructor.
FieldConverters - Interface in com.yahoo.bard.webservice.druid.util
An interface for transforming sketch aggregations into other sketch (post-)aggregations.
FieldConverterSupplier - Class in com.yahoo.bard.webservice.druid.util
Supplies global access points to utility operations that work on sketch-like objects.
FieldConverterSupplier() - Constructor for class com.yahoo.bard.webservice.druid.util.FieldConverterSupplier
 
FieldName - Interface in com.yahoo.bard.webservice.data.config.names
Marker interface for enums that can be treated as a metric or dimension field name for Druid Query fields.
FiliApiMetricName - Class in com.yahoo.wiki.webservice.data.config.metric
Holds a metric name which is stored in fili.
FiliApiMetricName(String, TimeGrain) - Constructor for class com.yahoo.wiki.webservice.data.config.metric.FiliApiMetricName
Constructs a FiliApiMetricName.
FiliResponseWriter - Class in com.yahoo.bard.webservice.web
Default writer for response.
FiliResponseWriter(ResponseWriterSelector) - Constructor for class com.yahoo.bard.webservice.web.FiliResponseWriter
Constructor.
FiliResponseWriterSelector - Class in com.yahoo.bard.webservice.web
FiliResponseWriterSelector is the default selector for ReponseWriterSelector.
FiliResponseWriterSelector(CsvResponseWriter, JsonResponseWriter, JsonApiResponseWriter) - Constructor for class com.yahoo.bard.webservice.web.FiliResponseWriterSelector
Constructor for default writer selector.
Filter - Class in com.yahoo.bard.webservice.druid.model.filter
Model representing a filter expression in a druid query.
Filter(FilterType) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.Filter
Constructor.
filter - Variable in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidFactQuery
 
Filter - Class in com.yahoo.bard.webservice.logging.blocks
Inner log block recording information related to the API filters of a query.
Filter(ApiFilter) - Constructor for class com.yahoo.bard.webservice.logging.blocks.Filter
Constructor.
filter(Collection<PhysicalTable>, QueryPlanningConstraint) - Method in class com.yahoo.bard.webservice.table.resolver.BasePhysicalTableResolver
Filter to a set of tables matching the rules of this resolver.
filter(Collection<PhysicalTable>, List<PhysicalTableMatcher>) - Method in class com.yahoo.bard.webservice.table.resolver.BasePhysicalTableResolver
Filter a list of tables through each matcher using a list of matchers sequentially.
filter(ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
Intercept the Container request to add length of request and a start timestamp.
filter(ContainerRequestContext, ContainerResponseContext) - Method in class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
Intercept the Container request/response and log.
filter(ClientRequestContext) - Method in class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
Intercept Client request and add start timestamp.
filter(ClientRequestContext, ClientResponseContext) - Method in class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
 
filter(ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.filters.HealthCheckFilter
 
filter(ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.filters.QueryParameterNormalizationFilter
 
filter(ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.filters.RateLimitFilter
 
filter(ContainerRequestContext, ContainerResponseContext) - Method in class com.yahoo.bard.webservice.web.filters.RateLimitFilter
 
filter(ContainerRequestContext, ContainerResponseContext) - Method in class com.yahoo.bard.webservice.web.filters.RequestIdHeaderFilter
 
filter(ContainerRequestContext, ContainerResponseContext) - Method in class com.yahoo.bard.webservice.web.filters.ResponseCorsFilter
 
filter(ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.filters.RoleBasedAuthFilter
 
Filter.DefaultFilterType - Enum in com.yahoo.bard.webservice.druid.model.filter
Valid types for druid filters.
FilterDimensionRows - Interface in com.yahoo.bard.webservice.data.dimension
Interface representing an object which can filter dimension row sets.
FilteredAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
FilteredAggregation wraps aggregation with the associated filter.
FilteredAggregation(String, Aggregation, Filter) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
Constructor.
FilteredAggregation(String, String, Aggregation, Filter) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
Deprecated.
Filtered Aggregations do not have their own field name, they use the one from their aggregator
FilteredAggregationMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Build a Filtered Aggregation logical metric.
FilteredAggregationMaker(MetricDictionary, Filter) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.FilteredAggregationMaker
Construct a metric maker for Filtered Aggregations.
FilteredSketchMetricsHelper - Class in com.yahoo.bard.webservice.web
Deprecated.
To consider the latest version of sketch Library. This class is replaced by FilteredThetaSketchMetricsHelper class
FilteredSketchMetricsHelper() - Constructor for class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
 
FilteredThetaSketchMetricsHelper - Class in com.yahoo.bard.webservice.web
Class containing helper methods to build filtered metrics.
FilteredThetaSketchMetricsHelper() - Constructor for class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
FilterEvaluator - Class in com.yahoo.bard.webservice.sql.evaluator
Evaluates filters to find all the dimensions used in them and to build a RexNode with an equivalent sql filter.
FilterEvaluator() - Constructor for class com.yahoo.bard.webservice.sql.evaluator.FilterEvaluator
Constructor.
FilterOperation - Enum in com.yahoo.bard.webservice.web
Types of legal filter operations.
filters - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
FilterTokenizer - Class in com.yahoo.bard.webservice.util
Utility class to tokenize Strings based on CSV properties.
FilterTokenizer() - Constructor for class com.yahoo.bard.webservice.util.FilterTokenizer
 
FilterType - Interface in com.yahoo.bard.webservice.druid.model.filter
Allowed values for Filter expressions in druid.
finalize() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Make sure the scheduler for loader tasks shuts down when the resources of this class are released.
finalize() - Method in class com.yahoo.bard.webservice.web.ratelimit.CallbackRateLimitRequestToken
 
findAll() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionDictionary
Get all dimensions available in dimension dictionary.
findAllDimensionRows() - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Deprecated.
Searching for dimension rows is moving to a paginated version (SearchProvider.findAllDimensionRowsPaged(com.yahoo.bard.webservice.web.util.PaginationParameters)) in order to give greater control to the caller.
findAllDimensionRowsPaged(PaginationParameters) - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
 
findAllDimensionRowsPaged(PaginationParameters) - Method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
 
findAllDimensionRowsPaged(PaginationParameters) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
findAllDimensionRowsPaged(PaginationParameters) - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Return the desired page of dimension rows.
findAllOrderedDimensionRows() - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
 
findAllOrderedDimensionRows() - Method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
For dimensions with NoOpSearchProvider, the dimension rows are unknown.
findAllOrderedDimensionRows() - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
findAllOrderedDimensionRows() - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Getter for dimension rows in tree set for consistent order.
findByApiName(String) - Method in class com.yahoo.bard.webservice.data.dimension.DimensionDictionary
Find a Dimension given a dimension api name.
findByDimension(Dimension) - Method in class com.yahoo.bard.webservice.table.LogicalTableDictionary
Get the logical tables for which the given logical dimension is valid.
findByLogicalMetric(LogicalMetric) - Method in class com.yahoo.bard.webservice.table.LogicalTableDictionary
Get the logical tables for which the given logical metric is valid.
findDimensionRowByKeyValue(String) - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Get a dimension row given an id.
findDimensionRowByKeyValue(String) - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
findDimensionRowByKeyValue(String) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
Get a dimension row given an id.
findFilteredDimensionRows(Set<ApiFilter>) - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Deprecated.
Searching for filtered dimension rows is moving to a paginated version (SearchProvider.findFilteredDimensionRowsPaged(java.util.Set<com.yahoo.bard.webservice.web.ApiFilter>, com.yahoo.bard.webservice.web.util.PaginationParameters)) in order to give greater control to the caller.
findFilteredDimensionRowsPaged(Set<ApiFilter>, PaginationParameters) - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
 
findFilteredDimensionRowsPaged(Set<ApiFilter>, PaginationParameters) - Method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
 
findFilteredDimensionRowsPaged(Set<ApiFilter>, PaginationParameters) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
findFilteredDimensionRowsPaged(Set<ApiFilter>, PaginationParameters) - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Return the desired page of dimension rows that match the specified filters.
findFullAvailabilityGaps(Set<Interval>, Set<Interval>) - Static method in class com.yahoo.bard.webservice.util.DateTimeUtils
Finds the gaps in available vs needed interval sets.
findMissingTimeGrainIntervals(SimplifiedIntervalList, SimplifiedIntervalList, Granularity) - Method in class com.yahoo.bard.webservice.data.PartialDataHandler
Find the holes in the passed in intervals at a given granularity.
findPhysicalName(Dimension, JsonGenerator) - Static method in class com.yahoo.bard.webservice.druid.serializers.SerializerUtil
JSON tree walk up to physical table to retrieve physical name for a dimension.
FIRST_PAGE - Static variable in interface com.yahoo.bard.webservice.util.Pagination
 
firstMoment(Collection<? extends Collection<Interval>>) - Static method in class com.yahoo.bard.webservice.util.IntervalUtils
Return the first date time instant in this set of intervals if available.
flag - Variable in class com.yahoo.bard.webservice.logging.blocks.FeatureFlagRequest
 
flatView() - Method in class com.yahoo.bard.webservice.util.DelegatingMap
Return a non delegating map which snapshots the data visible in this delegating map, disconnected from changes to this and the underlying delegates.
forBouncerValue(int) - Static method in enum com.yahoo.bard.webservice.web.filters.BouncerAuthorizationStatus
Get the value for the given bouncer value.
fork() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
Fork the QueryContext, cloning the values and continuing the number fo queries.
forKey(String, Map<String, T>, Class<T>) - Static method in class com.yahoo.bard.webservice.util.EnumUtils
Boilerplate method to retrieve an enum method via an arbitrary key, rather than just the enum value.
forKey(int, Map<Integer, T>, Class<T>) - Static method in class com.yahoo.bard.webservice.util.EnumUtils
Boilerplate method to retrieve an enum method via an arbitrary key, rather than just the enum value.
format - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
format(LogBlock) - Method in class com.yahoo.bard.webservice.logging.JsonLogFormatter
 
format(LogBlock) - Method in interface com.yahoo.bard.webservice.logging.LogFormatter
Takes in a log block and returns a formatted String to be logged.
format(Object...) - Method in interface com.yahoo.bard.webservice.MessageFormatter
Format a message for reporting to a user/client.
format - Variable in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
formatResponse(ApiRequest, Stream<T>, String, List<String>) - Method in class com.yahoo.bard.webservice.web.endpoints.EndpointServlet
Format and build the response as JSON or CSV.
formatTable(LogicalTable, UriInfo) - Method in class com.yahoo.bard.webservice.web.TableFullViewProcessor
Method to provide metadata of the table.
formatTable(LogicalTable, UriInfo) - Method in interface com.yahoo.bard.webservice.web.TableMetadataFormatter
Get a representation of a table and underlying information.
formatTableGrain(LogicalTable, String, UriInfo) - Method in class com.yahoo.bard.webservice.web.TableFullViewProcessor
Method to provide grain level details(with metrics and dimensions) of the given logical table.
formatTableGrain(LogicalTable, String, UriInfo) - Method in interface com.yahoo.bard.webservice.web.TableMetadataFormatter
Get a representation of a table at grain level.
formatTables(Set<LogicalTable>, UriInfo) - Method in class com.yahoo.bard.webservice.web.TableFullViewProcessor
Method to provide full view of the tables which includes grains, metrics and dimensions.
formatTables(Set<LogicalTable>, UriInfo) - Method in interface com.yahoo.bard.webservice.web.TableMetadataFormatter
Get a list of TableViews which have a complete view of all the tables and underlying information.
forName(String) - Method in class com.yahoo.bard.webservice.config.FeatureFlagRegistry
Get a registered FeatureFlag by name.
forName(String) - Static method in enum com.yahoo.bard.webservice.web.TimeMacro
Get the time macro for the given name.
ForTesting - Annotation Type in com.yahoo.bard.webservice.web
Intended to signify that a constructor is defined only for testing purposes.
FragmentSearchQuerySpec - Class in com.yahoo.bard.webservice.druid.model.query
Class for specifying the FragmentSearchQuerySpec for DruidSearchQuery.
FragmentSearchQuerySpec(Collection<String>) - Constructor for class com.yahoo.bard.webservice.druid.model.query.FragmentSearchQuerySpec
Constructor.
fromString(String) - Static method in enum com.yahoo.bard.webservice.web.HavingOperation
Convert from a string to a Having operation.
fromType(String) - Static method in enum com.yahoo.bard.webservice.druid.model.filter.SearchFilter.QueryType
Get the QueryType enum from it's search type.
FullResponseProcessor - Interface in com.yahoo.bard.webservice.web.responseprocessors
Response processor for that extracts header information from Druid response and put the information in our own response.
FULLY_OPTIONAL_DATETIME_FORMATTER - Static variable in class com.yahoo.bard.webservice.util.DateTimeFormatterFactory
 
future - Variable in class com.yahoo.bard.webservice.application.LoadTask
 
FuzzySetPostAggregation - Class in com.yahoo.bard.webservice.druid.model.postaggregation
Model representing post aggregation numeric estimates from sketches.
FuzzySetPostAggregation(PostAggregationType, String, PostAggregation) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.FuzzySetPostAggregation
Constructor accepting fields as list of field accessor post aggs.

G

gatherFilterDimensions(Filter) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
Helper method that calls gatherFilterDimensions(Filter filter, Set<Dimension> dimensions) by passing in filter and an empty HashSet.
gatherFilterDimensions(Filter, Set<Dimension>) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
 
gatherFilterDimensions(Filter) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
gatherFilterDimensions(Filter, Set<Dimension>) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
gatherFilterDimensions(Filter) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
Helper method that calls MetricsFilterSetBuilder.gatherFilterDimensions(Filter, Set) by passing in filter and an empty HashSet.
gatherFilterDimensions(Filter, Set<Dimension>) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
Method to get dimensions from a Filter object.
generateAcceptFormat(String) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Generates the format in which the response data is expected.
generateApiMetricColumns(Set<String>) - Method in class com.yahoo.bard.webservice.web.ResponseData
Builds a set of only those metric columns which correspond to the metrics requested in the API.
generateAsyncAfter(String) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Parses the asyncAfter parameter into a long describing how long the user is willing to wait for the results of a synchronous request before the request should become asynchronous.
generateCleanupClosure(AtomicInteger, String) - Method in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
Creates a callback to be passed to a token to execute when a request has completed.
generateDateTimeFormatter(DateTimeZone) - Method in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
Get the DateTimeFormatter shifted to the given time zone.
generateDateTimeSortColumn(LinkedHashMap<String, SortDirection>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Method to generate DateTime sort column from the map of columns and its direction.
generateDimensionColumnHeaders(Map.Entry<Dimension, LinkedHashSet<DimensionField>>) - Method in class com.yahoo.bard.webservice.web.ResponseData
Build the headers for the dimension columns.
generateDimensionFields(List<PathSegment>, DimensionDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Extracts the list of dimensions from the url dimension path segments and "show" matrix params and generates a map of dimension to dimension fields which needs to be annotated on the response.
generateDimensions(List<PathSegment>, DimensionDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Extracts the list of dimension names from the url dimension path segments and generates a set of dimension objects based on it.
generateDimensions(String, DimensionDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
Returns a set of dimension names that contains either the requested dimension or all the available ones.
generateFilters(String, LogicalTable, DimensionDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Generates filter objects on the based on the filter query in the api request.
generateFilters(String, LogicalTable, DimensionDictionary) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
Generates filter objects on the based on the filter query in the api request.
generateFilters(String, DimensionDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
Generates filter objects based on the filter query in the api request.
generateGranularity(String, DateTimeZone, GranularityParser) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Generate a Granularity instance based on a path element.
generateGranularity(String, GranularityParser) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Generate a Granularity instance based on a path element.
generateInteger(String, String) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Parses the requested input String by converting it to an integer, while treating null as zero.
generateIntervals(String, Granularity, DateTimeFormatter) - Static method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Extracts the set of intervals from the api request.
generateIntervals(DateTime, String, Granularity, DateTimeFormatter) - Static method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Extracts the set of intervals from the api request.
generateLogicalMetrics(String, MetricDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Extracts the list of metrics from the url metric query string and generates a set of LogicalMetrics.
generateLogicalMetrics(String, MetricDictionary, DimensionDictionary, LogicalTable) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Extracts the list of metrics from the url metric query string and generates a set of LogicalMetrics.
generateLogicalMetrics(String, MetricDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
Extracts the list of metrics from the url metric query string and generates a set of LogicalMetrics.
generateMetricFilterJsonArray(String) - Static method in class com.yahoo.bard.webservice.web.MetricParser
This function converts the string of metrics extracted from the url into ArrayNode.
generateMetricName(String) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Given a single dimension filter string, generate a metric name extension.
generateMetricName(String) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
 
generateMetricName(String) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
generateMetricName(String) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
Method to prepare filter string.
generateMetrics(String, MetricDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.MetricsApiRequestImpl
Generates the set of all available metrics.
generatePaginationParameters(String, String) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Builds the paginationParameters object, if the request provides both a perPage and page field.
generateSlice(String, PhysicalTableDictionary, DataSourceMetadataService, UriInfo) - Method in class com.yahoo.bard.webservice.web.apirequest.SlicesApiRequestImpl
Generates a slice object for a given slice name.
generateSlices(PhysicalTableDictionary, UriInfo) - Method in class com.yahoo.bard.webservice.web.apirequest.SlicesApiRequestImpl
Generates the set of all available slices.
generateSortColumns(String) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Method to convert sort list to column and direction map.
generateSortColumns(Map<String, SortDirection>, Set<LogicalMetric>, MetricDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Generates a Set of OrderByColumn.
generateTable(String, Granularity, LogicalTableDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Extracts a specific logical table object given a valid table name and a valid granularity.
generateTables(String, LogicalTableDictionary) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
Extracts the list of logical table names from the url table path segment and generates a set of logical table objects based on it.
generateTimeZone(String, DateTimeZone) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Get the timezone for the request.
GenericBinderFactory - Class in com.yahoo.wiki.webservice.application
Builds dimensions, metrics, and tables for all datasources found from druid.
GenericBinderFactory() - Constructor for class com.yahoo.wiki.webservice.application.GenericBinderFactory
Constructs a GenericBinderFactory using the MetadataDruidWebService to configure dimensions, tables, and metrics from Druid.
GenericDimensionConfigs - Class in com.yahoo.wiki.webservice.data.config.dimension
Hold all the dimension configurations for a generic druid configuration.
GenericDimensionConfigs(Supplier<List<? extends DataSourceConfiguration>>) - Constructor for class com.yahoo.wiki.webservice.data.config.dimension.GenericDimensionConfigs
Construct the dimension configurations.
GenericMain - Class in com.yahoo.wiki.webservice.application
Launch Bard in Embedded Jetty.
GenericMain() - Constructor for class com.yahoo.wiki.webservice.application.GenericMain
 
GenericMetricLoader - Class in com.yahoo.wiki.webservice.data.config.metric
Loads all metrics from a list of DataSourceConfiguration.
GenericMetricLoader(Supplier<List<? extends DataSourceConfiguration>>) - Constructor for class com.yahoo.wiki.webservice.data.config.metric.GenericMetricLoader
Constructs a GenericMetricLoader using the given sketch size.
GenericTableLoader - Class in com.yahoo.wiki.webservice.data.config.table
Load the table configuration for any Druid setup.
GenericTableLoader(Supplier<List<? extends DataSourceConfiguration>>, GenericDimensionConfigs, DataSourceMetadataService) - Constructor for class com.yahoo.wiki.webservice.data.config.table.GenericTableLoader
Constructor.
get(String) - Method in interface com.yahoo.bard.webservice.async.jobs.stores.ApiJobStore
Returns a cold Observable that emits 0 or 1 messages: the desired JobRow, or nothing if there is no JobRow with the specified id.
get(String) - Method in class com.yahoo.bard.webservice.async.jobs.stores.HashJobStore
 
get(String) - Method in class com.yahoo.bard.webservice.async.jobs.stores.NoOpApiJobStore
 
get(String) - Method in class com.yahoo.bard.webservice.async.preresponses.stores.NoOpPreResponseStore
 
get(String) - Method in interface com.yahoo.bard.webservice.async.preresponses.stores.PreResponseStore
Returns an Observable over a PreResponse associated with a given ticket.
get(String) - Method in interface com.yahoo.bard.webservice.data.cache.DataCache
Read data from cache.
get(String) - Method in class com.yahoo.bard.webservice.data.cache.HashDataCache
Lookup pair key/value by hashkey but verify found key matches original key.
get(String) - Method in class com.yahoo.bard.webservice.data.cache.MemDataCache
 
get(String) - Method in class com.yahoo.bard.webservice.data.cache.MemTupleDataCache
 
get(String) - Method in class com.yahoo.bard.webservice.data.cache.StubDataCache
 
get(String) - Method in interface com.yahoo.bard.webservice.data.cache.TupleDataCache
Retrieve the complete data entry from the cache.
get(String) - Method in interface com.yahoo.bard.webservice.data.dimension.KeyValueStore
Get the value for a key from store.
get(String) - Method in class com.yahoo.bard.webservice.data.dimension.MapStore
 
get(String) - Method in class com.yahoo.bard.webservice.data.dimension.RedisStore
 
get(String) - Method in class com.yahoo.bard.webservice.logging.LogBlock
Return a part of logging information in this LogBlock.
get(Object) - Method in class com.yahoo.bard.webservice.util.DefaultingDictionary
 
get(Object) - Method in class com.yahoo.bard.webservice.util.DelegatingMap
 
get() - Method in class com.yahoo.wiki.webservice.data.config.auto.DruidNavigator
Queries druid for all datasources and loads each of their configurations.
getAggregateDurations() - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Get the aggregate durations for this request.
getAggregation() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
 
getAggregation() - Method in class com.yahoo.bard.webservice.druid.model.having.NumericHaving
 
getAggregation() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
Deprecated.
Use getMetricField instead
getAggregations() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getAggregations() - Method in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidAggregationQuery
 
getAggregations() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidAggregationQuery
Returns the aggregations of the query.
getAggregations() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getAggregationTypeMapper(DruidAggregationQuery<?>) - Static method in class com.yahoo.bard.webservice.sql.SqlResultSetProcessor
Creates a map from each aggregation name, i.e.
getAlignmentDescription() - Method in class com.yahoo.bard.webservice.data.time.AllGranularity
 
getAlignmentDescription() - Method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
 
getAlignmentDescription() - Method in interface com.yahoo.bard.webservice.data.time.Granularity
Get description of correct alignment of a granularity, e.g.
getAlignmentDescription() - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
 
getAlignmentDescription() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
getAllAvailableIntervals() - Method in interface com.yahoo.bard.webservice.table.availability.Availability
The availability of all columns.
getAllAvailableIntervals() - Method in class com.yahoo.bard.webservice.table.availability.BaseCompositeAvailability
Retrieve all available intervals for all data source fields across all the underlying datasources.
getAllAvailableIntervals() - Method in class com.yahoo.bard.webservice.table.availability.BaseMetadataAvailability
 
getAllAvailableIntervals() - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
getAllAvailableIntervals() - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
 
getAllAvailableIntervals() - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Getter for all the available intervals for the corresponding columns configured on the table.
getAllColumnNames() - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
 
getAllColumnPhysicalNames() - Method in class com.yahoo.bard.webservice.table.resolver.PhysicalDataSourceConstraint
Getter for the all column names as physical names.
getAllDimensionConfigurations() - Method in class com.yahoo.wiki.webservice.data.config.dimension.GenericDimensionConfigs
Get all dimension configurations of all data sources.
getAllDimensionConfigurations() - Method in class com.yahoo.wiki.webservice.data.config.dimension.WikiDimensions
Get all dimension configurations.
getAllDimensionNames() - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
 
getAllDimensions() - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
 
getAllDimensions(String, String, String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Get all the dimensions as a summary list.
getAllGroupByColumns(RelBuilder, DruidAggregationQuery<?>, ApiToFieldMapper, String) - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Collects all the time columns and dimensions to be grouped on.
getAllLogicalMetrics(String, String, String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.MetricsServlet
Get all the logical metrics as a summary list.
getAllPagesPaginationFactory(PaginationParameters) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
This method returns a Function that can basically take a Collection and return an instance of AllPagesPagination.
getAllQueryAggregations(RelBuilder, DruidAggregationQuery<?>, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Find all druid aggregations and convert them to RelBuilder.AggCall.
getAllRows() - Method in interface com.yahoo.bard.webservice.async.jobs.stores.ApiJobStore
A cold observable that emits a stream of JobRows until all JobRows have been retrieved from the store.
getAllRows() - Method in class com.yahoo.bard.webservice.async.jobs.stores.HashJobStore
 
getAllRows() - Method in class com.yahoo.bard.webservice.async.jobs.stores.NoOpApiJobStore
 
getAllSourceAvailabilities() - Method in class com.yahoo.bard.webservice.table.availability.BaseCompositeAvailability
Return a stream of all the availabilities which this availability composites from.
getAllTables(String, String, String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Get all the logical tables as a summary list.
getAllValuesKey() - Static method in class com.yahoo.bard.webservice.util.DimensionStoreKeyUtils
Returns a key for accessing all the dimension values in a KeyValueStore.
getAllWhereFilters(RelBuilder, DruidAggregationQuery<?>, ApiToFieldMapper, String) - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Returns the RexNode used to filter the druidQuery.
getApiFilters() - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
 
getApiFilters() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
The filters for this ApiRequest, grouped by dimensions.
getApiFilters() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getApiFilters() - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
Returns a map of filters by dimension for this request, grouped by dimensions.
getApiFilters() - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
getApiMetricColumns() - Method in class com.yahoo.bard.webservice.web.ResponseData
 
getApiMetricNames() - Method in class com.yahoo.bard.webservice.table.TableGroup
Getter for the api metric names on this group.
getApiName() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
 
getApiName() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
The API Name is the external, end-user-facing name for the dimension.
getApiName() - Method in interface com.yahoo.bard.webservice.data.config.names.ApiMetricName
The API Name is the external, end-user-facing name for the metric.
getApiName() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Getter for api name.
getApiName() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getApiName() - Method in enum com.yahoo.bard.webservice.data.dimension.metadata.StorageStrategy
Returns the API name of this StorageStrategy.
getApiName() - Method in class com.yahoo.wiki.webservice.data.config.metric.FiliApiMetricName
 
getApiName() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiMetricName
 
getAsDateTime(DateTime, Granularity, String, DateTimeFormatter) - Static method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Get datetime from the given input text based on granularity.
getAsyncAfter() - Method in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
Returns how long the user is willing to wait before a request should go asynchronous.
getAsyncAfter() - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
getAsynchronousPayload() - Method in class com.yahoo.bard.webservice.async.workflows.AsynchronousWorkflows
Returns an Observable that emits the job metadata to send to the user.
getAsynchronousProcessBuilder() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Initializes the factory that builds the asynchronous PreResponse processing workflow.
getAvailability() - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
getAvailability() - Method in interface com.yahoo.bard.webservice.table.ConfigPhysicalTable
Get the value of the backing availability instance for this physical table.
getAvailableIntervals() - Method in interface com.yahoo.bard.webservice.table.availability.Availability
Fetch a SimplifiedIntervalList representing the coalesced available intervals on this availability.
getAvailableIntervals(PhysicalDataSourceConstraint) - Method in interface com.yahoo.bard.webservice.table.availability.Availability
Fetch a SimplifiedIntervalList representing the coalesced available intervals on this availability as filtered by the PhysicalDataSourceConstraint.
getAvailableIntervals(DataSourceConstraint) - Method in interface com.yahoo.bard.webservice.table.availability.Availability
Fetch a SimplifiedIntervalList representing the coalesced available intervals on this availability as filtered by the DataSourceConstraint.
getAvailableIntervals(PhysicalDataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.availability.BaseMetadataAvailability
 
getAvailableIntervals(PhysicalDataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.availability.MetricUnionAvailability
 
getAvailableIntervals(PhysicalDataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.availability.PartitionAvailability
 
getAvailableIntervals(PhysicalDataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.availability.PermissiveAvailability
Returns union of all available intervals.
getAvailableIntervals(PhysicalDataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.availability.StrictAvailability
 
getAvailableIntervals(DataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
getAvailableIntervals() - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
 
getAvailableIntervals(DataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
Return a view of the available intervals for the original source table given a constraint.
getAvailableIntervals() - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Return a view of the available intervals.
getAvailableIntervals(DataSourceConstraint) - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Return a view of the available intervals for this table given a constraint.
getAvailableIntervalsByDataSource(DataSourceName) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataService
Get a set of intervals available for each column in the data source.
getBardQueryInfo() - Static method in class com.yahoo.bard.webservice.logging.blocks.BardQueryInfo
Retrieves BardQueryInfo from RequestLog.
getBaseTimeGrain() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
getBetterTableOperator(QueryPlanningConstraint) - Method in class com.yahoo.bard.webservice.table.resolver.BasePhysicalTableResolver
Create a binary operator which returns the 'better' of two physical table.
getBetterTableOperator(QueryPlanningConstraint) - Method in class com.yahoo.bard.webservice.table.resolver.DefaultPhysicalTableResolver
 
getBodyName() - Method in enum com.yahoo.bard.webservice.web.util.PaginationLink
 
getBooleanProperty(String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getBooleanProperty(String, boolean) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getBouncerValue() - Method in enum com.yahoo.bard.webservice.web.filters.BouncerAuthorizationStatus
 
getBuilder(DataSource, String) - Static method in class com.yahoo.bard.webservice.sql.helper.CalciteHelper
Creates a RelBuilder with the given schema.
getBuilder() - Method in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
Get the response builder associated with this request.
getBuilder() - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
getBySegment() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
getCalculation() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
getCardinality() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Get the cardinality of the dimension.
getCardinality() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getCardinalityKey() - Static method in class com.yahoo.bard.webservice.util.DimensionStoreKeyUtils
Returns a key that, when fed into a KeyValueStore returns the cardinality of the dimensions.
getCategory() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
 
getCategory() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
The Category is the external, end-user-facing category for the dimension.
getCategory() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Get the category of the dimension.
getCategory() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getCategory() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
getCategory() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetricInfo
Returns the category of the metric.
getCategory() - Method in class com.yahoo.bard.webservice.table.LogicalTable
 
getCategory() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiDimensionConfigInfo
 
getCause() - Method in exception com.yahoo.bard.webservice.async.ResponseException
 
getClassType() - Method in class com.yahoo.bard.webservice.data.metric.MetricColumnWithValueType
 
getClock() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Returns a clock for generating instants for timestamps.
getCollector() - Static method in class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Build a collector which appends overlapping intervals, merging and simplifying as it goes.
getColumn(String, Class<T>) - Method in interface com.yahoo.bard.webservice.table.Schema
Given a column type and name, return the column of the expected type.
getColumnKey(String) - Static method in class com.yahoo.bard.webservice.util.DimensionStoreKeyUtils
Returns a key that, when fed into a KeyValueStore returns the field name used by Lucene.
getColumnNames() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
Getter for list of dimension and metric names.
getColumnNames() - Method in class com.yahoo.bard.webservice.table.BaseSchema
Get the names of the columns returned by getColumns method.
getColumnNames(DataApiRequest, DruidAggregationQuery<?>, PhysicalTable) - Static method in class com.yahoo.bard.webservice.util.TableUtils
Deprecated.
in favor of getColumnNames(DataApiRequest, DruidAggregationQuery) returning dimension api name
getColumnNames(DataApiRequest, DruidAggregationQuery<?>) - Static method in class com.yahoo.bard.webservice.util.TableUtils
Get the schema column names from the dimensions and metrics.
getColumns() - Method in class com.yahoo.bard.webservice.druid.model.orderby.LimitSpec
Getter for columns.
getColumns() - Method in class com.yahoo.bard.webservice.table.BaseSchema
 
getColumns() - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Deprecated.
In favor of getting the columns directly from the schema
getColumns() - Method in interface com.yahoo.bard.webservice.table.Schema
Get all the columns underlying this Schema.
getColumns(Class<T>) - Method in interface com.yahoo.bard.webservice.table.Schema
Getter for set of columns by sub-type.
getConfiguration(String) - Method in class com.yahoo.bard.webservice.config.ConfigurationGraph
Return the configuration corresponding to a module name.
getConfigurationLoader() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Get the application specific configuration loader, if not exist already, initialize with pluggable loaders.
getConfigurations(List<String>) - Method in class com.yahoo.bard.webservice.config.ModuleLoader
Get a stream of configurations in descending order of precedence given a list of dependent modules.
getConnection() - Method in class com.yahoo.bard.webservice.sql.helper.CalciteHelper
Creates a connection to the database from the CalciteHelper.dataSource.
getConstrainedLogicalTableAvailability(LogicalTable, QueryPlanningConstraint) - Static method in class com.yahoo.bard.webservice.util.TableUtils
Returns union of constrained availabilities of constrained logical table.
getContainerRequestContextProperty(String) - Method in class com.yahoo.bard.webservice.web.handlers.RequestContext
Get a container property from the RequestContext.
getContext() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getContext() - Method in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidQuery
 
getContext() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidQuery
Returns the context of the query.
getCount() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
An optional limit of records returned.
getCount() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getCount(String) - Method in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
Get the current count for this username.
getCsvContentDispositionValue(UriInfo) - Static method in class com.yahoo.bard.webservice.web.util.ResponseFormat
This method will get the path segments and the interval (if it is part of the request) from the apiRequest and create a content-disposition header value with a proposed filename in the following format.
getCsvMapper() - Method in class com.yahoo.bard.webservice.application.ObjectMappersSuite
Get the CSV mapper.
getCurrentDate(DateTime, TimeGrain) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Generate current date based on granularity.
getData(UriInfo, ContainerRequestContext, String, String, List<PathSegment>, String, String, String, String, String, String, String, String, String, String, String, String, Boolean, AsyncResponse) - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
Resource method with dimensions as a mandatory path parameter.
getDataApiRequest() - Method in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
 
getDataRequestHandler() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getDataSegments() - Method in interface com.yahoo.wiki.webservice.data.config.auto.DataSourceConfiguration
Gets a list of data segments for a datasource in Druid.
getDataSegments() - Method in class com.yahoo.wiki.webservice.data.config.auto.TableConfig
 
getDataSource() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getDataSource() - Method in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidQuery
 
getDataSource() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidQuery
Returns the data source of the query.
getDataSource() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
Getter for the datasource of this segment partition.
getDataSourceMetadataService() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Get the stored metadata service, if not exist yet, create the service and store it.
getDataSourceMetadataService() - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Getter for the data source metadata service use for creating physical tables.
getDataSourceMetadataService() - Method in class com.yahoo.bard.webservice.table.availability.BaseMetadataAvailability
 
getDataSourceName() - Method in class com.yahoo.bard.webservice.table.availability.BaseMetadataAvailability
 
getDataSourceName() - Method in class com.yahoo.bard.webservice.table.SingleDataSourcePhysicalTable
 
getDataSourceNames() - Method in interface com.yahoo.bard.webservice.table.availability.Availability
The names of the data sources backing this availability.
getDataSourceNames(PhysicalDataSourceConstraint) - Method in interface com.yahoo.bard.webservice.table.availability.Availability
The names of the data sources backing this availability as filtered by the constraint.
getDataSourceNames(DataSourceConstraint) - Method in interface com.yahoo.bard.webservice.table.availability.Availability
The names of the data sources backing this availability as filtered by the constraint.
getDataSourceNames() - Method in class com.yahoo.bard.webservice.table.availability.BaseCompositeAvailability
 
getDataSourceNames() - Method in class com.yahoo.bard.webservice.table.availability.BaseMetadataAvailability
 
getDataSourceNames(PhysicalDataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.availability.PartitionAvailability
 
getDataSourceNames() - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
getDataSourceNames() - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
 
getDataSourceNames(DataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
Return the TableName of the dataSources which back the original source table given a constraint.
getDataSourceNames() - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Get the names of the data sources that back this physical table.
getDataSourceNames(DataSourceConstraint) - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Return the DataSourceName of the dataSources which back this table given a constraint.
getDataSources() - Method in interface com.yahoo.bard.webservice.application.DimensionValueLoader
Gets the list of datasources to query against.
getDataSources() - Method in class com.yahoo.bard.webservice.application.DruidDimensionValueLoader
 
getDataSources() - Method in class com.yahoo.bard.webservice.application.SqlDimensionValueLoader
 
getDataValue(String) - Method in class com.yahoo.bard.webservice.data.cache.MemTupleDataCache
 
getDataValue(K) - Method in interface com.yahoo.bard.webservice.data.cache.TupleDataCache
Read the raw data from cache.
getDateTime(DateTime, TimeGrain) - Method in class com.yahoo.bard.webservice.web.CurrentMacroCalculation
 
getDateTime(DateTime, TimeGrain) - Method in interface com.yahoo.bard.webservice.web.MacroCalculationStrategies
Get the DateTime for the macro given the DateTime to base from and the timeGrain to determine how far to move.
getDateTime(DateTime, TimeGrain) - Method in class com.yahoo.bard.webservice.web.NextMacroCalculation
 
getDateTime(DateTime, TimeGrain) - Method in enum com.yahoo.bard.webservice.web.TimeMacro
Calculate the macro-adjusted DateTime under the TimeGrain.
getDateTimeSort() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
An optional sorting predicate for the time column.
getDateTimeSort() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getDateTimeZone() - Method in class com.yahoo.bard.webservice.table.ZonedSchema
Deprecated.
 
getDefaultDimensionFields() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
 
getDefaultDimensionFields() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
The default set of fields for this dimension to be shown in the response.
getDefaultDimensionFields() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Getter for default dimension fields.
getDefaultDimensionFields() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getDefaultDruidToSqlAggregation() - Static method in class com.yahoo.bard.webservice.sql.aggregation.DruidSqlAggregationConverter
The default mapping from druid to sql aggregations defined by DefaultSqlAggregationType.
getDefaultGrainMap() - Static method in class com.yahoo.bard.webservice.data.time.StandardGranularityParser
This method loads default grains and can be extended to add customer grain extensions.
getDefaultPagination() - Method in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
Get the default pagination parameters for this type of API request.
getDefaultPagination() - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
getDefaultValue() - Method in class com.yahoo.bard.webservice.util.DefaultingDictionary
Return the defaultValue for this class.
getDefinedDelay() - Method in class com.yahoo.bard.webservice.application.LoadTask
Get the defined delay of this loader in milliseconds.
getDefinedPeriod() - Method in class com.yahoo.bard.webservice.application.LoadTask
Get the defined period of this loader in milliseconds.
getDelay(TimeUnit) - Method in class com.yahoo.bard.webservice.application.SchedulableTask
 
getDelegate() - Method in class com.yahoo.bard.webservice.druid.model.dimension.ListFilteredDimensionSpec
 
getDelegate() - Method in class com.yahoo.bard.webservice.druid.model.dimension.RegexFilteredDimensionSpec
 
getDependencyMetricNames() - Method in class com.yahoo.bard.webservice.data.config.metric.MetricInstance
 
getDependentDimensions() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
 
getDependentDimensions() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
 
getDependentDimensions() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
 
getDependentDimensions() - Method in interface com.yahoo.bard.webservice.druid.model.MetricField
Get the dimensions, if any, this metric depends on.
getDependentDimensions() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ConstantPostAggregation
 
getDependentDimensions() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
 
getDependentDimensions() - Method in interface com.yahoo.bard.webservice.druid.model.postaggregation.WithFields
Get the dimensions from all child postAggregations.
getDependentFieldNames() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidAggregationQuery
Retrieves a set of druid metric names associated with the query.
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.AggregationAverageMaker
 
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.ArithmeticMaker
 
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.CardinalityMaker
 
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.ConstantMaker
 
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.CountMaker
 
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.FilteredAggregationMaker
 
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Get the number of dependent metrics the maker requires for making the metric.
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.RawAggregationMetricMaker
 
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.RowNumMaker
 
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.SketchSetOperationMaker
Deprecated.
 
getDependentMetricsRequired() - Method in class com.yahoo.bard.webservice.data.config.metric.makers.ThetaSketchSetOperationMaker
 
getDependentQuery(String) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Deprecated.
Instead get the metric in the calling function and then get the TDQ out only if necessary
getDependentTableNames() - Method in class com.yahoo.bard.webservice.data.config.table.ConcretePhysicalTableDefinition
 
getDependentTableNames() - Method in class com.yahoo.bard.webservice.data.config.table.DimensionListPartitionTableDefinition
 
getDependentTableNames() - Method in class com.yahoo.bard.webservice.data.config.table.MetricUnionCompositeTableDefinition
 
getDependentTableNames() - Method in class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
Get the set of physical tables required to build the current physical table.
getDescription(Throwable) - Static method in class com.yahoo.bard.webservice.async.ErrorUtils
Method to get the description for an error.
getDescription() - Method in enum com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobField
 
getDescription() - Method in enum com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobStatus
 
getDescription() - Method in interface com.yahoo.bard.webservice.async.jobs.jobrows.JobField
Returns a human-friendly description of the field.
getDescription() - Method in interface com.yahoo.bard.webservice.async.jobs.jobrows.JobStatus
Returns a human-friendly description of the status.
getDescription() - Method in exception com.yahoo.bard.webservice.async.ResponseException
 
getDescription() - Method in enum com.yahoo.bard.webservice.data.config.dimension.DefaultDimensionField
 
getDescription() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
 
getDescription() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
The description for this dimension.
getDescription() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Getter for description.
getDescription() - Method in interface com.yahoo.bard.webservice.data.dimension.DimensionField
The description for the dimension field.
getDescription() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getDescription() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
getDescription() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetricInfo
Returns the description of the metric.
getDescription() - Method in class com.yahoo.bard.webservice.table.LogicalTable
 
getDescription() - Method in enum com.yahoo.bard.webservice.web.filters.BouncerAuthorizationStatus
 
getDescription() - Method in enum com.yahoo.wiki.webservice.data.config.dimension.WikiDimensionField
 
getDescription() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiDimensionConfigInfo
 
getDictionaries() - Method in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
 
getDimension() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionColumn
 
getDimension() - Method in class com.yahoo.bard.webservice.druid.model.dimension.DefaultDimensionSpec
 
getDimension() - Method in class com.yahoo.bard.webservice.druid.model.dimension.ExtractionDimensionSpec
 
getDimension() - Method in class com.yahoo.bard.webservice.druid.model.filter.DimensionalFilter
 
getDimension() - Method in class com.yahoo.bard.webservice.druid.model.orderby.OrderByColumn
Getter for sort column dimension.
getDimension() - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
getDimension() - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
getDimension() - Method in interface com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequest
 
getDimension() - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
 
getDimension(String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Get the details of a dimension.
getDimensionCardinality() - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
 
getDimensionCardinality() - Method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
Get cardinality for the dimension
getDimensionCardinality() - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
getDimensionCardinality() - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Gets the number of distinct dimension rows (assuming the key field is unique) in the index.
getDimensionColumnName(Dimension, DimensionField) - Static method in class com.yahoo.bard.webservice.web.ResponseData
Retrieve dimension column name from cache, or build it and cache it.
getDimensionConfigs() - Method in class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
 
getDimensionConfigs(DataSourceConfiguration) - Method in class com.yahoo.wiki.webservice.data.config.dimension.GenericDimensionConfigs
Deprecated.
only the name(a String) of DataSourceConfiguration can resolve its set of DimensionConfigs. There is no need to pass a heavier DataSourceConfiguration object. Use GenericDimensionConfigs.getDimensionConfigs(String) instead.
getDimensionConfigs(String) - Method in class com.yahoo.wiki.webservice.data.config.dimension.GenericDimensionConfigs
Returns all dimension configurations of a particular data source.
getDimensionConfigurations() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
A set of all dimension configurations for this application.
getDimensionConfigurations() - Method in class com.yahoo.wiki.webservice.application.GenericBinderFactory
 
getDimensionConfigurations() - Method in class com.yahoo.wiki.webservice.application.WikiBinderFactory
 
getDimensionConfigurationsByConfigInfo(WikiApiDimensionConfigInfo...) - Method in class com.yahoo.wiki.webservice.data.config.dimension.WikiDimensions
Get dimension configurations provided the dimension api name.
getDimensionDictionary() - Method in class com.yahoo.bard.webservice.application.healthchecks.AllDimensionsLoadedHealthCheck
 
getDimensionDictionary() - Method in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
 
getDimensionDictionary() - Method in class com.yahoo.bard.webservice.data.config.ResourceDictionaries
 
getDimensionDictionary() - Method in class com.yahoo.bard.webservice.data.PreResponseDeserializer
 
getDimensionDictionary() - Method in interface com.yahoo.bard.webservice.web.util.BardConfigResources
The dictionary of configured dimensions.
getDimensionField() - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
getDimensionFieldListSummaryView(Collection<DimensionField>) - Static method in class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Deprecated.
should be private, now the internal usage need is gone, will deprecate in case someone is using it
getDimensionFields() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Getter for dimension fields.
getDimensionFields() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getDimensionFields() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
A map of dimension fields specified for the output schema.
getDimensionFields() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getDimensionFieldSummaryView(DimensionField) - Static method in class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Deprecated.
should be private, now the internal usage need is gone, will deprecate in case someone is using it
getDimensionFullView(Dimension, LogicalTableDictionary, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Get the full view of the dimension.
getDimensionIntervals() - Method in class com.yahoo.bard.webservice.metadata.SegmentMetadata
 
getDimensionLastUpdated(String) - Method in class com.yahoo.bard.webservice.web.endpoints.DimensionCacheLoaderServlet
Get the lastUpdated date for a particular dimension.
getDimensionListSummaryView(Iterable<Dimension>, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Get the summary list view of the dimensions.
getDimensionLoader() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Create a Dimension Loader which will populate the dimensionDictionary.
getDimensionRow(DimensionColumn) - Method in class com.yahoo.bard.webservice.data.Result
Fetch a DimensionRow from dimensionValues based on the column provided.
getDimensionRows() - Method in class com.yahoo.bard.webservice.data.Result
The dimensions in the result row expressed as an unmodifiable map keyed by columns.
getDimensionRows(String, String, String, String, String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Endpoint to get values of a dimension.
getDimensions() - Method in interface com.yahoo.bard.webservice.application.DimensionValueLoader
Gets the list of dimensions to load.
getDimensions() - Method in class com.yahoo.bard.webservice.application.DruidDimensionValueLoader
 
getDimensions() - Method in class com.yahoo.bard.webservice.application.SqlDimensionValueLoader
 
getDimensions() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getDimensions() - Method in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidAggregationQuery
 
getDimensions() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidAggregationQuery
Returns the dimensions of the query if any.
getDimensions() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getDimensions() - Method in class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
 
getDimensions() - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
getDimensions() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
Getter for the dimensions in this segment.
getDimensions() - Method in interface com.yahoo.bard.webservice.table.Table
Getter for set of dimensions.
getDimensions() - Method in class com.yahoo.bard.webservice.table.TableGroup
Getter for the set of maximal dimensions for tables in this table group.
getDimensions(DataApiRequest, DruidAggregationQuery<?>) - Static method in class com.yahoo.bard.webservice.util.TableUtils
Get a stream returning all the fact store dimensions.
getDimensions() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
The set of grouping dimensions on this ApiRequest.
getDimensions() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getDimensions() - Method in interface com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequest
 
getDimensions() - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
 
getDimensions() - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
Returns the set of grouping dimensions on this request.
getDimensions() - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
getDimensions() - Method in interface com.yahoo.wiki.webservice.data.config.auto.DataSourceConfiguration
Gets the names of all the dimensions for the current datasource.
getDimensions() - Method in class com.yahoo.wiki.webservice.data.config.auto.TableConfig
Gets the dimensions from the datasource.
getDimensionSummaryView(Dimension, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Get the summary view of the dimension.
getDimensionToDimensionFieldMap() - Method in class com.yahoo.bard.webservice.web.responseprocessors.ResponseContext
 
getDimensionUrl(Dimension, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Get the URL of the dimension.
getDimensionValues() - Method in class com.yahoo.bard.webservice.data.ResultSerializationProxy
 
getDimensionValuesUrl(Dimension, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.DimensionsServlet
Get the URL of the dimension values collection.
getDirection() - Method in class com.yahoo.bard.webservice.druid.model.orderby.OrderByColumn
Getter for sort direction.
getDoubleProperty(String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getDoubleProperty(String, double) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getDruidCoordUrl() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Fetches the URL of the druid coordinator.
getDruidFilter() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
Builds and returns the Druid filters from this request's ApiFilters.
getDruidFilter() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Builds and returns the Druid filters from this request's ApiFilters.
getDruidName() - Method in interface com.yahoo.bard.webservice.druid.model.HasDruidName
Get the Druid name.
getDruidName() - Method in enum com.yahoo.bard.webservice.druid.model.having.Having.DefaultHavingType
 
getDruidName() - Method in enum com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation.ArithmeticPostAggregationFunction
 
getDruidNonUiPriority() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Deprecated.
The druid non-UI priority is deprecated, please use DruidClientConfigHelper.getDruidPriority().
getDruidNonUiTimeout() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Deprecated.
The druid non-UI timeout is deprecated, please use DruidClientConfigHelper.getDruidTimeout().
getDruidNonUiUrl() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Deprecated.
The druid non-UI URL is deprecated, please use DruidClientConfigHelper.getDruidUrl().
getDruidPriority() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Fetches the druid Priority.
getDruidQuery() - Method in exception com.yahoo.bard.webservice.async.ResponseException
 
getDruidQueryBuilder() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getDruidResponseParser() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getDruidServiceConfig() - Method in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
getDruidTimeout() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Fetches the druid request timeout.
getDruidUiPriority() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Deprecated.
The druid UI priority is deprecated, please use DruidClientConfigHelper.getDruidPriority().
getDruidUiTimeout() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Deprecated.
The druid UI timeout is deprecated, please use DruidClientConfigHelper.getDruidTimeout().
getDruidUiUrl() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Deprecated.
The druid UI URL is deprecated, please use DruidClientConfigHelper.getDruidUrl()
getDruidUrl() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Fetches the druid URL.
getDuration() - Method in class com.yahoo.bard.webservice.logging.TimedPhase
Return the duration of the timer in nanoseconds.
getDurations() - Method in class com.yahoo.bard.webservice.logging.blocks.Durations
 
getDurations() - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Get the aggregate durations for this request.
getError() - Method in class com.yahoo.bard.webservice.util.CacheLastObserver
Returns the last error received by this Observable, if any.
getErrorCallback() - Method in class com.yahoo.bard.webservice.application.LoadTask
Get a default callback for an http error.
getErrorCallback(SingleDataSourcePhysicalTable) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
Deprecated.
Pass the DataSourceName directly, rather than via the PhysicalTable
getErrorCallback(DataSourceName) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
Get a default callback for an http error.
getErrorCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.CacheV2ResponseProcessor
 
getErrorCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.CachingResponseProcessor
 
getErrorCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.DruidPartialDataResponseProcessor
 
getErrorCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.EtagCacheResponseProcessor
 
getErrorCallback(DruidAggregationQuery<?>) - Method in interface com.yahoo.bard.webservice.web.responseprocessors.ResponseProcessor
Callback for handling http errors.
getErrorCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessor
 
getErrorCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.SplitQueryResponseProcessor
 
getErrorCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.WeightCheckResponseProcessor
 
getErrorHttpMsg() - Method in exception com.yahoo.bard.webservice.web.RequestValidationException
 
getErrorResponse(Throwable) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Map the exception thrown while processing the job request to an appropriate http response.
getErrorStatus() - Method in exception com.yahoo.bard.webservice.web.PageNotFoundException
 
getEstimatedDuration() - Method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
 
getEstimatedDuration() - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
Estimated duration gives a rough millisecond length of the TimeGrain usable for comparison.
getEstimatedDuration() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
getExceptionMeter() - Method in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
getExtractionFunction() - Method in interface com.yahoo.bard.webservice.data.dimension.impl.ExtractionFunctionDimension
Build an extraction function model object.
getExtractionFunction() - Method in class com.yahoo.bard.webservice.data.dimension.impl.LookupDimension
Build an extraction function model object.
getExtractionFunction() - Method in class com.yahoo.bard.webservice.data.dimension.impl.RegisteredLookupDimension
Build an extraction function model object.
getExtractionFunction() - Method in class com.yahoo.bard.webservice.druid.model.dimension.ExtractionDimensionSpec
 
getExtractionFunction() - Method in class com.yahoo.bard.webservice.druid.model.filter.DimensionalFilter
 
getExtractionFunctions() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.CascadeExtractionFunction
 
getFactTableName() - Method in class com.yahoo.bard.webservice.table.StrictPhysicalTable
Deprecated.
Use getDataSourceName instead.
getFailureCallback() - Method in class com.yahoo.bard.webservice.application.LoadTask
Get a default callback to use when a failure occurs.
getFailureCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.CacheV2ResponseProcessor
 
getFailureCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.CachingResponseProcessor
 
getFailureCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.DruidPartialDataResponseProcessor
 
getFailureCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.EtagCacheResponseProcessor
 
getFailureCallback(DruidAggregationQuery<?>) - Method in interface com.yahoo.bard.webservice.web.responseprocessors.ResponseProcessor
Callback handler for unexpected failures.
getFailureCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessor
 
getFailureCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.SplitQueryResponseProcessor
 
getFailureCallback(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.WeightCheckResponseProcessor
 
getFamily() - Method in enum com.yahoo.bard.webservice.web.ResponseCode
 
getFeatureFlagStatus(String, String, UriInfo) - Method in class com.yahoo.bard.webservice.web.endpoints.FeatureFlagsServlet
Get the status of a specific feature flag.
getFeatureFlagStatusAll(String, String, String, UriInfo) - Method in class com.yahoo.bard.webservice.web.endpoints.FeatureFlagsServlet
Get the status of all feature flags.
getField() - Method in class com.yahoo.bard.webservice.druid.model.filter.NotFilter
 
getField() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FuzzySetPostAggregation
 
getFieldByName(String) - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Find dimension field by name.
getFieldByName(String) - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getFieldName() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
The field name for aggregation.
getFieldName() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
Field name is not part of the Cardinality aggregation model in druid.
getFieldName() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CountAggregation
 
getFieldName() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
 
getFieldName() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
 
getFields() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
 
getFields() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
The set of fields for this dimension.
getFields() - Method in interface com.yahoo.bard.webservice.druid.model.filter.ComplexFilter
Returns the filters that are operated on by this filter.
getFields() - Method in class com.yahoo.bard.webservice.druid.model.filter.MultiClauseFilter
 
getFields() - Method in class com.yahoo.bard.webservice.druid.model.filter.NotFilter
 
getFields() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation
 
getFields() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FuzzySetPostAggregation
 
getFields() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
 
getFields() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
 
getFields() - Method in interface com.yahoo.bard.webservice.druid.model.postaggregation.WithFields
An interface method to get all the post aggregation fields.
getFilter() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getFilter() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
 
getFilter() - Method in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidFactQuery
 
getFilter() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidFactQuery
Returns the filter object of the query.
getFilter() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getFilterBuilder() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
A filter builder (remove).
getFilterBuilder() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getFilterBuilder() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getFilterBuilder() - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Filter builder isn't used in TablesServlet but is part of the configuration interface, so this is an empty implementation.
getFilterBuilder() - Method in interface com.yahoo.bard.webservice.web.util.BardConfigResources
A parser and builder for filters.
getFilterDimensions() - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
 
getFilterDimensions() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
Get the dimensions used in filters on this request.
getFilterDimensions() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Gets the filter dimensions form the given set of filter objects.
getFilterDimensions() - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
Returns the dimensions used in filters on this request.
getFilterDimensions() - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
getFilteredAggregation(JsonNode, Aggregation, DimensionDictionary, LogicalTable, DataApiRequest) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
 
getFilteredAggregation(JsonNode, Aggregation, DimensionDictionary, LogicalTable, DataApiRequest) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
getFilteredAggregation(JsonNode, Aggregation, DimensionDictionary, LogicalTable, DataApiRequest) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
For a given aggregator, this method applies the filter and returns a set of filtered aggregations.
getFilteredDimensionRows(Dimension, Set<ApiFilter>) - Method in class com.yahoo.bard.webservice.data.filterbuilders.ConjunctionDruidFilterBuilder
Resolves a set of ApiFilters into a list of dimension rows that need to be filtered in Druid.
getFilteredLogicalMetric(LogicalMetric, JsonNode, DimensionDictionary, LogicalTable, DataApiRequest) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
 
getFilteredLogicalMetric(LogicalMetric, JsonNode, DimensionDictionary, LogicalTable, DataApiRequest) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
getFilteredLogicalMetric(LogicalMetric, JsonNode, DimensionDictionary, LogicalTable, DataApiRequest) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
Provides filter wrapped logical metric for the given logical metric.
getFilteredRows(Set<JobRowFilter>) - Method in interface com.yahoo.bard.webservice.async.jobs.stores.ApiJobStore
This method takes a Set of JobRowFilters, ANDS them by default, and returns a cold observable that emits a stream of JobRows which satisfy the given filter.
getFilteredRows(Set<JobRowFilter>) - Method in class com.yahoo.bard.webservice.async.jobs.stores.HashJobStore
 
getFilteredRows(Set<JobRowFilter>) - Method in class com.yahoo.bard.webservice.async.jobs.stores.NoOpApiJobStore
This method ignores the filters and returns an empty Observable.
getFilters() - Method in interface com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequest
 
getFilters() - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
 
getFinalize() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
getFirstPage() - Method in class com.yahoo.bard.webservice.util.AllPagesPagination
 
getFirstPage() - Method in interface com.yahoo.bard.webservice.util.Pagination
Gets the number of the first page if this is not the current page.
getFirstPage() - Method in class com.yahoo.bard.webservice.util.SinglePagePagination
 
getFloatProperty(String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getFloatProperty(String, float) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getFn() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation
 
getFormat() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
Returns format of this TimeFormatExtractionFunction.
getFormat() - Method in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
Get the type of the requested response format.
getFormat() - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
getFunc() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
 
getFunc() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
 
getFuture() - Method in class com.yahoo.bard.webservice.application.LoadTask
Get the future associated with the execution of this loader.
getGranularity() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getGranularity() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
getGranularity() - Method in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidFactQuery
 
getGranularity() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidFactQuery
Returns the time grain (granularity) of the query.
getGranularity() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getGranularity() - Method in class com.yahoo.bard.webservice.druid.model.query.WeightEvaluationQuery
 
getGranularity() - Method in class com.yahoo.bard.webservice.table.BaseSchema
 
getGranularity() - Method in class com.yahoo.bard.webservice.table.LogicalTable
 
getGranularity() - Method in interface com.yahoo.bard.webservice.table.Schema
Get the time granularity for this Schema.
getGranularity() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
The grain to group the results of this request.
getGranularity() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getGranularity() - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
Returns the grain to group the results of this request.
getGranularity() - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
getGranularityDictionary() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Extension point for building a dictionary of base granularities for use in the system.
getGranularityParser() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Extension point for selecting GranularityParser implementations.
getGranularityParser() - Method in class com.yahoo.bard.webservice.data.PreResponseDeserializer
 
getGranularityParser() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getGranularityParser() - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
 
getGranularityParser() - Method in interface com.yahoo.bard.webservice.web.util.BardConfigResources
A parser for string to granularities.
getHaving() - Method in class com.yahoo.bard.webservice.druid.model.having.NotHaving
 
getHaving() - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
getHaving() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getHaving() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
The fact model having (should probably remove this).
getHaving() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getHavingApiGenerator() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getHavingApiGenerator() - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Having Api generator isn't used in TablesServlet but is part of the configuration interface, so this is an empty implementation.
getHavingApiGenerator() - Method in interface com.yahoo.bard.webservice.web.util.BardConfigResources
Having Api Generator.
getHavingFilter(RelBuilder, DruidAggregationQuery<?>, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Gets the collection of having filters to be applied from the druid query.
getHavings() - Method in class com.yahoo.bard.webservice.druid.model.having.MultiClauseHaving
 
getHavings() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
The having constraints for this request, grouped by logical metrics.
getHavings() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getHeaderName() - Method in enum com.yahoo.bard.webservice.web.util.PaginationLink
 
getHeaders() - Method in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
getHeaders() - Method in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
 
getHeadersLowerCase() - Method in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
getHealthCheckRegistry() - Method in class com.yahoo.bard.webservice.application.HealthCheckServletContextListener
 
getHttpErrorMeter() - Method in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
getHttpResponseMaker() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Initializes the factory that builds HttpResponseMaker.
getId() - Method in class com.yahoo.bard.webservice.async.jobs.jobrows.JobRow
 
getId() - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Returns the id of this request log as a string.
getIdentifier() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
Getter for the identifier of this segment partition.
getInjective() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
getInjective() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
getInnermostQuery() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getInnermostQuery() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidAggregationQuery
 
getInnermostQuery() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidFactQuery
 
getInnermostQuery() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidQuery
If this structure is part of a query stack, return the lowest element.
getInnerQuery() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getInnerQuery() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidAggregationQuery
 
getInnerQuery() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidFactQuery
 
getInnerQuery() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidQuery
If this query is nestable, and has a nested query return it.
getInnerQuery() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getInstance() - Static method in class com.yahoo.bard.webservice.config.SystemConfigProvider
Get an instance of SystemConfiguration.
getInstance(String) - Static method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProviderManager
Get instance pointing to a search provider.
getInstance(String) - Static method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProviderManager
Get instance pointing to a search provider.
getInstance(String) - Static method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProviderManager
Get instance pointing to a search provider This method makes sure that there just one instance of search provider for a given dimension.
getInstance(String) - Static method in class com.yahoo.bard.webservice.data.dimension.MapStoreManager
Factory for singleton instances by name.
getInstance(String) - Static method in class com.yahoo.bard.webservice.data.dimension.RedisStoreManager
Factory for singleton instances by name.
getInstance() - Static method in class com.yahoo.bard.webservice.logging.LogFormatterProvider
Get an instance of LogFormatter.
getInstance() - Static method in class com.yahoo.bard.webservice.table.resolver.GranularityComparator
Factory method for creating new GranularityComparator instance.
getInterval() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
Getter for the interval that this segment partition is referring to.
getIntervalLists(DataSourceMetadata) - Static method in class com.yahoo.bard.webservice.metadata.DataSourceMetadata
Return a pair of maps containing the simplified intervals for dimensions and metrics respectively.
getIntervalOverlaps(Interval, Collection<Interval>) - Static method in class com.yahoo.bard.webservice.util.IntervalUtils
For a given interval, return a stream of the subintervals of it that are shared with at least one interval in the collection of compare intervals.
getIntervals() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getIntervals() - Method in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidFactQuery
 
getIntervals() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidFactQuery
Returns the intervals of the query.
getIntervals() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getIntervals() - Method in class com.yahoo.bard.webservice.druid.model.query.SegmentMetadataQuery
 
getIntervals() - Method in class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
 
getIntervals() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
The intervals for this query.
getIntervals() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getIntervals() - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
Returns the intervals for this query.
getIntervals() - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
getIntervalStart(int, String[], DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.sql.helper.SqlTimeConverter
Given an array of strings (a row from a ResultSet) and the Granularity used to make groupBy statements on time, it will parse out a DateTime for the row which represents the beginning of the interval it was grouped on.
getIntProperty(String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getIntProperty(String, int) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getIsWhitelist() - Method in class com.yahoo.bard.webservice.druid.model.dimension.ListFilteredDimensionSpec
 
getJobByTicket(String, UriInfo, ContainerRequestContext, AsyncResponse) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Endpoint to get all the metadata about a particular job.
getJobField() - Method in class com.yahoo.bard.webservice.async.jobs.stores.JobRowFilter
 
getJobMarkedCompleteNotifications() - Method in class com.yahoo.bard.webservice.async.workflows.AsynchronousWorkflows
Returns an Observable that emits notifications that the JobRow has been updated.
getJobResultsByTicket(String, String, String, String, String, UriInfo, ContainerRequestContext, AsyncResponse) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Endpoint to get a particular job's result.
getJobRow() - Method in exception com.yahoo.bard.webservice.async.jobs.stores.ApiJobStoreException
 
getJobs(String, String, String, String, UriInfo, ContainerRequestContext, AsyncResponse) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Endpoint to get metadata of all the Jobs in the ApiJobStore.
getJobViewObservable(String) - Method in class com.yahoo.bard.webservice.web.apirequest.JobsApiRequestImpl
Returns an Observable over the Map representing the job to be returned to the user.
getJobViews() - Method in class com.yahoo.bard.webservice.web.apirequest.JobsApiRequestImpl
Return an Observable containing a stream of job views for jobs in the ApiJobStore.
getJsonObject(SuccessCallback, HttpErrorCallback, FailureCallback, String) - Method in interface com.yahoo.bard.webservice.druid.client.DruidWebService
Invokes GET on the druid broker with a callback expecting a JSON Object on success.
getJsonObject(SuccessCallback, HttpErrorCallback, FailureCallback, String) - Method in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
getKey() - Method in class com.yahoo.bard.webservice.data.cache.MemTupleDataCache.DataEntry
 
getKey() - Method in interface com.yahoo.bard.webservice.data.cache.TupleDataCache.DataEntry
Returns the key of this data cache entry.
getKey() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Get primary key field for this dimension.
getKey() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getKey(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.handlers.CacheRequestHandler
Construct the cache key.
getKey(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.handlers.CacheV2RequestHandler
Construct the cache key.
getKeyValue() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionRow
Getter.
getKeyValueStore() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
 
getKeyValueStore() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
The key value store holding dimension row data.
getLastMessageReceived() - Method in class com.yahoo.bard.webservice.util.CacheLastObserver
The last message received by this Observable, if any.
getLastPage() - Method in class com.yahoo.bard.webservice.util.AllPagesPagination
 
getLastPage() - Method in interface com.yahoo.bard.webservice.util.Pagination
Gets the number of the last page if this is not the current page.
getLastPage() - Method in class com.yahoo.bard.webservice.util.SinglePagePagination
 
getLastRunTimestamp() - Method in class com.yahoo.bard.webservice.application.DimensionValueLoadTask
 
getLastRunTimestamp() - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
Return when this loader ran most recently.
getLastUpdated() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Getter for lastUpdated.
getLastUpdated() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionUpdateDate
 
getLastUpdated() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getLastUpdatedKey() - Static method in class com.yahoo.bard.webservice.util.DimensionStoreKeyUtils
 
getLeft() - Method in class com.yahoo.bard.webservice.util.Either
Returns the Left value wrapped in this Either.
getLimit() - Method in class com.yahoo.bard.webservice.druid.model.orderby.LimitSpec
Getter for limit.
getLimit() - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
getLimit(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Gets the number of rows to limit results to for a Group by Query.
getLimitSpec() - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
getLimitSpec() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getListProperty(String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getListProperty(String, List<T>) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getLocale() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
getLoggingFormat() - Method in enum com.yahoo.bard.webservice.config.ConfigMessageFormat
 
getLoggingFormat() - Method in interface com.yahoo.bard.webservice.MessageFormatter
The message format used for logging.
getLoggingFormat() - Method in enum com.yahoo.bard.webservice.web.ErrorMessageFormat
 
getLoggingFormat() - Method in enum com.yahoo.bard.webservice.web.security.SecurityErrorMessageFormat
 
getLogicalAll(Collection<LogicalTable>, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Get the summary list view of the logical tables.
getLogicalColumnNames(String) - Method in class com.yahoo.bard.webservice.table.PhysicalTableSchema
Look up all the logical column names corresponding to a physical name.
getLogicalDictionary() - Method in class com.yahoo.bard.webservice.data.config.ResourceDictionaries
 
getLogicalMetric() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetricColumn
Getter for a logical metric.
getLogicalMetricFullView(LogicalMetric, LogicalTableDictionary, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.MetricsServlet
Get the full view of the logical metric.
getLogicalMetricInfo() - Method in class com.yahoo.bard.webservice.data.config.metric.MetricInstance
Returns the LogicalMetricInfo of this MetricInstance.
getLogicalMetricListSummaryView(Collection<LogicalMetric>, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.MetricsServlet
Get the summary list view of the logical metrics.
getLogicalMetricNames() - Method in class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
 
getLogicalMetrics() - Method in class com.yahoo.bard.webservice.table.LogicalTable
 
getLogicalMetrics() - Method in class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
 
getLogicalMetrics() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
The logical metrics requested in this query.
getLogicalMetrics() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getLogicalMetrics() - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
Returns the logical metrics requested in this query.
getLogicalMetrics() - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
getLogicalMetricSummaryView(LogicalMetric, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.MetricsServlet
Get the summary view of the logical metric.
getLogicalMetricUrl(LogicalMetric, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.MetricsServlet
Get the URL of the logical metric.
getLogicalTable() - Method in class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
 
getLogicalTableDictionary() - Method in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
 
getLogicalTableDictionary() - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
 
getLogicalTableDictionary() - Method in interface com.yahoo.bard.webservice.web.util.BardConfigResources
The dictionary of logical tables.
getLogicalTableFullView(LogicalTable, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Deprecated.
In order to display constrained data availability in table resource, this method needs to accept a TablesApiRequest as a parameter. Use TablesServlet.getLogicalTableFullView(TablesApiRequestImpl, UriInfo) instead.
getLogicalTableFullView(TablesApiRequestImpl, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Get the full view of the logical table.
getLogicalTableListSummaryView(Collection<LogicalTable>, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Get the summary list view of the logical tables.
getLogicalTableSummaryView(LogicalTable, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Get the summary view of the logical table.
getLogicalTableUrl(LogicalTable, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Get the URL of the logical table.
getLogicalToPhysicalNames() - Method in class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
 
getLogMessage() - Method in exception com.yahoo.bard.webservice.web.PageNotFoundException
 
getLongName() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
 
getLongName() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
The Long Name is the external, end-user-facing long name for the dimension.
getLongName() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Get the long name of the dimension.
getLongName() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getLongName() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
getLongName() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetricInfo
Returns the long name of the metric.
getLongName() - Method in class com.yahoo.bard.webservice.table.LogicalTable
 
getLongName() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiDimensionConfigInfo
 
getLongProperty(String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getLongProperty(String, long) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getLookbackOffsets() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getlookbackOffsets() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
Get the collection of lookback offsets.
getLookbackPostAggregations() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getLookbackPrefixes() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getLookup() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
getLookup() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
getLookup(List<ShardSpec>) - Method in class com.yahoo.bard.webservice.druid.model.metadata.NumberedShardSpec
 
getLookups() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultRegisteredLookupDimensionConfig
 
getLookups() - Method in interface com.yahoo.bard.webservice.data.config.dimension.RegisteredLookupDimensionConfig
Returns a list of lookups used to configure the Lookup dimension.
getLookups() - Method in class com.yahoo.bard.webservice.data.dimension.impl.RegisteredLookupDimension
 
getLookupTiers() - Method in class com.yahoo.bard.webservice.metadata.RegisteredLookupMetadataLoadTask
Returns a list of configured lookup tiers.
getMaker() - Method in class com.yahoo.bard.webservice.data.config.metric.MetricInstance
 
getMapper() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Return the instance of ObjectMapper defined in the current ObjectMappersSuite.
getMapper() - Method in class com.yahoo.bard.webservice.application.ObjectMappersSuite
Get the default mapper.
getMappers() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Build an ObjectMappersSuite for everyone to use, since they are heavy-weight.
getMappers() - Method in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
 
getMapping() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.MapLookup
 
getMasterConfiguration() - Method in class com.yahoo.bard.webservice.config.LayeredFileSystemConfig
 
getMasterConfiguration() - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get the internal System Configuration instance.
getMatchers(QueryPlanningConstraint) - Method in class com.yahoo.bard.webservice.table.resolver.BasePhysicalTableResolver
Create a list of matchers based on a request and query.
getMatchers(QueryPlanningConstraint) - Method in class com.yahoo.bard.webservice.table.resolver.DefaultPhysicalTableResolver
 
getMaxTime() - Method in class com.yahoo.bard.webservice.metadata.TimeBoundaryResponse
 
getMergedQuery(List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
A helper function returning the resulting aggregation set from merging one or more template druid queries.
getMessage() - Method in exception com.yahoo.bard.webservice.web.PageNotFoundException
 
getMessageFormat() - Method in enum com.yahoo.bard.webservice.config.ConfigMessageFormat
 
getMessageFormat() - Method in interface com.yahoo.bard.webservice.MessageFormatter
The message format used for publishing out of the system, typically in error messages.
getMessageFormat() - Method in enum com.yahoo.bard.webservice.web.ErrorMessageFormat
 
getMessageFormat() - Method in enum com.yahoo.bard.webservice.web.security.SecurityErrorMessageFormat
 
getMeta() - Method in class com.yahoo.bard.webservice.data.cache.MemTupleDataCache.DataEntry
 
getMeta() - Method in interface com.yahoo.bard.webservice.data.cache.TupleDataCache.DataEntry
Returns the metadata of this data cache entry.
getMetadataServiceConfig() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Create a druid service configuration object for the metadata service.
getMetric() - Method in class com.yahoo.bard.webservice.druid.model.orderby.TopNMetric
Getter for the metric of TopNMetric.
getMetric() - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
getMetric() - Method in class com.yahoo.bard.webservice.web.ApiHaving
 
getMetric() - Method in interface com.yahoo.bard.webservice.web.apirequest.MetricsApiRequest
Returns an available metric.
getMetric() - Method in class com.yahoo.bard.webservice.web.apirequest.MetricsApiRequestImpl
 
getMetric(String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.MetricsServlet
Get the details of a specific logical metric.
getMetricColumnNames() - Method in class com.yahoo.bard.webservice.table.BaseSchema
Get the names of the columns returned by getColumns method which are metric columns.
getMetricDictionary() - Method in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
 
getMetricDictionary() - Method in class com.yahoo.bard.webservice.data.config.ResourceDictionaries
 
getMetricDictionary() - Method in interface com.yahoo.bard.webservice.web.util.BardConfigResources
The dictionary of configured metrics.
getMetricDimensions() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidAggregationQuery
Get all the dimensions from Filtered Aggregations of a filtered metric.
getMetricDimensions() - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
 
getMetricField() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
getMetricField(String) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Get the field by name.
getMetricField() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
Retrieve the MetricField column which this field accesses.
getMetricIntervals() - Method in class com.yahoo.bard.webservice.metadata.SegmentMetadata
 
getMetricLoader() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Create a Metric Loader.
getMetricLoader() - Method in class com.yahoo.wiki.webservice.application.GenericBinderFactory
 
getMetricLoader() - Method in class com.yahoo.wiki.webservice.application.WikiBinderFactory
 
getMetricName() - Method in class com.yahoo.bard.webservice.data.config.metric.MetricInstance
 
getMetricNames() - Method in class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
 
getMetricNames() - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
 
getMetricRegistry() - Method in class com.yahoo.bard.webservice.application.MetricServletContextListener
 
getMetrics() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
Getter for the metrics in this segment.
getMetrics() - Method in interface com.yahoo.bard.webservice.web.apirequest.MetricsApiRequest
Returns a set of all available metrics.
getMetrics() - Method in class com.yahoo.bard.webservice.web.apirequest.MetricsApiRequestImpl
 
getMetrics() - Method in interface com.yahoo.wiki.webservice.data.config.auto.DataSourceConfiguration
Gets the names of all the metrics for the current datasource.
getMetrics() - Method in class com.yahoo.wiki.webservice.data.config.auto.TableConfig
Gets the metrics from the datasource.
getMetricValue(MetricColumn) - Method in class com.yahoo.bard.webservice.data.Result
Fetches the metric value associated with the specified metric column.
getMetricValueAsBoolean(MetricColumn) - Method in class com.yahoo.bard.webservice.data.Result
Fetch the value of the specified metric as a boolean.
getMetricValueAsJsonNode(MetricColumn) - Method in class com.yahoo.bard.webservice.data.Result
Fetch the value of the specified metric as a JsonNode.
getMetricValueAsNumber(MetricColumn) - Method in class com.yahoo.bard.webservice.data.Result
Fetch the value of the specified numeric metric.
getMetricValueAsString(MetricColumn) - Method in class com.yahoo.bard.webservice.data.Result
Fetch the String representation of the value of the specified metric.
getMetricValues() - Method in class com.yahoo.bard.webservice.data.Result
The metrics in the result row expressed as an unmodifiable map keyed by columns.
getMetricValues() - Method in class com.yahoo.bard.webservice.data.ResultSerializationProxy
 
getMetricValuesType() - Method in class com.yahoo.bard.webservice.data.ResultSerializationProxy
Get type of class type of metric values mapped with metric names.
getMinimumGranularity() - Method in class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
 
getMinTime() - Method in class com.yahoo.bard.webservice.metadata.TimeBoundaryResponse
 
getMinValue(T, T) - Static method in class com.yahoo.bard.webservice.util.Utils
Find the minimum value between two comparable objects.
getMissingIntervals() - Method in class com.yahoo.bard.webservice.web.ResponseData
 
getMsg() - Method in class com.yahoo.bard.webservice.web.endpoints.DimensionCacheLoaderServlet
Get the status of the cache.
getName() - Method in class com.yahoo.bard.webservice.application.LoadTask
Return the name of this loader.
getName() - Method in enum com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobField
 
getName() - Method in enum com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobStatus
 
getName() - Method in interface com.yahoo.bard.webservice.async.jobs.jobrows.JobField
Returns the name of the field (i.e.
getName() - Method in interface com.yahoo.bard.webservice.async.jobs.jobrows.JobStatus
Returns a human-friendly name of the status.
getName() - Method in enum com.yahoo.bard.webservice.config.BardFeatureFlag
 
getName() - Method in enum com.yahoo.bard.webservice.config.CacheFeatureFlag
 
getName() - Method in interface com.yahoo.bard.webservice.config.FeatureFlag
Returns the simple property name of this feature flag.
getName() - Method in enum com.yahoo.bard.webservice.data.config.dimension.DefaultDimensionField
 
getName() - Method in class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
 
getName() - Method in interface com.yahoo.bard.webservice.data.dimension.DimensionField
The name of the dimension field.
getName() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionUpdateDate
 
getName() - Method in enum com.yahoo.bard.webservice.data.dimension.impl.DefaultDimensionFieldTag
 
getName() - Method in interface com.yahoo.bard.webservice.data.dimension.Tag
Gets the String representation of the tag.
getName() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
getName() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetricInfo
Returns the name of the metric.
getName() - Method in class com.yahoo.bard.webservice.data.time.AllGranularity
 
getName() - Method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
 
getName() - Method in interface com.yahoo.bard.webservice.data.time.Granularity
Get the name of the granularity.
getName() - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
 
getName() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
getName() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
 
getName() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
 
getName() - Method in class com.yahoo.bard.webservice.druid.model.datasource.TableDataSource
 
getName() - Method in interface com.yahoo.bard.webservice.druid.model.MetricField
Get the name of the metric field in the response.
getName() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
 
getName() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation
 
getName() - Method in interface com.yahoo.bard.webservice.logging.LogInfo
Get the name of this logging information part.
getName() - Method in class com.yahoo.bard.webservice.logging.TimedPhase
 
getName() - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadata
Get the name of this datasource.
getName() - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
getName() - Method in class com.yahoo.bard.webservice.table.Column
Getter for column name.
getName() - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
 
getName() - Method in class com.yahoo.bard.webservice.table.LogicalTable
 
getName() - Method in interface com.yahoo.bard.webservice.table.Table
The name for this table.
getName() - Method in enum com.yahoo.bard.webservice.web.filters.BouncerAuthorizationStatus
 
getName() - Method in enum com.yahoo.bard.webservice.web.responseprocessors.DruidJsonRequestContentKeys
 
getName() - Method in enum com.yahoo.bard.webservice.web.responseprocessors.DruidJsonResponseContentKeys
 
getName() - Method in enum com.yahoo.bard.webservice.web.responseprocessors.ResponseContextKeys
 
getName() - Method in enum com.yahoo.bard.webservice.web.TimeMacro
 
getName() - Method in interface com.yahoo.wiki.webservice.data.config.auto.DataSourceConfiguration
Gets the name of a datasource as would be stored in Druid.
getName() - Method in class com.yahoo.wiki.webservice.data.config.auto.TableConfig
Gets the name of the table.
getName() - Method in enum com.yahoo.wiki.webservice.data.config.dimension.WikiDimensionField
 
getNameAndUrl() - Method in class com.yahoo.bard.webservice.druid.client.DruidServiceConfig
Return the name and the URL of this druid service.
getNames() - Method in class com.yahoo.bard.webservice.druid.model.datasource.DataSource
Returns a set of identifiers used by Fili to identify this data source's physical tables.
getNames() - Method in class com.yahoo.bard.webservice.druid.model.datasource.QueryDataSource
 
getNames() - Method in class com.yahoo.bard.webservice.druid.model.datasource.TableDataSource
 
getNames() - Method in class com.yahoo.bard.webservice.druid.model.datasource.UnionDataSource
 
getNamespace() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.NamespaceLookup
 
getNamespaces() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultLookupDimensionConfig
 
getNamespaces() - Method in interface com.yahoo.bard.webservice.data.config.dimension.LookupDimensionConfig
Returns a list of namespaces used to configure the Lookup dimension.
getNamespaces() - Method in class com.yahoo.bard.webservice.data.dimension.impl.LookupDimension
 
getNewRelBuilder(String) - Method in class com.yahoo.bard.webservice.sql.helper.CalciteHelper
Creates a RelBuilder which can be used to build sql.
getNewRelToSqlConverter() - Method in class com.yahoo.bard.webservice.sql.helper.CalciteHelper
Creates a new RelToSqlConverter using the dialect from the datasource this was constructed with.
getNewSqlWriter() - Method in class com.yahoo.bard.webservice.sql.helper.CalciteHelper
Creates a new SqlPrettyWriter using the dialect from the datasource this was constructed with.
getNextIfAvailable - Variable in class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Function to iterate an iterator if it has a next element, otherwise return null.
getNextPage() - Method in class com.yahoo.bard.webservice.util.AllPagesPagination
 
getNextPage() - Method in interface com.yahoo.bard.webservice.util.Pagination
Gets next page if it exists.
getNextPage() - Method in class com.yahoo.bard.webservice.util.SinglePagePagination
 
getNoDimensionData(UriInfo, ContainerRequestContext, String, String, String, String, String, String, String, String, String, String, String, String, String, String, Boolean, AsyncResponse) - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
Resource method with tableName and timeGrain as a mandatory path parameter.
getNonResponseContextMapper() - Method in class com.yahoo.bard.webservice.data.PreResponseDeserializer
 
getNonUiServiceConfig() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Deprecated.
The druid Non-UI service config is deprecated, please use DruidClientConfigHelper.getServiceConfig().
getNotifications() - Method in interface com.yahoo.bard.webservice.async.broadcastchannels.BroadcastChannel
This method returns a Hot Observable (Observable which emits events whether someone is listening or not) that emits all the notifications passed to it by Bard instances in the cluster.
getNotifications() - Method in class com.yahoo.bard.webservice.async.broadcastchannels.RedisBroadcastChannel
 
getNotifications() - Method in class com.yahoo.bard.webservice.async.broadcastchannels.SimpleBroadcastChannel
 
getNumberOfIncoming() - Method in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
getNumberOfOutgoing() - Method in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
getNumberOfQueries() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
getNumericField(String) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Deprecated.
use the static version MetricMaker.getNumericField(MetricField) by preference
getNumericField(MetricField) - Static method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Prepare a post aggregation for a field expecting a numeric value.
getNumResults() - Method in class com.yahoo.bard.webservice.util.AllPagesPagination
 
getNumResults() - Method in interface com.yahoo.bard.webservice.util.Pagination
Get the size of all the data.
getNumResults() - Method in class com.yahoo.bard.webservice.util.SinglePagePagination
 
getObjectMappers() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getObjectMappers() - Method in class com.yahoo.bard.webservice.web.JsonAndJsonApiResponseWriter
 
getObjectMappers() - Method in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
 
getOperation() - Method in class com.yahoo.bard.webservice.async.jobs.stores.JobRowFilter
 
getOperation() - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
getOperation() - Method in class com.yahoo.bard.webservice.web.ApiHaving
 
getOptimize() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
getOptimize() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
getOrDefault(String, String) - Method in interface com.yahoo.bard.webservice.data.dimension.KeyValueStore
Get the value for a key from store or provide a default.
getOutputFormatter() - Static method in class com.yahoo.bard.webservice.util.DateTimeFormatterFactory
Get the output formatter for the system.
getOutputName() - Method in class com.yahoo.bard.webservice.druid.model.dimension.DefaultDimensionSpec
 
getOutputName() - Method in class com.yahoo.bard.webservice.druid.model.dimension.ExtractionDimensionSpec
 
getOverlappingSubintervals(Collection<Interval>, Collection<Interval>) - Static method in class com.yahoo.bard.webservice.util.IntervalUtils
Find all the interval overlaps between two collections of intervals.
getOverlappingSubintervals(Set<Interval>, Set<Interval>) - Static method in class com.yahoo.bard.webservice.util.IntervalUtils
Find all the interval overlaps between two collections of intervals.
getPackageVariableName(String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get a package scoped variable name.
getPage() - Method in class com.yahoo.bard.webservice.util.AllPagesPagination
 
getPage() - Method in interface com.yahoo.bard.webservice.util.Pagination
Gets the number of the current page.
getPage() - Method in class com.yahoo.bard.webservice.util.SinglePagePagination
 
getPage(Collection<T>) - Method in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
Deprecated.
Pagination is moving to a Stream and pushing creation of the page to a more general method (ApiRequest.getPage(Pagination)) to allow for more flexibility in how pagination is done.
getPage(Pagination<T>) - Method in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
Add links to the response builder and return a stream with the requested page from the raw data.
getPage(Collection<T>) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Deprecated.
Pagination is moving to a Stream and pushing creation of the page to a more general method (ApiRequestImpl.getPage(Pagination)) to allow for more flexibility in how pagination is done.
getPage(Pagination<T>) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Add links to the response builder and return a stream with the requested page from the raw data.
getPage(Pagination<?>) - Method in enum com.yahoo.bard.webservice.web.util.PaginationLink
Get the page number if the specified page exists relative to the current page.
getPage(int) - Method in class com.yahoo.bard.webservice.web.util.PaginationParameters
Returns the requested page number.
getPageOfData() - Method in class com.yahoo.bard.webservice.util.AllPagesPagination
 
getPageOfData() - Method in interface com.yahoo.bard.webservice.util.Pagination
Get a list of results corresponding to the current page of data.
getPageOfData() - Method in class com.yahoo.bard.webservice.util.SinglePagePagination
 
getPagination() - Method in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
Get the pagination object associated with this request.
getPagination() - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
getPagination() - Method in class com.yahoo.bard.webservice.web.ResponseData
 
getPaginationLinks() - Method in class com.yahoo.bard.webservice.web.ResponseData
 
getPaginationParameters() - Method in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
Get the requested pagination parameters.
getPaginationParameters() - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
getPartialIntervalsWithDefault(Map<String, Serializable>) - Static method in class com.yahoo.bard.webservice.web.handlers.PartialDataRequestHandler
Return the missing intervals from the context.
getPartitionNum() - Method in class com.yahoo.bard.webservice.druid.model.metadata.NumberedShardSpec
Getter for partition number.
getPartitions() - Method in class com.yahoo.bard.webservice.druid.model.metadata.NumberedShardSpec
Getter for the number of partitions.
getPattern() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.PartialExtractionFunction
 
getPattern() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegularExpressionExtractionFunction
 
getPattern() - Method in class com.yahoo.bard.webservice.druid.model.dimension.RegexFilteredDimensionSpec
 
getPattern() - Method in class com.yahoo.bard.webservice.druid.model.filter.RegularExpressionFilter
 
getPattern() - Method in class com.yahoo.bard.webservice.druid.model.query.RegexSearchQuerySpec
 
getPendingLookups() - Method in class com.yahoo.bard.webservice.metadata.RegisteredLookupMetadataLoadTask
Returns a set of lookup namespaces that have not been loaded to Druid yet.
getPeriod() - Method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
 
getPeriod() - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
Get the Period of the TimeGrain.
getPeriod() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
getPeriodString() - Method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
 
getPeriodString() - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
Period string to use when serializing.
getPeriodString() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
getPerPage() - Method in class com.yahoo.bard.webservice.util.AllPagesPagination
 
getPerPage() - Method in interface com.yahoo.bard.webservice.util.Pagination
Gets the maximum size of a page.
getPerPage() - Method in class com.yahoo.bard.webservice.util.SinglePagePagination
 
getPerPage() - Method in class com.yahoo.bard.webservice.web.util.PaginationParameters
 
getPhysicalColumnName(String) - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
getPhysicalColumnName(String) - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
 
getPhysicalColumnName(String) - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Translate a logical name into a physical column name.
getPhysicalColumnName(String) - Method in class com.yahoo.bard.webservice.table.PhysicalTableSchema
Translate a logical name into a physical column name.
getPhysicalDictionary() - Method in class com.yahoo.bard.webservice.data.config.ResourceDictionaries
 
getPhysicalName() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
 
getPhysicalName() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
The internal, physical name for the dimension.
getPhysicalTable() - Method in class com.yahoo.bard.webservice.druid.model.datasource.DataSource
Get the data source physical table.
getPhysicalTableDictionary() - Method in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
 
getPhysicalTableResolver() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Select a physical table resolver class.
getPhysicalTables() - Method in class com.yahoo.bard.webservice.druid.model.datasource.DataSource
Deprecated.
DataSources can only have a single table, and any unioning semantics is done at the PhysicalTable level
getPhysicalTables() - Method in class com.yahoo.bard.webservice.table.TableGroup
Getter for set of physical tables.
getPopulateCache() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
getPostAggregations() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getPostAggregations() - Method in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidAggregationQuery
 
getPostAggregations() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidAggregationQuery
Returns the post-aggregations of the query.
getPostAggregations() - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
getPostAggregationType() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FuzzySetPostAggregation
 
getPreResponseReadyNotifications() - Method in class com.yahoo.bard.webservice.async.workflows.AsynchronousWorkflows
Returns an Observable that emits notifications that the query results have been stored in the PreResponseStore.
getPreviousPage() - Method in class com.yahoo.bard.webservice.util.AllPagesPagination
 
getPreviousPage() - Method in interface com.yahoo.bard.webservice.util.Pagination
Gets previous page if it exists.
getPreviousPage() - Method in class com.yahoo.bard.webservice.util.SinglePagePagination
 
getPreviousStop() - Method in class com.yahoo.bard.webservice.druid.model.orderby.TopNMetric
Getter for the previousStop of TopNMetric.
getPriority() - Method in class com.yahoo.bard.webservice.druid.client.DruidServiceConfig
The priority value attached to druid request queries used in the metadata block of the query.
getPriority() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
getProperties() - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadata
Get the properties of the datasource.
getQuery() - Method in class com.yahoo.bard.webservice.druid.model.datasource.DataSource
Get the query that defines the data source.
getQuery() - Method in class com.yahoo.bard.webservice.druid.model.datasource.QueryDataSource
 
getQuery() - Method in class com.yahoo.bard.webservice.druid.model.filter.SearchFilter
 
getQuery() - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
getQueryCounter() - Method in class com.yahoo.bard.webservice.logging.blocks.BardQueryInfo
 
getQueryId() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
getQueryType() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getQueryType() - Method in class com.yahoo.bard.webservice.druid.model.filter.SearchFilter
 
getQueryType() - Method in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidQuery
 
getQueryType() - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidQuery
Returns the type of the query.
getQueryValue() - Method in class com.yahoo.bard.webservice.druid.model.filter.SearchFilter
 
getQueryWeightThreshold(Granularity) - Method in class com.yahoo.bard.webservice.web.util.QueryWeightUtil
Get the weight threshold for the granularity.
getRangeLists(DataSourceMetadata) - Static method in class com.yahoo.bard.webservice.metadata.DataSourceMetadata
Return a pair of maps containing the ranges of availability for dimensions and metrics respectively.
getReason(Throwable) - Static method in class com.yahoo.bard.webservice.async.ErrorUtils
Method to get the reason for an error.
getReason() - Method in exception com.yahoo.bard.webservice.async.ResponseException
 
getReasonPhrase() - Method in enum com.yahoo.bard.webservice.web.ResponseCode
 
getRegistry() - Static method in class com.yahoo.bard.webservice.application.HealthCheckRegistryFactory
Get the global registry.
getRegistry() - Static method in class com.yahoo.bard.webservice.application.MetricRegistryFactory
Get the global registry for metrics.
getReplaceMissingValueWith() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
getReplaceMissingValueWith() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
getRequestDimensions() - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
 
getRequestedApiDimensionFields() - Method in class com.yahoo.bard.webservice.web.ResponseData
 
getRequestGranularity() - Method in class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
 
getRequestLog() - Method in class com.yahoo.bard.webservice.web.responseprocessors.LoggingContext
 
getRequestMapper() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getRequestMapper() - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
 
getRequestMappers(ResourceDictionaries) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Get a map of named RequestMappers.
getResourceDictionaries() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getResourceDictionaries() - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
 
getResourceDictionaries() - Method in class com.yahoo.bard.webservice.web.RequestMapper
 
getResourceDictionaries() - Method in interface com.yahoo.bard.webservice.web.util.BardConfigResources
The collection of resource dictionaries.
getResponse(String) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Map the given jsonString to a Response object.
getResponseContext() - Method in class com.yahoo.bard.webservice.data.PreResponseSerializationProxy
 
getResponseContext() - Method in class com.yahoo.bard.webservice.web.PreResponse
 
getResponseContext() - Method in class com.yahoo.bard.webservice.web.responseprocessors.CacheV2ResponseProcessor
 
getResponseContext() - Method in class com.yahoo.bard.webservice.web.responseprocessors.CachingResponseProcessor
 
getResponseContext() - Method in class com.yahoo.bard.webservice.web.responseprocessors.DruidPartialDataResponseProcessor
 
getResponseContext() - Method in class com.yahoo.bard.webservice.web.responseprocessors.EtagCacheResponseProcessor
 
getResponseContext() - Method in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
 
getResponseContext() - Method in interface com.yahoo.bard.webservice.web.responseprocessors.ResponseProcessor
The response context allows state to be injected from construction and visible across response processor layers as necessary.
getResponseContext() - Method in class com.yahoo.bard.webservice.web.responseprocessors.SplitQueryResponseProcessor
 
getResponseContext() - Method in class com.yahoo.bard.webservice.web.responseprocessors.WeightCheckResponseProcessor
 
getResponseContextMapper() - Method in class com.yahoo.bard.webservice.data.PreResponseDeserializer
 
getResponseLength() - Method in class com.yahoo.bard.webservice.logging.blocks.Epilogue
 
getResponseStream() - Method in class com.yahoo.bard.webservice.web.AbstractResponse
Get a resource method that can be used to stream this response as an entity.
getResponseStream() - Method in interface com.yahoo.bard.webservice.web.ResponseStream
Gets a resource method that can be used to stream this response as an entity.
getResults(String, long) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Get an Observable wrapping a PreResponse.
getResultsBaseUrl(UriInfo) - Static method in interface com.yahoo.bard.webservice.async.jobs.payloads.JobPayloadBuilder
Get the UriBuilder for the /jobs/ticket/results endpoint.
getResultSerializationProxies() - Method in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
getResultSet() - Method in class com.yahoo.bard.webservice.web.PreResponse
 
getResultSet() - Method in class com.yahoo.bard.webservice.web.ResponseData
 
getResultSetMapper(String) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.RawAggregationMetricMaker
The result set mapper associated with this metric.
getResultSetMapper(String) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.SketchCountMaker
Deprecated.
 
getResultSetMapper(String) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.ThetaSketchMaker
 
getResultSetSerializationProxy() - Method in class com.yahoo.bard.webservice.data.PreResponseSerializationProxy
 
getResultsUrl(String, UriInfo) - Static method in interface com.yahoo.bard.webservice.async.jobs.payloads.JobPayloadBuilder
Get the job results url.
getRetainMissingValue() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
getRetainMissingValue() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
getRetention() - Method in class com.yahoo.bard.webservice.table.LogicalTable
 
getRight() - Method in class com.yahoo.bard.webservice.util.Either
Returns the Right value wrapped in this Either.
getRowKey(String, String) - Static method in class com.yahoo.bard.webservice.util.DimensionStoreKeyUtils
Returns a key that allows access to the dimension rows of a given dimension.
getRowMap() - Method in class com.yahoo.bard.webservice.async.jobs.jobrows.JobRow
Coerces the JobRow into a mapping from the names of JobFields to their values.
getRowMap() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionRow
Get DimensionRows as a map of Field Name and Value.
getRuntimeProperties() - Method in class com.yahoo.bard.webservice.config.LayeredFileSystemConfig
 
getRuntimeProperties() - Method in interface com.yahoo.bard.webservice.config.SystemConfig
The properties file used to hold modified SystemConfiguration values.
getSchema() - Method in class com.yahoo.bard.webservice.data.ResultSet
Getter for ResultSet schema.
getSchema(SerializerProvider, Type) - Method in class com.yahoo.bard.webservice.druid.serializers.HasDruidNameSerializer
 
getSchema() - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
getSchema() - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
 
getSchema() - Method in class com.yahoo.bard.webservice.table.LogicalTable
 
getSchema() - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
 
getSchema() - Method in interface com.yahoo.bard.webservice.table.Table
The schema for this table.
getSchemaName() - Method in class com.yahoo.bard.webservice.table.SqlPhysicalTable
Gets the sql schema name this table belongs to.
getScope(List<S>) - Method in interface com.yahoo.bard.webservice.util.Scope
Resolves a child scope.
getScope(List<S>) - Method in class com.yahoo.bard.webservice.util.ScopeMap
 
getScope(S...) - Method in class com.yahoo.bard.webservice.util.ScopeMap
Helper function converting the varargs to array.
getSearchDimensions() - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
getSearchProvider() - Method in class com.yahoo.bard.webservice.data.config.dimension.DefaultKeyValueStoreDimensionConfig
 
getSearchProvider() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
The search provider for field value lookups on this dimension.
getSearchProvider() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Getter for search provider.
getSearchProvider() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getSecurityContext() - Method in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
getSegmentHash(Stream<SortedMap<DateTime, Map<String, SegmentInfo>>>) - Method in class com.yahoo.bard.webservice.metadata.SegmentIntervalsHashIdGenerator
Given a set of requested segments, calculate a hash to represent the segment set Id.
getSegments() - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadata
Get the segments of the datasource.
getSegments(Set<DataSourceName>) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataService
Get all the segments associated with the given Set of data source names.
getSegmentSetId(DruidAggregationQuery<?>) - Method in interface com.yahoo.bard.webservice.metadata.QuerySigningService
Return an identifier that corresponds to the set of segments that a query references.
getSegmentSetId(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.metadata.SegmentIntervalsHashIdGenerator
 
getSelfUrl(String, UriInfo) - Static method in interface com.yahoo.bard.webservice.async.jobs.payloads.JobPayloadBuilder
Get the url for the given ticket.
getSequenceNumber() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
getSerializedSchema() - Method in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
getServiceConfig() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Create a druid service configuration object.
getServiceConfig() - Method in interface com.yahoo.bard.webservice.druid.client.DruidWebService
Returns the service configuration object for this web service.
getServiceConfig() - Method in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
getShardSpec() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
Getter for the shard spec of this segment partition.
getSize() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchAggregation
 
getSize() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
 
getSize() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
 
getSize() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
Getter for the size of this segment partition.
getSketchField(String) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Deprecated.
use the static version MetricMaker.getSketchField(MetricField) by preference
getSketchField(MetricField) - Static method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Prepare a post aggregation for a field expecting a sketch value.
getSlice() - Method in interface com.yahoo.bard.webservice.web.apirequest.SlicesApiRequest
Returns a slice object.
getSlice() - Method in class com.yahoo.bard.webservice.web.apirequest.SlicesApiRequestImpl
 
getSliceBySliceName(String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.SlicesServlet
Endpoint to get all the dimensions and metrics serviced by a druid slice.
getSliceDetailUrl(String, UriInfo) - Static method in class com.yahoo.bard.webservice.web.endpoints.SlicesServlet
Get the URL of the slice.
getSlicedIntervals(Collection<Interval>, Granularity) - Static method in class com.yahoo.bard.webservice.util.IntervalUtils
Simplify raw intervals and return a map of intervals (dividing them by the grain) to the ordinal of the interval.
getSlices() - Method in interface com.yahoo.bard.webservice.web.apirequest.SlicesApiRequest
Returns a set of all available slices.
getSlices() - Method in class com.yahoo.bard.webservice.web.apirequest.SlicesApiRequestImpl
 
getSlices(String, String, String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.SlicesServlet
Endpoint to get all the performance slices.
getSort() - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
getSort(RelBuilder, DruidAggregationQuery<?>, ApiToFieldMapper, String) - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Finds the sorting for a druid query.
getSortDirection(List<String>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Extract valid sort direction.
getSorts() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
A prioritized list of sort columns.
getSorts() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getSourceTable() - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
 
getSqlAggFunction() - Method in class com.yahoo.bard.webservice.sql.aggregation.SqlAggregation
Gets the sql aggregation to be used on the field.
getSqlAggregation(Aggregation, ApiToFieldMapper) - Method in enum com.yahoo.bard.webservice.sql.aggregation.DefaultSqlAggregationType
 
getSqlAggregation(Aggregation, ApiToFieldMapper) - Method in interface com.yahoo.bard.webservice.sql.aggregation.SqlAggregationType
Builds a SqlAggregation which contains all the necessary information to build an aggregation in sql.
getSqlAggregationAsName() - Method in class com.yahoo.bard.webservice.sql.aggregation.SqlAggregation
Gets the alias name to be used for the aggregation (i.e.
getSqlAggregationFieldName() - Method in class com.yahoo.bard.webservice.sql.aggregation.SqlAggregation
The field name to call the aggregation on (i.e.
getStandardError(Subject, DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
Get the standard error callback.
getStandardFailure(Subject, DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
Get the standard failure callback.
getStatus() - Method in exception com.yahoo.bard.webservice.web.RequestValidationException
 
getStatusCode() - Method in exception com.yahoo.bard.webservice.async.ResponseException
 
getStatusCode() - Method in enum com.yahoo.bard.webservice.web.ResponseCode
 
getStorageStrategy() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Returns the StorageStrategy of the dimension.
getStorageStrategy() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
getStringProperty(String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getStringProperty(String, String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Get property value for a key.
getSubsetByType(Collection<T>, Class<K>) - Static method in class com.yahoo.bard.webservice.util.Utils
Given a collection of objects which share the same super class, return the subset of objects that share a common sub class.
getSupportedDruidAggregations() - Method in enum com.yahoo.bard.webservice.sql.aggregation.DefaultSqlAggregationType
 
getSupportedDruidAggregations() - Method in interface com.yahoo.bard.webservice.sql.aggregation.SqlAggregationType
Returns a set of supported druid aggregations.
getSynchronousPayload() - Method in class com.yahoo.bard.webservice.async.workflows.AsynchronousWorkflows
Returns an Observable that emits the query results to send to the user.
getSyncResultsUrl(String, UriInfo) - Static method in interface com.yahoo.bard.webservice.async.jobs.payloads.JobPayloadBuilder
Get the url for obtaining the job results synchronously.
getSystemTimeZone() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getSystemTimeZone() - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
SystemTimeZone isn't used in TablesServlet but is part of the configuration interface, so this is an empty implementation.
getSystemTimeZone() - Method in interface com.yahoo.bard.webservice.web.util.BardConfigResources
The configured default time zone for dates.
getTable() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
The logical table for this request.
getTable() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getTable() - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
Returns the LogicalTable requested in the table API request URL.
getTable() - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
getTable(String, String, String, String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Get all grain-specific logical tables for a logical table name as a summary list.
getTableAlignment() - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
getTableAlignment() - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
 
getTableAlignment() - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Get a date time that the table will align to based on grain and available intervals.
getTableByGrain(String, String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Get unconstrained logical table details for a grain-specific logical table.
getTableByGrainAndConstraint(String, String, List<PathSegment>, String, String, String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Get constrained logical table details for a grain-specific logical table.
getTableGroup() - Method in class com.yahoo.bard.webservice.table.LogicalTable
 
getTableLoader() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Create a Table Loader.
getTableLoader() - Method in class com.yahoo.wiki.webservice.application.GenericBinderFactory
 
getTableLoader() - Method in class com.yahoo.wiki.webservice.application.WikiBinderFactory
 
getTableName() - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
getTableName() - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
 
getTableName() - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Deprecated.
Use Table::getName instead
getTableName() - Method in interface com.yahoo.wiki.webservice.data.config.auto.DataSourceConfiguration
Gets the name of the datasource to be used as a TableName in fili.
getTableName() - Method in class com.yahoo.wiki.webservice.data.config.auto.TableConfig
Gets the TableName of the current datasource.
getTables() - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
Returns a set of LogicalTables associated with a table API request.
getTables() - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
getTablesFullView(String, String, UriInfo, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Get all the tables full view.
getTableToMetricsMap(ResourceDictionaries) - Method in class com.yahoo.bard.webservice.data.config.table.MetricUnionCompositeTableDefinition
Returns a map from availability to set of metrics.
getTags() - Method in interface com.yahoo.bard.webservice.data.dimension.TaggedDimensionField
Get a set of tags associated to the current field.
getTemplateDruidQuery() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
getTemplateDruidQueryMerger() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
getThreads() - Method in class com.yahoo.bard.webservice.logging.blocks.Threads
 
getThreshold() - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
getTimeConverter() - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
 
getTimeGrain() - Method in class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
 
getTimeGrain() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
getTimeGrain() - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Deprecated.
use getSchema().getTimeGrain()
getTimeGrain() - Method in class com.yahoo.bard.webservice.table.PhysicalTableSchema
Granularity.
getTimeGrain(Interval) - Static method in class com.yahoo.bard.webservice.util.IntervalUtils
Find a valid timegrain for the interval based on the start and end date of the interval.
getTimeout() - Method in class com.yahoo.bard.webservice.druid.client.DruidServiceConfig
The timeout for requests to druid.
getTimeout() - Method in interface com.yahoo.bard.webservice.druid.client.DruidWebService
Returns the timeout configured on this web service.
getTimeout() - Method in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
getTimeout() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
getTimeStamp() - Method in class com.yahoo.bard.webservice.data.Result
The timestamp representing the start moment of the aggregated record.
getTimeStamp() - Method in class com.yahoo.bard.webservice.data.ResultSerializationProxy
 
getTimestampColumn() - Method in class com.yahoo.bard.webservice.table.SqlPhysicalTable
Gets the name of the timestamp column backing this table.
getTimeZone() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
getTimeZone() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
Returns time zone of this TimeFormatExtractionFunction.
getTimeZone(Granularity) - Static method in class com.yahoo.bard.webservice.util.DateTimeUtils
Given a granularity, produce a time zone.
getTimeZone() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
The date time zone to apply to the dateTime parameter and to express the response and granularity in.
getTimeZone() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getTimeZoneName() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
getToken(ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
getToken(ContainerRequestContext) - Method in interface com.yahoo.bard.webservice.web.RateLimiter
Request a token from the RateLimiter, which represents an in-flight request.
getTopN() - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
The limit per time bucket for a top n query.
getTopN() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
getTotalDuration(Collection<Interval>) - Static method in class com.yahoo.bard.webservice.util.IntervalUtils
Sum the length of the intervals in this collection.
getType() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
The type of the Dimension this DimensionConfiguration is intended to build.
getType() - Method in interface com.yahoo.bard.webservice.data.config.dimension.LookupDimensionConfig
 
getType() - Method in interface com.yahoo.bard.webservice.data.config.dimension.RegisteredLookupDimensionConfig
 
getType() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
getType() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetricInfo
Returns the type of the metric.
getType() - Method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
 
getType() - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
Type of Granularity to use when serializing.
getType() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
The Type name for the aggregation in the druid configuration.
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CountAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.DoubleMaxAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.DoubleMinAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.DoubleSumAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.LongMaxAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.LongMinAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.LongSumAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.MaxAggregation
Deprecated.
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.MinAggregation
Deprecated.
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchCountAggregation
Deprecated.
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchMergeAggregation
Deprecated.
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.ThetaSketchAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.datasource.DataSource
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.dimension.DimensionSpec
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.ExtractionFunction
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.Lookup
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.filter.Filter
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.having.Having
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.having.NumericHaving
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.metadata.NumberedShardSpec
Getter for type.
getType() - Method in class com.yahoo.bard.webservice.druid.model.orderby.LimitSpec
Getter for type of orderBy.
getType() - Method in class com.yahoo.bard.webservice.druid.model.orderby.TopNMetric
Getter for the type of TopNMetric.
getType() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation
 
getType() - Method in class com.yahoo.bard.webservice.druid.model.query.SearchQuerySpec
 
getType() - Method in class com.yahoo.bard.webservice.logging.blocks.BardQueryInfo
 
getType() - Method in enum com.yahoo.bard.webservice.web.HavingOperation
 
getUiServiceConfig() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
Deprecated.
The druid UI service config is deprecated, please use DruidClientConfigHelper.getServiceConfig().
getUncoveredIntervalsLimit() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
getUnhealthy() - Method in class com.yahoo.bard.webservice.web.filters.HealthCheckFilter
Get all the failing healthchecks.
getUnit() - Method in class com.yahoo.bard.webservice.logging.TimedPhase
 
getUriInfo() - Method in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
Get the uri info.
getUriInfo() - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
getUrl() - Method in class com.yahoo.bard.webservice.druid.client.DruidServiceConfig
The URL for the primary servlet of the druid service.
getUseCache() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
getValidTimeGrain() - Method in interface com.yahoo.wiki.webservice.data.config.auto.DataSourceConfiguration
Gets the TimeGrain which is valid for use in queries.
getValidTimeGrain() - Method in class com.yahoo.wiki.webservice.data.config.auto.TableConfig
Gets the valid TimeGrains for the datasource.
getValue() - Method in class com.yahoo.bard.webservice.data.cache.MemTupleDataCache.DataEntry
 
getValue() - Method in interface com.yahoo.bard.webservice.data.cache.TupleDataCache.DataEntry
Returns the value of this data cache entry.
getValue() - Method in class com.yahoo.bard.webservice.druid.model.filter.ExtractionFilter
Deprecated.
 
getValue() - Method in class com.yahoo.bard.webservice.druid.model.filter.SelectorFilter
 
getValue() - Method in class com.yahoo.bard.webservice.druid.model.having.NumericHaving
 
getValue() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ConstantPostAggregation
 
getValue() - Method in class com.yahoo.bard.webservice.druid.model.query.InsensitiveContainsSearchQuerySpec
 
getValues() - Method in class com.yahoo.bard.webservice.async.jobs.stores.JobRowFilter
 
getValues() - Method in class com.yahoo.bard.webservice.config.FeatureFlagRegistry
 
getValues() - Method in class com.yahoo.bard.webservice.druid.model.dimension.ListFilteredDimensionSpec
 
getValues() - Method in class com.yahoo.bard.webservice.druid.model.filter.InFilter
Return the list of values to filter on.
getValues() - Method in class com.yahoo.bard.webservice.druid.model.query.FragmentSearchQuerySpec
 
getValues() - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
getValues() - Method in class com.yahoo.bard.webservice.web.ApiHaving
 
getVersion() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
Getter for the version of this segment partition.
getVolatileIntervals(Granularity, List<Interval>, PhysicalTable) - Method in class com.yahoo.bard.webservice.data.volatility.DefaultingVolatileIntervalsService
 
getVolatileIntervals() - Method in class com.yahoo.bard.webservice.data.volatility.NoVolatileIntervalsFunction
 
getVolatileIntervals() - Method in class com.yahoo.bard.webservice.data.volatility.TimeOffsetVolatileIntervalsFunction
 
getVolatileIntervals() - Method in interface com.yahoo.bard.webservice.data.volatility.VolatileIntervalsFunction
Retrieve a list of which intervals are volatile.
getVolatileIntervals(Granularity, List<Interval>, PhysicalTable) - Method in interface com.yahoo.bard.webservice.data.volatility.VolatileIntervalsService
Retrieve a simplified sublist of the given intervals aligned to the specified time buckets and that are partially or fully volatile.
getVolatileIntervals(DruidAggregationQuery<?>, PhysicalTable) - Method in interface com.yahoo.bard.webservice.data.volatility.VolatileIntervalsService
Deprecated.
Exists solely for backwards compatibility. VolatileIntervalsService.getVolatileIntervals(Granularity, List, PhysicalTable) should be used instead
getVolatileIntervals() - Method in class com.yahoo.bard.webservice.web.ResponseData
 
getVolatileIntervalsService() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Initialize the service that decides which intervals in a request are volatile relative to a physical table.
getVolatileIntervalsWithDefault(Map<String, Serializable>) - Static method in class com.yahoo.bard.webservice.web.handlers.VolatileDataRequestHandler
Return the volatile intervals from the context.
getWebService() - Method in class com.yahoo.bard.webservice.web.handlers.WebServiceHandler
 
getWorkflow() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Return a workflow class to bind to RequestWorkflowProvider.
getWorstCaseWeightEstimate(DruidAggregationQuery<?>) - Static method in class com.yahoo.bard.webservice.druid.model.query.WeightEvaluationQuery
Evaluate Druid query for worst possible case expensive aggregation that could bring down Druid.
getWriter() - Method in class com.yahoo.bard.webservice.web.endpoints.DataServlet
 
GIT_SHA_KEY - Static variable in class com.yahoo.bard.webservice.application.healthchecks.VersionHealthCheck
 
globalCount - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
grain - Variable in class com.yahoo.bard.webservice.logging.blocks.TableRequest
 
Granularity - Interface in com.yahoo.bard.webservice.data.time
A granularity describes a way of dividing up or organizing time.
granularity - Variable in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidFactQuery
 
granularity - Variable in class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessor
 
GranularityComparator - Class in com.yahoo.bard.webservice.table.resolver
Comparator to prefer coarser physical tables (i.e.
GranularityComparator() - Constructor for class com.yahoo.bard.webservice.table.resolver.GranularityComparator
A constructor provided in case other classes need to subclass GranularityComparator.
GranularityDictionary - Class in com.yahoo.bard.webservice.data.time
Map of Granularity name to Granularity.
GranularityDictionary() - Constructor for class com.yahoo.bard.webservice.data.time.GranularityDictionary
 
GranularityParseException - Exception in com.yahoo.bard.webservice.util
Thrown when there's a problem parsing a string into a Granularity.
GranularityParseException(String) - Constructor for exception com.yahoo.bard.webservice.util.GranularityParseException
Constructor.
GranularityParser - Interface in com.yahoo.bard.webservice.data.time
A GranularityParser produces granularities from names and time zones.
groupByDimensions - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
GroupByQuery - Class in com.yahoo.bard.webservice.druid.model.query
Druid groupBy query.
GroupByQuery(DataSource, Granularity, Collection<Dimension>, Filter, Having, Collection<Aggregation>, Collection<PostAggregation>, Collection<Interval>, LimitSpec, QueryContext, boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
Constructor.
GroupByQuery(DataSource, Granularity, Collection<Dimension>, Filter, Having, Collection<Aggregation>, Collection<PostAggregation>, Collection<Interval>, LimitSpec) - Constructor for class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
Constructor.
groupIntervalByColumn(DataSourceMetadata) - Static method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataService
Group interval in segment metadata by column.
groupSegmentByTime(DataSourceMetadata) - Static method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataService
Group segment metadata by date time.

H

handleJobResponse(String, JobsApiRequestImpl) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Process a request to get job payload.
handlePreResponse(String, JobsApiRequestImpl, AsyncResponse, Observable<PreResponse>, boolean) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
If isEmpty is true, call the method to send the job payload to the user else call the method to send the job result to the user.
handlePreResponseWithError(PreResponse, UriInfo, Optional<PaginationParameters>) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Check whether the PreResponse contains an error and if it does, return an Observable wrapping the error else return an Observable wrapping the PreResponse as is.
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.AsyncWebServiceRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.CacheRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.CacheV2RequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in interface com.yahoo.bard.webservice.web.handlers.DataRequestHandler
Handle the response, passing the request down the chain as necessary.
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.DateTimeSortRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.DebugRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.DruidPartialDataRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.EtagCacheRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.PaginationRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.PartialDataRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.SplitQueryRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.SqlRequestHandler
Handles a request by detecting if it's a sql backed table and sending to a sql backend.
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.TopNMapperRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.VolatileDataRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.WebServiceHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.WebServiceSelectorRequestHandler
 
handleRequest(RequestContext, DataApiRequest, DruidAggregationQuery<?>, ResponseProcessor) - Method in class com.yahoo.bard.webservice.web.handlers.WeightCheckRequestHandler
 
handleResultsResponse(Observable<PreResponse>, AsyncResponse, ApiRequest) - Method in class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Process a request to get job results.
hasAnyRows(Set<ApiFilter>) - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Determine if any rows match these filters.
HasDruidName - Interface in com.yahoo.bard.webservice.druid.model
A marker interface for things which have a druid name.
HasDruidNameSerializer - Class in com.yahoo.bard.webservice.druid.serializers
Serializer to write out fields which have druid names.
HasDruidNameSerializer() - Constructor for class com.yahoo.bard.webservice.druid.serializers.HasDruidNameSerializer
Note: usually you should NOT create new instances, but instead use HasDruidNameSerializer.INSTANCE which is stateless and fully thread-safe.
hasError(Response.Status) - Method in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
Return true if response status code indicates an error.
hash(String) - Method in class com.yahoo.bard.webservice.data.cache.HashDataCache
Get the hash encoding of a key string.
hash(String) - Method in class com.yahoo.bard.webservice.data.cache.MemTupleDataCache
Get the hash encoding of a key string.
hashCode() - Method in class com.yahoo.bard.webservice.async.jobs.jobrows.JobRow
The hash code of a job row is simply the hash code of its ID.
hashCode() - Method in class com.yahoo.bard.webservice.async.jobs.stores.JobRowFilter
 
hashCode() - Method in class com.yahoo.bard.webservice.config.ConfigurationGraph
 
hashCode() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionDictionary
 
hashCode() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionUpdateDate
 
hashCode() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
hashCode() - Method in class com.yahoo.bard.webservice.data.dimension.impl.LookupDimension
 
hashCode() - Method in class com.yahoo.bard.webservice.data.dimension.impl.RegisteredLookupDimension
 
hashCode() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
hashCode() - Method in class com.yahoo.bard.webservice.data.metric.mappers.PartialDataResultSetMapper
 
hashCode() - Method in class com.yahoo.bard.webservice.data.metric.mappers.ResultSetMapper
 
hashCode() - Method in class com.yahoo.bard.webservice.data.metric.mappers.SketchRoundUpMapper
 
hashCode() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
hashCode() - Method in class com.yahoo.bard.webservice.data.Result
 
hashCode() - Method in class com.yahoo.bard.webservice.data.time.AllGranularity
 
hashCode() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchAggregation
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.DefaultDimensionSpec
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.DimensionSpec
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.ExtractionDimensionSpec
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.CascadeExtractionFunction
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.ExtractionFunction
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.Lookup
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.MapLookup
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.NamespaceLookup
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.PartialExtractionFunction
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegularExpressionExtractionFunction
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.ListFilteredDimensionSpec
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.dimension.RegexFilteredDimensionSpec
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.filter.DimensionalFilter
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.filter.ExtractionFilter
Deprecated.
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.filter.Filter
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.filter.InFilter
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.filter.MultiClauseFilter
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.filter.NotFilter
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.filter.RegularExpressionFilter
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.filter.SearchFilter
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.filter.SelectorFilter
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.orderby.LimitSpec
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.orderby.OrderByColumn
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ConstantPostAggregation
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FuzzySetPostAggregation
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
 
hashCode() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
hashCode() - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadata
 
hashCode() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
 
hashCode() - Method in class com.yahoo.bard.webservice.metadata.SegmentMetadata
 
hashCode() - Method in class com.yahoo.bard.webservice.table.availability.BaseMetadataAvailability
 
hashCode() - Method in class com.yahoo.bard.webservice.table.availability.MetricUnionAvailability
 
hashCode() - Method in class com.yahoo.bard.webservice.table.availability.PartitionAvailability
 
hashCode() - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
hashCode() - Method in class com.yahoo.bard.webservice.table.BaseSchema
 
hashCode() - Method in class com.yahoo.bard.webservice.table.Column
 
hashCode() - Method in class com.yahoo.bard.webservice.table.PhysicalTableSchema
 
hashCode() - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
 
hashCode() - Method in class com.yahoo.bard.webservice.table.resolver.DimensionIdFilter
 
hashCode() - Method in class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
 
hashCode() - Method in class com.yahoo.bard.webservice.table.TableGroup
 
hashCode() - Method in class com.yahoo.bard.webservice.util.DelegatingMap
 
hashCode() - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
hashCode() - Method in class com.yahoo.bard.webservice.web.ApiHaving
 
hashCode() - Method in class com.yahoo.bard.webservice.web.PreResponse
 
hashCode() - Method in class com.yahoo.bard.webservice.web.responseprocessors.ResponseContext
 
hashCode() - Method in class com.yahoo.bard.webservice.web.util.PaginationParameters
 
HashDataCache<T extends Serializable> - Class in com.yahoo.bard.webservice.data.cache
DataCache using hashed keys to reduce the key length for the provided underlying cache.
HashDataCache(DataCache<HashDataCache.Pair<String, T>>, MessageDigest) - Constructor for class com.yahoo.bard.webservice.data.cache.HashDataCache
Creates cache hashing with given algorithm.
HashDataCache(DataCache<HashDataCache.Pair<String, T>>) - Constructor for class com.yahoo.bard.webservice.data.cache.HashDataCache
Creates cache hashing with default SHA-512 algorithm.
HashDataCache.Pair<K,V> - Class in com.yahoo.bard.webservice.data.cache
Key/Value pair.
HashJobStore - Class in com.yahoo.bard.webservice.async.jobs.stores
An ApiJobStore backed by an in-memory map.
HashJobStore(Map<String, JobRow>) - Constructor for class com.yahoo.bard.webservice.async.jobs.stores.HashJobStore
Builds a job store using the passed in map as the backing store.
HashJobStore() - Constructor for class com.yahoo.bard.webservice.async.jobs.stores.HashJobStore
Constructs an empty HashJobStore, using a LinkedHashMap as the backing store.
hasInnerQuery(JsonGenerator) - Static method in class com.yahoo.bard.webservice.druid.serializers.SerializerUtil
JSON tree walk to determine if there is a nested query below the current json node or not.
hasNext() - Method in class com.yahoo.bard.webservice.util.IntervalPeriodIterator
 
Having - Class in com.yahoo.bard.webservice.druid.model.having
A model for Druid having clauses.
Having(HavingType) - Constructor for class com.yahoo.bard.webservice.druid.model.having.Having
Constructor.
Having.DefaultHavingType - Enum in com.yahoo.bard.webservice.druid.model.having
Allowed values for Having expressions in druid.
HavingEvaluator - Class in com.yahoo.bard.webservice.sql.evaluator
Evaluates Having filters on aggregated metrics to build an equivalent RexNode for making a sql query.
HavingEvaluator() - Constructor for class com.yahoo.bard.webservice.sql.evaluator.HavingEvaluator
Constructor.
HavingGenerator - Interface in com.yahoo.bard.webservice.web.apirequest
Generates having maps from having strings.
HavingOperation - Enum in com.yahoo.bard.webservice.web
Types of legal having operations.
HavingType - Interface in com.yahoo.bard.webservice.druid.model.having
Allowed values for Having expressions in druid.
HC_LAST_RUN_PERIOD_MILLIS_DEFAULT - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
HeaderNestingJsonBuilderStrategy - Class in com.yahoo.bard.webservice.druid.client.impl
A strategy that takes a JSON Node built from a Response, nests it and makes it a peer with the Response headers.
HeaderNestingJsonBuilderStrategy(Function<Response, JsonNode>) - Constructor for class com.yahoo.bard.webservice.druid.client.impl.HeaderNestingJsonBuilderStrategy
Constructor.
headers - Variable in class com.yahoo.bard.webservice.logging.blocks.Preface
 
headers - Variable in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
 
headersToLowerCase(MultivaluedMap<String, String>) - Static method in class com.yahoo.bard.webservice.util.Utils
Helper method to return request headers as a map of the same type with its keys lower cased.
HEALTH_CHECK_NAME_DATASOURCE_METADATA - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
HEALTH_CHECK_NAME_DIMENSION - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
HEALTH_CHECK_NAME_DRUID_DIM_LOADER - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
HEALTH_CHECK_NAME_LOOKUP_METADATA - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
HEALTH_CHECK_VERSION - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
HealthCheckFilter - Class in com.yahoo.bard.webservice.web.filters
Filter all /data requests to respond SERVICE_UNAVAILABLE if any health check fails.
HealthCheckFilter() - Constructor for class com.yahoo.bard.webservice.web.filters.HealthCheckFilter
 
HealthCheckRegistryFactory - Class in com.yahoo.bard.webservice.application
EVIL - a RegistryFactory: An object which builds an object which builds objects.
HealthCheckRegistryFactory() - Constructor for class com.yahoo.bard.webservice.application.HealthCheckRegistryFactory
 
HealthCheckServletContextListener - Class in com.yahoo.bard.webservice.application
Servlet Context Listener which initializes the Codahale metrics registry used by the Codahale metrics filter and the metrics servlet.
HealthCheckServletContextListener() - Constructor for class com.yahoo.bard.webservice.application.HealthCheckServletContextListener
 
HttpErrorCallback - Interface in com.yahoo.bard.webservice.druid.client
Callback from the async HTTP client on error.
HttpResponseChannel - Class in com.yahoo.bard.webservice.data
Converts preResponse/errorResponse into HTTP Responses, and ships them immediately to the client.
HttpResponseChannel(AsyncResponse, ApiRequest, HttpResponseMaker) - Constructor for class com.yahoo.bard.webservice.data.HttpResponseChannel
Constructor.
HttpResponseMaker - Class in com.yahoo.bard.webservice.data
Translates a PreResponse into an HTTP Response containing the results of a query.
HttpResponseMaker(ObjectMappersSuite, DimensionDictionary, ResponseWriter) - Constructor for class com.yahoo.bard.webservice.data.HttpResponseMaker
Class constructor.
httpResponseMaker - Variable in class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessor
 

I

identityMapper(ResourceDictionaries) - Static method in class com.yahoo.bard.webservice.web.security.DataApiRequestMapperUtils
Create a request mapper that always returns an unmodified request.
incrementAndCheckCount(AtomicInteger, int) - Method in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
Increment the initial count and check if the count has gone over the request limit.
incrementCountCacheHits() - Static method in class com.yahoo.bard.webservice.logging.blocks.BardQueryInfo
Increments the number of cache-hit queries.
incrementCountFactHits() - Static method in class com.yahoo.bard.webservice.logging.blocks.BardQueryInfo
Increments the number of fact queries.
incrementCountWeightCheck() - Static method in class com.yahoo.bard.webservice.logging.blocks.BardQueryInfo
Increments the number of weight check queries.
InFilter - Class in com.yahoo.bard.webservice.druid.model.filter
Fili model of the Druid In Filter: http://druid.io/docs/0.9.1.1/querying/filters.html.
InFilter(Dimension, List<String>) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.InFilter
Constructor.
inFilterOperation(TreeSet<DimensionRow>, ApiFilter) - Method in interface com.yahoo.bard.webservice.data.dimension.FilterDimensionRows
In-filter operation.
inFilterOperation(TreeSet<DimensionRow>, ApiFilter) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
init(CsvSchema) - Static method in class com.yahoo.bard.webservice.util.FilterTokenizer
Initialize the tokenizer.
initDefault() - Static method in class com.yahoo.bard.webservice.util.FilterTokenizer
Initialize an ObjectReader.
initializeMetricsFilterSetBuilder() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Initialize the FilteredMetricsHelper.
initializePreResponseDeserializer(DimensionDictionary, ObjectMapper, ObjectMapper, GranularityParser) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Initialize the PreResponse deserializer to deserialize the custom serialized PreResponse.
initializeSketchConverter() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Initialize the field converter.
initRaw() - Static method in class com.yahoo.bard.webservice.util.FilterTokenizer
Initialize an ObjectReader that does not quote things.
InsensitiveContainsSearchQuerySpec - Class in com.yahoo.bard.webservice.druid.model.query
Class for specifying the InsensitiveContainsSearchQuerySpec for DruidSearchQuery.
InsensitiveContainsSearchQuerySpec(String) - Constructor for class com.yahoo.bard.webservice.druid.model.query.InsensitiveContainsSearchQuerySpec
Constructor.
INSTANCE - Static variable in class com.yahoo.bard.webservice.data.time.AllGranularity
 
INSTANCE - Static variable in class com.yahoo.bard.webservice.data.volatility.NoVolatileIntervalsFunction
Create a singleton instance of NoVolatileIntervalsFunction.
INSTANCE - Static variable in class com.yahoo.bard.webservice.druid.serializers.HasDruidNameSerializer
Singleton instance to use.
INSTANCE - Static variable in class com.yahoo.bard.webservice.util.IntervalStartComparator
 
insteadThrowRuntime(RuntimeException) - Static method in class com.yahoo.bard.webservice.util.Utils
Helper method to throw an exception when a result is expected as a return value (e.g.
internalApply(T, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.security.ChainingRequestMapper
Rewrite and Validate the ApiRequest(e.g.
internalApply(DataApiRequest, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.security.RoleDimensionApiFilterRequestMapper
 
intersect(SimplifiedIntervalList) - Method in class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Return the intersection of all subintervals in two interval lists.
IntervalPeriodIterator - Class in com.yahoo.bard.webservice.util
An iterator that splits an interval into slices of length equal to a period and returns them
IntervalPeriodIterator(ReadablePeriod, Interval) - Constructor for class com.yahoo.bard.webservice.util.IntervalPeriodIterator
Constructor.
intervals - Variable in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidFactQuery
 
intervals - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
intervalsIterable(Collection<Interval>) - Method in interface com.yahoo.bard.webservice.data.time.Granularity
Wrap the granularity iterator in an iterable predicate for use in streaming.
intervalsIterator(SimplifiedIntervalList) - Method in class com.yahoo.bard.webservice.data.time.AllGranularity
 
intervalsIterator(Collection<Interval>) - Method in interface com.yahoo.bard.webservice.data.time.Granularity
Build an iterator that will iterate over a set of intervals, collecting them into a single stream, and slicing or not slicing them according to the granularity given.
intervalsIterator(SimplifiedIntervalList) - Method in interface com.yahoo.bard.webservice.data.time.Granularity
Build an iterator from a pre-simplified list of intervals.
intervalsIterator(SimplifiedIntervalList) - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
 
IntervalStartComparator - Class in com.yahoo.bard.webservice.util
Compare intervals based on their starting instant.
IntervalStartComparator() - Constructor for class com.yahoo.bard.webservice.util.IntervalStartComparator
 
intervalToString(Interval, DateTimeFormatter, String) - Static method in class com.yahoo.bard.webservice.util.DateTimeUtils
Converts an interval to a specified string format.
IntervalUtils - Class in com.yahoo.bard.webservice.util
Methods and Iterators which support interval slicing alignment and set operations.
IntervalUtils() - Constructor for class com.yahoo.bard.webservice.util.IntervalUtils
 
invoke(Throwable) - Method in class com.yahoo.bard.webservice.application.LoadTask.TaskFailureCallback
 
invoke(int, String, String) - Method in class com.yahoo.bard.webservice.application.LoadTask.TaskHttpErrorCallback
 
invoke(Throwable) - Method in interface com.yahoo.bard.webservice.druid.client.FailureCallback
Invoke the failure callback code.
invoke(int, String, String) - Method in interface com.yahoo.bard.webservice.druid.client.HttpErrorCallback
Invoke the error callback code.
invoke(JsonNode) - Method in interface com.yahoo.bard.webservice.druid.client.SuccessCallback
Invoke the success callback code.
IS_SUBINTERVAL - Static variable in class com.yahoo.bard.webservice.util.SimplifiedIntervalList.IsSubinterval
Filter in intervals from the stream that are fully contained by the supply.
isAggregatable() - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionConfig
Return whether this dimension can be aggregated.
isAggregatable() - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Return whether this dimension can be aggregated.
isAggregatable() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
isAsMillis() - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
Returns whether to treat input input strings as millis(true) or ISO8601 strings(false).
isBound() - Method in class com.yahoo.bard.webservice.web.ratelimit.BypassRateLimitRequestToken
 
isBound() - Method in class com.yahoo.bard.webservice.web.ratelimit.CallbackRateLimitRequestToken
 
isBound() - Method in interface com.yahoo.bard.webservice.web.ratelimit.RateLimitRequestToken
Check if the token is bound.
isBypass(MultivaluedMap<String, String>) - Static method in class com.yahoo.bard.webservice.web.DataApiRequestTypeIdentifier
Check if the request header is a bypass header.
isBypassMethod(ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.filters.RoleBasedAuthFilter
Returns true to bypass the filter if the request is a Http OPTIONS method to allow CORS by default.
isByRow() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
 
isCacheable() - Method in class com.yahoo.bard.webservice.web.responseprocessors.CacheV2ResponseProcessor
A request is cacheable if it does not refer to partial data.
isConnectionClosedPrematurely() - Method in class com.yahoo.bard.webservice.logging.blocks.Epilogue
The connection between Bard and the client is considered to be closed prematurely if the connection is closed before Bard finishes streaming the results back to the client.
isCorsPreflight(String, SecurityContext) - Static method in class com.yahoo.bard.webservice.web.DataApiRequestTypeIdentifier
Check if the request is a CORS preflight request.
isDateTimeFirstSortField(LinkedHashMap<String, SortDirection>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
To check whether dateTime column request is first one in the sort list or not.
isEmpty() - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
isEmpty(SerializerProvider, HasDruidName) - Method in class com.yahoo.bard.webservice.druid.serializers.HasDruidNameSerializer
 
isEmpty() - Method in class com.yahoo.bard.webservice.metadata.SegmentMetadata
 
isFloatingPoint() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
 
isFloatingPoint() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CountAggregation
 
isFloatingPoint() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
 
isFloatingPoint() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.LongSumAggregation
 
isFloatingPoint() - Method in interface com.yahoo.bard.webservice.druid.model.MetricField
Indicate if the MetricField is a floating-point value.
isFloatingPoint() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation
 
isFloatingPoint() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
 
isFloatingPoint() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation
 
isHealthy() - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
 
isHealthy() - Method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
 
isHealthy() - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
isHealthy() - Method in interface com.yahoo.bard.webservice.data.dimension.KeyValueStore
Get the health status of the store.
isHealthy() - Method in class com.yahoo.bard.webservice.data.dimension.MapStore
 
isHealthy() - Method in class com.yahoo.bard.webservice.data.dimension.RedisStore
 
isHealthy() - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Method to check if search provider is healthy.
isInChunk(long, InputRow) - Method in class com.yahoo.bard.webservice.druid.model.metadata.NumberedShardSpec
 
isLeft() - Method in class com.yahoo.bard.webservice.util.Either
Returns whether or not this Either represents a Left value.
isNegated() - Method in enum com.yahoo.bard.webservice.web.HavingOperation
 
isNested() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Checks if the template druid query is nested.
isNonAggregatableInFilter() - Static method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Validity rules for non-aggregatable dimensions that are only referenced in filters.
isOn() - Method in enum com.yahoo.bard.webservice.config.BardFeatureFlag
 
isOn() - Method in enum com.yahoo.bard.webservice.config.CacheFeatureFlag
 
isOn() - Method in interface com.yahoo.bard.webservice.config.FeatureFlag
Returns whether the feature flag is activated.
isOpen() - Method in interface com.yahoo.bard.webservice.data.dimension.KeyValueStore
Get the open / closed status of the store.
isOpen() - Method in class com.yahoo.bard.webservice.data.dimension.MapStore
 
isOpen() - Method in class com.yahoo.bard.webservice.data.dimension.RedisStore
 
isPeriodic - Variable in class com.yahoo.bard.webservice.application.LoadTask
 
isPeriodic() - Method in class com.yahoo.bard.webservice.application.LoadTask
Return whether this loader is periodic or one-off.
isPeriodic() - Method in class com.yahoo.bard.webservice.application.SchedulableTask
 
isReadCache() - Method in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
isResourceNotAJar(Resource) - Method in class com.yahoo.bard.webservice.config.ConfigResourceLoader
A simple predicate that is true if a resource is not from a jar.
isRight() - Method in class com.yahoo.bard.webservice.util.Either
Returns whether or not this Either represents a Right value.
isRunning(Object) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Check if a stopwatch is currently running.
isRunning(String) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Check if a stopwatch is currently running.
isRunning() - Method in class com.yahoo.bard.webservice.logging.TimedPhase
 
isSet() - Method in interface com.yahoo.bard.webservice.config.FeatureFlag
Returns whether the feature flag has been configured.
isSketch() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
 
isSketch() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
 
isSketch() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchCountAggregation
Deprecated.
 
isSketch() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchMergeAggregation
Deprecated.
 
isSketch() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.ThetaSketchAggregation
 
isSketch() - Method in interface com.yahoo.bard.webservice.druid.model.MetricField
Indicate if the MetricField is based on a sketch.
isSketch() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
 
isSketch() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation
 
isSketch() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
 
isSketch() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
 
IsSubinterval(SimplifiedIntervalList) - Constructor for class com.yahoo.bard.webservice.util.SimplifiedIntervalList.IsSubinterval
Construct a subinterval predicate that closes over a supply of intervals.
IsTableAligned - Interface in com.yahoo.bard.webservice.table.availability
A predicate to determine whether a table aligns with a criteria.
IsTableStartAlignedWithIntervals - Class in com.yahoo.bard.webservice.table.availability
Test that the start of each interval in a list falls on a time bucket of the table under test.
IsTableStartAlignedWithIntervals(Collection<Interval>) - Constructor for class com.yahoo.bard.webservice.table.availability.IsTableStartAlignedWithIntervals
Constructor.
isTimeGrainValid() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Check if outer TimeGrain is compatible with inner TimeGrain.
isUi(MultivaluedMap<String, String>) - Static method in class com.yahoo.bard.webservice.web.DataApiRequestTypeIdentifier
Check if the request header is a UI header.
isUserInRole(List<String>, ContainerRequestContext) - Method in class com.yahoo.bard.webservice.web.filters.RoleBasedAuthFilter
Checks if an user role belongs to the list of allowed roles.
isValidFor(TimeGrain) - Method in interface com.yahoo.bard.webservice.data.config.names.ApiMetricName
Determine if this API Metric Name is valid for the given time grain.
isValidFor(Granularity) - Method in interface com.yahoo.bard.webservice.data.config.names.ApiMetricName
Determine if this API Metric Name is valid for the given time grain.
isValidFor(Granularity, LogicalMetric) - Method in interface com.yahoo.bard.webservice.data.config.names.ApiMetricName
Determine if this API Metric Name is valid for the given time grain.
isValidFor(TimeGrain) - Method in class com.yahoo.wiki.webservice.data.config.metric.FiliApiMetricName
 
isValidFor(TimeGrain) - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiMetricName
 
isValidQuery(DruidQuery<?>) - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Determines whether or not a query is able to be processed using the Sql backend.

J

JobField - Interface in com.yahoo.bard.webservice.async.jobs.jobrows
Represents a column in the table of job metadata.
JobNotFoundException - Exception in com.yahoo.bard.webservice.web
Class for exception thrown if a job is not found in the ApiJobStore.
JobNotFoundException(String) - Constructor for exception com.yahoo.bard.webservice.web.JobNotFoundException
Build a JobNotFoundException with the given message.
JobNotFoundException(Throwable) - Constructor for exception com.yahoo.bard.webservice.web.JobNotFoundException
Build a JobNotFoundException with the given cause of the exception.
JobNotFoundException(String, Throwable) - Constructor for exception com.yahoo.bard.webservice.web.JobNotFoundException
Build a JobNotFoundException with the specified cause and message.
JobPayloadBuilder - Interface in com.yahoo.bard.webservice.async.jobs.payloads
Interface to build a Job payload from a JobRow.
JobRequest - Class in com.yahoo.bard.webservice.logging.blocks
Main log of a request served by the JobsServlet.
JobRequest(String) - Constructor for class com.yahoo.bard.webservice.logging.blocks.JobRequest
Build a JobRequest with the given ticket.
JobRequestFailedException - Exception in com.yahoo.bard.webservice.web
Unchecked exception in case request to the jobs endpoint fails.
JobRequestFailedException(String) - Constructor for exception com.yahoo.bard.webservice.web.JobRequestFailedException
Build a JobRequestFailedException with the given message.
JobRequestFailedException(Throwable) - Constructor for exception com.yahoo.bard.webservice.web.JobRequestFailedException
Build a JobRequestFailedException with the given cause of the exception.
JobRequestFailedException(String, Throwable) - Constructor for exception com.yahoo.bard.webservice.web.JobRequestFailedException
Build a JobNotFoundException with the specified cause and message.
JobRow - Class in com.yahoo.bard.webservice.async.jobs.jobrows
A row in the conceptual table defined by the ApiJobStore, containing the metadata about a particular job.
JobRow(String, Map<JobField, String>) - Constructor for class com.yahoo.bard.webservice.async.jobs.jobrows.JobRow
An internal-only constructor that provides the jobId directly, used by the copy-and-modify methods.
JobRow(JobField, Map<JobField, String>) - Constructor for class com.yahoo.bard.webservice.async.jobs.jobrows.JobRow
Builds a row of job metadata.
JobRowBuilder - Interface in com.yahoo.bard.webservice.async.jobs.jobrows
Interface for building JobRows (i.e.
JobRowFilter - Class in com.yahoo.bard.webservice.async.jobs.stores
Class containing filter information to filter JobRows in ApiJobStore.
JobRowFilter(String) - Constructor for class com.yahoo.bard.webservice.async.jobs.stores.JobRowFilter
Parses the URL ApiJobStore filter query and generates the JobRowFilter object.
JobsApiRequest - Interface in com.yahoo.bard.webservice.web.apirequest
Jobs API Request.
JobsApiRequestImpl - Class in com.yahoo.bard.webservice.web.apirequest
Jobs API Request Implementation binds, validates, and models the parts of a request to the jobs endpoint.
JobsApiRequestImpl(String, String, String, String, String, UriInfo, JobPayloadBuilder, ApiJobStore) - Constructor for class com.yahoo.bard.webservice.web.apirequest.JobsApiRequestImpl
Parses the API request URL and generates the Api Request object.
JobsServlet - Class in com.yahoo.bard.webservice.web.endpoints
Resource code for job resource endpoints.
JobsServlet(ObjectMappersSuite, ApiJobStore, JobPayloadBuilder, PreResponseStore, BroadcastChannel<String>, RequestMapper, HttpResponseMaker, ResponseFormatResolver) - Constructor for class com.yahoo.bard.webservice.web.endpoints.JobsServlet
Constructor.
JobStatus - Interface in com.yahoo.bard.webservice.async.jobs.jobrows
A job status describes the current state of a job (i.e.
JsonAndJsonApiResponseWriter - Class in com.yahoo.bard.webservice.web
An wrapper for JsonResponseWriter and JsonApiResponseWriter.
JsonAndJsonApiResponseWriter(ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.JsonAndJsonApiResponseWriter
Constructor for both Json and JsonApi format serializer.
JsonApiResponseWriter - Class in com.yahoo.bard.webservice.web
Serializer for JsonApi format.
JsonApiResponseWriter(ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.JsonApiResponseWriter
Constructor.
JsonLogFormatter - Class in com.yahoo.bard.webservice.logging
A log formatter that prints log in JSON format.
JsonLogFormatter() - Constructor for class com.yahoo.bard.webservice.logging.JsonLogFormatter
Configure ObjectMapper.
JsonResponse<T> - Class in com.yahoo.bard.webservice.web
Formats data of a response as JSON.
JsonResponse(Stream<T>, Pagination<?>, UriInfo, String, ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.JsonResponse
Constructor.
JsonResponseWriter - Class in com.yahoo.bard.webservice.web
Serializer for Json format.
JsonResponseWriter(ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.JsonResponseWriter
Constructor.

K

KEY_SEPARATOR - Static variable in class com.yahoo.bard.webservice.util.DimensionStoreKeyUtils
 
keySet() - Method in class com.yahoo.bard.webservice.util.DelegatingMap
 
KeyValueStore - Interface in com.yahoo.bard.webservice.data.dimension
A simple key-value store.
KeyValueStoreDimension - Class in com.yahoo.bard.webservice.data.dimension.impl
KeyValueStoreDimension implements key value collection of DimensionRows.
KeyValueStoreDimension(String, String, String, String, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider, LinkedHashSet<DimensionField>, boolean, StorageStrategy) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
Constructor.
KeyValueStoreDimension(String, String, String, String, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider, LinkedHashSet<DimensionField>, boolean) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
Constructor.
KeyValueStoreDimension(String, String, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
Constructor.
KeyValueStoreDimension(String, String, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider, boolean) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
Constructor.
KeyValueStoreDimension(String, String, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider, Set<DimensionRow>) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
Constructor.
KeyValueStoreDimension(String, String, String, String, LinkedHashSet<DimensionField>, KeyValueStore, SearchProvider, Set<DimensionRow>) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
Constructor.
KeyValueStoreDimension(DimensionConfig) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
Constructor.
KeyValueStoreDimensionLoader - Class in com.yahoo.bard.webservice.data.config.dimension
Deprecated.
in favor of TypeAwareDimensionLoader which loads corresponding dimension based on config type
KeyValueStoreDimensionLoader(Iterable<DimensionConfig>) - Constructor for class com.yahoo.bard.webservice.data.config.dimension.KeyValueStoreDimensionLoader
Deprecated.
Constructor.
KeyValueStoreHealthCheck - Class in com.yahoo.bard.webservice.application.healthchecks
A health check to test if a keyValueStore reports as healthy.
KeyValueStoreHealthCheck(KeyValueStore) - Constructor for class com.yahoo.bard.webservice.application.healthchecks.KeyValueStoreHealthCheck
Constructor.

L

LayeredFileSystemConfig - Class in com.yahoo.bard.webservice.config
A class to hold and fetch configuration values from the environment, the system, user, application, module and library configurations.
LayeredFileSystemConfig() - Constructor for class com.yahoo.bard.webservice.config.LayeredFileSystemConfig
Build a Layered File System Configuration, using first the environment and an application configuration source, then drill down into available modules and load each of them in package dependency order.
left(L) - Static method in class com.yahoo.bard.webservice.util.Either
Constructs an Either containing a left value.
length - Variable in class com.yahoo.bard.webservice.logging.blocks.Response
 
LENGTH_UNKNOWN - Static variable in class com.yahoo.bard.webservice.logging.blocks.Epilogue
 
limit - Variable in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
LimitSpec - Class in com.yahoo.bard.webservice.druid.model.orderby
LimitSpec class.
LimitSpec(LinkedHashSet<OrderByColumn>) - Constructor for class com.yahoo.bard.webservice.druid.model.orderby.LimitSpec
Constructor.
LimitSpec(LinkedHashSet<OrderByColumn>, OptionalInt) - Constructor for class com.yahoo.bard.webservice.druid.model.orderby.LimitSpec
Constructor.
listEvaluate(MultiClauseHaving, SqlOperator, RelBuilder, ApiToFieldMapper) - Method in class com.yahoo.bard.webservice.sql.evaluator.HavingEvaluator
Evaluates a MultiClauseHaving filter by performing it's operation over a list of other havings.
ListFilteredDimensionSpec - Class in com.yahoo.bard.webservice.druid.model.dimension
Filtered DimensionSpec using a List of filter values on Druid multi-dimensional value dimensions.
ListFilteredDimensionSpec(DimensionSpec, List<String>, Boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.ListFilteredDimensionSpec
Constructor.
ListFilteredDimensionSpec(DimensionSpec, List<String>) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.ListFilteredDimensionSpec
Convenience Constructor, defaults: isWhitelist=true.
load() - Method in interface com.yahoo.bard.webservice.application.DimensionValueLoader
Start loading all dimensions.
load() - Method in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
Load the Dimensions, Metrics, and Tables.
loadConfigFromResource(Resource) - Method in class com.yahoo.bard.webservice.config.ConfigResourceLoader
Build a configuration object from a resource, processing it as a properties file.
loadConfigurations(String) - Method in class com.yahoo.bard.webservice.config.ConfigResourceLoader
Use a string pattern to load configurations matching a resource name from the class path and parse into Configuration objects.
loadConfigurationsNoJars(String) - Method in class com.yahoo.bard.webservice.config.ConfigResourceLoader
Use a string path to load configurations matching a resource name from the class path which are not from jars into Configuration objects.
loadDimensionDictionary(DimensionDictionary) - Method in interface com.yahoo.bard.webservice.data.config.dimension.DimensionLoader
Load dimensions and populate the dimension dictionary.
loadDimensionDictionary(DimensionDictionary) - Method in class com.yahoo.bard.webservice.data.config.dimension.KeyValueStoreDimensionLoader
Deprecated.
 
loadDimensionDictionary(DimensionDictionary) - Method in class com.yahoo.bard.webservice.data.config.dimension.TypeAwareDimensionLoader
 
LOADER_SCHEDULER_THREAD_POOL_SIZE - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
LOADER_SCHEDULER_THREAD_POOL_SIZE_DEFAULT - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
LOADER_TIMER_DELAY - Static variable in class com.yahoo.bard.webservice.application.DimensionValueLoadTask
 
LOADER_TIMER_DURATION - Static variable in class com.yahoo.bard.webservice.application.DimensionValueLoadTask
 
loaderName - Variable in class com.yahoo.bard.webservice.application.LoadTask
 
loadLogicalTablesWithGranularities(Map<String, TableGroup>, Set<? extends Granularity>, ResourceDictionaries) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Load several logical tables into the logicalDictionary, all with the globally-scoped metric dictionary.
loadLogicalTablesWithGranularities(Map<String, TableGroup>, Set<? extends Granularity>, LogicalTableDictionary, Map<String, MetricDictionary>) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Load several logical tables into the logicalDictionary, each with their own scoped metric dictionary.
loadLogicalTableWithGranularities(String, TableGroup, Set<? extends Granularity>, ResourceDictionaries) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Load a logical table into the logicalDictionary.
loadLogicalTableWithGranularities(String, TableGroup, Set<? extends Granularity>, LogicalTableDictionary, MetricDictionary) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Load a logical table into the logicalDictionary.
loadMetricDictionary(MetricDictionary) - Method in interface com.yahoo.bard.webservice.data.config.metric.MetricLoader
Deprecated.
in favor of loadMetricDictionary(MetricDictionary, DimensionDictionary)
loadMetricDictionary(MetricDictionary, DimensionDictionary) - Method in interface com.yahoo.bard.webservice.data.config.metric.MetricLoader
Load metrics and populate the metric dictionary with dimension dictionary for dimension dependent metrics.
loadMetricDictionary(MetricDictionary) - Method in class com.yahoo.wiki.webservice.data.config.metric.GenericMetricLoader
 
loadMetricDictionary(MetricDictionary) - Method in class com.yahoo.wiki.webservice.data.config.metric.WikiMetricLoader
 
loadPhysicalTable(PhysicalTableDefinition, Set<FieldName>, ResourceDictionaries) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Deprecated.
use buildPhysicalTableWithDependency instead, which also supports building table with dependencies
loadResourcesWithName(String) - Method in class com.yahoo.bard.webservice.config.ConfigResourceLoader
Use a string to load a stream of all resources from the class path which match a given name.
loadTableDictionary(ResourceDictionaries) - Method in class com.yahoo.bard.webservice.data.config.table.BaseTableLoader
Load user configured tables into resource dictionary.
loadTableDictionary(ResourceDictionaries) - Method in interface com.yahoo.bard.webservice.data.config.table.TableLoader
Load all of the logical tables, their table groups, and the physical tables for those groups.
loadTableDictionary(ResourceDictionaries) - Method in class com.yahoo.wiki.webservice.data.config.table.GenericTableLoader
 
loadTableDictionary(ResourceDictionaries) - Method in class com.yahoo.wiki.webservice.data.config.table.WikiTableLoader
 
LoadTask<V> - Class in com.yahoo.bard.webservice.application
Defines a task that is scheduled to run at a given time, potentially periodically.
LoadTask(String, long) - Constructor for class com.yahoo.bard.webservice.application.LoadTask
Creates a one-off loader.
LoadTask(String, long, long) - Constructor for class com.yahoo.bard.webservice.application.LoadTask
Creates a periodic loader.
LoadTask.TaskFailureCallback - Class in com.yahoo.bard.webservice.application
A basic nested class dealing with failures that can be re-used by classes extending LoadTask.
LoadTask.TaskHttpErrorCallback - Class in com.yahoo.bard.webservice.application
A basic nested class dealing with http errors that can be re-used by classes extending LoadTask.
LOG - Static variable in interface com.yahoo.bard.webservice.application.DimensionValueLoader
 
LOG - Static variable in class com.yahoo.bard.webservice.data.config.metric.makers.ConstantMaker
 
LOG - Static variable in class com.yahoo.bard.webservice.data.config.metric.makers.FilteredAggregationMaker
 
log() - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Write the request log object of the current thread as JSON.
LOG - Static variable in class com.yahoo.bard.webservice.table.resolver.AggregatableDimensionsMatcher
 
LOG - Static variable in class com.yahoo.bard.webservice.table.resolver.SchemaPhysicalTableMatcher
 
LOG - Static variable in class com.yahoo.bard.webservice.table.resolver.TimeAlignmentPhysicalTableMatcher
 
LOG - Static variable in class com.yahoo.bard.webservice.web.ResponseData
 
LOG_FORMATTER_IMPLEMENTATION_SETTING_NAME - Static variable in class com.yahoo.bard.webservice.logging.LogFormatterProvider
 
LogBlock - Class in com.yahoo.bard.webservice.logging
Represents the information that is written in a single log line per http request.
LogBlock(String) - Constructor for class com.yahoo.bard.webservice.logging.LogBlock
Given a universally unique identifier as string construct a logging context.
LogExceptionMapper - Class in com.yahoo.bard.webservice.web.exceptionmappers
An exception mapper that guarantees that an uncaught exception at this point is caught and an appropriate response is forwarded to the appropriate filters in the Jersey stack.
LogExceptionMapper() - Constructor for class com.yahoo.bard.webservice.web.exceptionmappers.LogExceptionMapper
 
logFormat(Object...) - Method in interface com.yahoo.bard.webservice.MessageFormatter
Format a message for writing to the log.
LogFormatter - Interface in com.yahoo.bard.webservice.logging
Interface for log formatter that are meant to facilitate log exploration and data extraction.
LogFormatterProvider - Class in com.yahoo.bard.webservice.logging
A class to provide a log formatter instance.
LogFormatterProvider() - Constructor for class com.yahoo.bard.webservice.logging.LogFormatterProvider
 
LoggingContext - Class in com.yahoo.bard.webservice.web.responseprocessors
A container for RequestLog.
LoggingContext(RequestLog) - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.LoggingContext
Build a container for RequestLog.
logical - Variable in class com.yahoo.bard.webservice.data.config.ResourceDictionaries
 
LogicalDimensionColumn - Class in com.yahoo.bard.webservice.data.dimension
Deprecated.
in favor of DimensionColumn which stores name as api name now
LogicalDimensionColumn(Dimension) - Constructor for class com.yahoo.bard.webservice.data.dimension.LogicalDimensionColumn
Deprecated.
Constructor.
LogicalMetric - Class in com.yahoo.bard.webservice.data.metric
A LogicalMetric is a set of its TemplateQueries, Mapper, and its name.
LogicalMetric(TemplateDruidQuery, ResultSetMapper, String, String, String, String) - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetric
Deprecated.
Properties, such as name, of LogicalMetric is stored in a unified object called LogicalMetricInfo. Use new constructor LogicalMetric.LogicalMetric(TemplateDruidQuery, ResultSetMapper, LogicalMetricInfo) instead.
LogicalMetric(TemplateDruidQuery, ResultSetMapper, String, String) - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetric
Deprecated.
Properties, such as name, of LogicalMetric is stored in a unified object called LogicalMetricInfo. Use new constructor LogicalMetric.LogicalMetric(TemplateDruidQuery, ResultSetMapper, LogicalMetricInfo) instead.
LogicalMetric(TemplateDruidQuery, ResultSetMapper, String) - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetric
Deprecated.
Properties, such as name, of LogicalMetric is stored in a unified object called LogicalMetricInfo. Use new constructor LogicalMetric.LogicalMetric(TemplateDruidQuery, ResultSetMapper, LogicalMetricInfo) instead.
LogicalMetric(TemplateDruidQuery, ResultSetMapper, LogicalMetricInfo) - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetric
Constructor.
LogicalMetricColumn - Class in com.yahoo.bard.webservice.data.metric
LogicalMetricColumn.
LogicalMetricColumn(String, LogicalMetric) - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetricColumn
Deprecated.
because LogicalMetricColumn is really only a thing for LogicalTable, so there's no reason for there to be an alias on the LogicalMetric inside the LogicalTableSchema.
LogicalMetricColumn(LogicalMetric) - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetricColumn
Constructor.
LogicalMetricDictionary - Class in com.yahoo.bard.webservice.data.metric
A LogicalMetricDictionary is a map of the metric name to the LogicalMetric object.
LogicalMetricDictionary() - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetricDictionary
 
LogicalMetricInfo - Class in com.yahoo.bard.webservice.data.metric
Contains information passed to LogicalMetric constructor.
LogicalMetricInfo(String, String, String, String, String) - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetricInfo
Constructor.
LogicalMetricInfo(String, String, String, String) - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetricInfo
Constructor.
LogicalMetricInfo(String) - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetricInfo
Constructor.
LogicalMetricInfo(String, String) - Constructor for class com.yahoo.bard.webservice.data.metric.LogicalMetricInfo
Constructor.
LogicalTable - Class in com.yahoo.bard.webservice.table
A LogicalTable has a grain and a tablegroup of physical tables that satisfy the logical table.
LogicalTable(String, Granularity, TableGroup, MetricDictionary) - Constructor for class com.yahoo.bard.webservice.table.LogicalTable
Constructor
LogicalTable(String, String, String, Granularity, ReadablePeriod, String, TableGroup, MetricDictionary) - Constructor for class com.yahoo.bard.webservice.table.LogicalTable
Constructor.
logicalTableAvailability(LogicalTable) - Static method in class com.yahoo.bard.webservice.util.TableUtils
Returns union of availabilities of the logical table.
LogicalTableDictionary - Class in com.yahoo.bard.webservice.table
Logical Table dictionary facilitates the mapping of the logical table Name and time grain pair to the logical table object.
LogicalTableDictionary() - Constructor for class com.yahoo.bard.webservice.table.LogicalTableDictionary
 
LogicalTableSchema - Class in com.yahoo.bard.webservice.table
The schema for a logical table.
LogicalTableSchema(TableGroup, Granularity, MetricDictionary) - Constructor for class com.yahoo.bard.webservice.table.LogicalTableSchema
Constructor.
LogInfo - Interface in com.yahoo.bard.webservice.logging
Interface for enums or classes that are meant to enclose log related information that can be exported to JSON format.
logMessage - Variable in class com.yahoo.bard.webservice.logging.blocks.Epilogue
 
LongMaxAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Aggregation for the maximum of longs.
LongMaxAggregation(String, String) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.LongMaxAggregation
Constructor.
LongMaxMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to get the max of long metrics.
LongMaxMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.LongMaxMaker
Constructor.
LongMinAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Aggregation for the minimum of longs.
LongMinAggregation(String, String) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.LongMinAggregation
Constructor.
LongMinMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to get the min of long metrics.
LongMinMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.LongMinMaker
Constructor.
LongSumAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Aggregation for the sum of longs.
LongSumAggregation(String, String) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.LongSumAggregation
Constructor.
LongSumMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to sum over numeric metrics.
LongSumMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.LongSumMaker
Constructor.
LookbackQuery - Class in com.yahoo.bard.webservice.druid.model.query
Druid lookback query.
LookbackQuery(DataSource, Collection<PostAggregation>, QueryContext, Collection<Period>, Collection<String>, Having, LimitSpec) - Constructor for class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
Constructor.
LookbackQuery.LookbackQueryRequestedIntervalsFunction - Class in com.yahoo.bard.webservice.druid.model.query
The function to get requestedIntervals from a LookbackQuery.
LookbackQueryRequestedIntervalsFunction() - Constructor for class com.yahoo.bard.webservice.druid.model.query.LookbackQuery.LookbackQueryRequestedIntervalsFunction
 
Lookup - Class in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
Base class model for Lookup property of Lookup Extraction Function.
Lookup(String) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.Lookup
Constructor.
LookupDimension - Class in com.yahoo.bard.webservice.data.dimension.impl
LookupDimension creates a Look up dimension based on the namespace chain.
LookupDimension(LookupDimensionConfig) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.LookupDimension
Constructor.
LookupDimensionConfig - Interface in com.yahoo.bard.webservice.data.config.dimension
Defines the information needed to configure a Lookup Dimension.
LookupDimensionToDimensionSpec - Class in com.yahoo.bard.webservice.druid.serializers
Serializer to map LookupDimension to either DimensionSpec base on namespaces.
LookupDimensionToDimensionSpec() - Constructor for class com.yahoo.bard.webservice.druid.serializers.LookupDimensionToDimensionSpec
 
LookupExtractionFunction - Class in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
Lookup ExtractionFunction that maps dimension values to some corresponding pre-defined values.
LookupExtractionFunction(Lookup, Boolean, String, Boolean, Boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
Constructor.
LookupExtractionFunction(Lookup) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
Convenience Constructor,
LookupHealthCheck - Class in com.yahoo.bard.webservice.application.healthchecks
Check load statuses of all Druid lookups.
LookupHealthCheck(RegisteredLookupMetadataLoadTask) - Constructor for class com.yahoo.bard.webservice.application.healthchecks.LookupHealthCheck
Constructor.
LUCENE_SEARCH_TIMEOUT_MS - Static variable in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
 
LuceneSearchProvider - Class in com.yahoo.bard.webservice.data.dimension.impl
LuceneSearchProvider.
LuceneSearchProvider(String, int, int) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
Constructor.
LuceneSearchProvider(String, int) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
Constructor.
LuceneSearchProviderManager - Class in com.yahoo.bard.webservice.data.dimension.impl
Lucene search provider factory.
LuceneSearchProviderManager() - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProviderManager
 

M

MacroCalculationStrategies - Interface in com.yahoo.bard.webservice.web
Interface implemented by macros to get the dateTime based on granularity.
main(String[]) - Static method in class com.yahoo.wiki.webservice.application.GenericMain
Run a generic setup which mirrors all information from druid into fili configuration.
main(String[]) - Static method in class com.yahoo.wiki.webservice.application.WikiMain
Run the Wikipedia application.
make(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.ConstantMaker
 
make(String, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Deprecated.
logical metric needs more config-richness to not just configure metric name, but also metric long name, description, etc. Use MetricMaker.make(LogicalMetricInfo, List) instead.
make(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Make the metric.
make(String, String) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Make the metric.
make() - Method in class com.yahoo.bard.webservice.data.config.metric.MetricInstance
Make the Logical Metric from the information in this MetricInstance.
makeErrorResponse(Response.StatusType, Throwable, ObjectWriter) - Static method in class com.yahoo.bard.webservice.web.handlers.RequestHandlerUtils
Builds error response from exception without group by.
makeErrorResponse(Response.StatusType, DruidQuery<?>, Throwable, ObjectWriter) - Static method in class com.yahoo.bard.webservice.web.handlers.RequestHandlerUtils
Builds error response from exception.
makeErrorResponse(int, String, String, DruidQuery<?>, ObjectWriter) - Static method in class com.yahoo.bard.webservice.web.handlers.RequestHandlerUtils
Builds error response for Web Service.
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.AggregationAverageMaker
 
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.ArithmeticMaker
 
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.CardinalityMaker
 
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.ConstantMaker
 
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.CountMaker
 
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.FilteredAggregationMaker
 
makeInner(String, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Deprecated.
logical metric needs more config-richness to not just configure metric name, but also metric long name, description, etc. Use MetricMaker.makeInner(LogicalMetricInfo, List) instead.
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Delegated to for actually making the metric.
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.RawAggregationMetricMaker
 
makeInner(String, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.RowNumMaker
 
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.RowNumMaker
 
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.SketchSetOperationMaker
Deprecated.
 
makeInner(LogicalMetricInfo, List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.makers.ThetaSketchSetOperationMaker
 
makeJobMetadataResponse(String) - Static method in class com.yahoo.bard.webservice.async.AsyncUtils
Given a String containing the metadata of an asynchronous job, returns a Response with that metadata as payload.
makePostAggFromAgg(SketchSetOperationPostAggFunction, String, List<FilteredAggregation>) - Static method in class com.yahoo.bard.webservice.data.config.metric.makers.SketchSetOperationHelper
Deprecated.
This method builds a SketchSetOperationPostAggregation by applying the set operation specified by 'function' on the FilteredAggregations in the filteredAggregationList.
makePostAggFromAgg(SketchSetOperationPostAggFunction, String, List<FilteredAggregation>) - Static method in class com.yahoo.bard.webservice.data.config.metric.makers.ThetaSketchSetOperationHelper
This method builds a ThetaSketchSetOperationPostAggregation by applying the set operation specified by 'function' on the FilteredAggregations in the filteredAggregationList.
makeWeightEvaluationQuery(DruidAggregationQuery<?>) - Static method in class com.yahoo.bard.webservice.druid.model.query.WeightEvaluationQuery
Evaluate Druid query for expensive aggregation that could bring down Druid.
makeWeightEvaluationQuery(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.util.QueryWeightUtil
Get the weight check query for the given query.
map(ResultSet) - Method in class com.yahoo.bard.webservice.data.metric.mappers.DateTimeSortMapper
Sorting the resultSet based on dateTime column sort direction.
map(Result, ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.DateTimeSortMapper
 
map(ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.DateTimeSortMapper
 
map(ResultSet) - Method in class com.yahoo.bard.webservice.data.metric.mappers.NoOpResultSetMapper
 
map(Result, ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.NoOpResultSetMapper
 
map(ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.NoOpResultSetMapper
 
map(ResultSet) - Method in class com.yahoo.bard.webservice.data.metric.mappers.PaginationMapper
Cuts the result set down to just the page requested.
map(Result, ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.PaginationMapper
 
map(ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.PaginationMapper
 
map(Result, ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.PartialDataResultSetMapper
Remove result records which are missing and not marked as volatile.
map(ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.PartialDataResultSetMapper
 
map(ResultSet) - Method in class com.yahoo.bard.webservice.data.metric.mappers.ResultSetMapper
Take a complete result set and replace it with one altered according to the rules of the concrete mapper.
map(Result, ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.ResultSetMapper
Returns a transformed result row, or null if the row is removed.
map(ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.ResultSetMapper
Returns a transformed schema.
map(ResultSet) - Method in class com.yahoo.bard.webservice.data.metric.mappers.RowNumMapper
 
map(Result, ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.RowNumMapper
 
map(ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.RowNumMapper
 
map(Result, ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.SketchRoundUpMapper
 
map(ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.SketchRoundUpMapper
 
map(ResultSet) - Method in class com.yahoo.bard.webservice.data.metric.mappers.TopNResultSetMapper
 
map(Result, ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.TopNResultSetMapper
 
map(ResultSetSchema) - Method in class com.yahoo.bard.webservice.data.metric.mappers.TopNResultSetMapper
 
MapLookup - Class in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
Lookup property of Lookup Extraction Function using provided map as key value mapping.
MapLookup(Map<String, String>) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.MapLookup
Constructor.
mapNearestDruidQuery(JsonGenerator, Function<DruidQuery, T>) - Static method in class com.yahoo.bard.webservice.druid.serializers.SerializerUtil
JSON tree walk to find the druid query context of the current context and apply handler to the DruidQuery, finds the current context if current context is a druid query.
mapper - Variable in class com.yahoo.bard.webservice.web.handlers.BaseDataRequestHandler
 
mapper - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
mapper - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
mappers - Variable in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
 
MappingResponseProcessor - Class in com.yahoo.bard.webservice.web.responseprocessors
Response Processor which will perform result set mapping.
MappingResponseProcessor(DataApiRequest, ObjectMappersSuite) - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
Constructor.
mapResultSet(ResultSet) - Method in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
Builds a mapped result set by running through ResultSetMappers.
MapStore - Class in com.yahoo.bard.webservice.data.dimension
A HashMap-based implementation of KeyValueStore.
MapStore() - Constructor for class com.yahoo.bard.webservice.data.dimension.MapStore
Private constructor for the singleton pattern.
MapStoreManager - Class in com.yahoo.bard.webservice.data.dimension
Map Store instance manager.
MapStoreManager() - Constructor for class com.yahoo.bard.webservice.data.dimension.MapStoreManager
 
mapToSchemaAvailability(Map<String, SimplifiedIntervalList>, PhysicalTableSchema) - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Map availabilities in schema-less columns to a Column keyed availability map for a given table.
matchNotEmpty(Stream<PhysicalTable>) - Method in interface com.yahoo.bard.webservice.table.resolver.PhysicalTableMatcher
Run matches on each physical table in the stream, filtering down to matching tables.
MaxAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Deprecated.
in favor of LongMaxAggregation or DoubleMaxAggregation, since Druid is deprecating MaxAggregation
MaxAggregation(String, String) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.MaxAggregation
Deprecated.
Constructor.
MaxMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Deprecated.
MaxMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.MaxMaker
Deprecated.
Constructor.
MemDataCache<T extends Serializable> - Class in com.yahoo.bard.webservice.data.cache
MemCached client implementation of DataCache.
MemDataCache() - Constructor for class com.yahoo.bard.webservice.data.cache.MemDataCache
Constructor using a default Memcached Client.
MemDataCache(MemcachedClient) - Constructor for class com.yahoo.bard.webservice.data.cache.MemDataCache
Constructor.
MemTupleDataCache<T extends Serializable,V extends Serializable> - Class in com.yahoo.bard.webservice.data.cache
Memcached client implementation of TupleDataCache.
MemTupleDataCache() - Constructor for class com.yahoo.bard.webservice.data.cache.MemTupleDataCache
Constructor using a default memcached client.
MemTupleDataCache(MemcachedClient) - Constructor for class com.yahoo.bard.webservice.data.cache.MemTupleDataCache
Constructor.
MemTupleDataCache.DataEntry<T extends Serializable,V extends Serializable> - Class in com.yahoo.bard.webservice.data.cache
Memcached implementation of the data cache entry of the tuple data cache.
merge(TemplateDruidQuery) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Merges two template queries into one.
merge(DataApiRequest) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQueryMerger
Merge all of the TemplateDruidQueries from all of the Metrics in an DataApiRequest together.
mergeIntervalSet(Set<Interval>) - Static method in class com.yahoo.bard.webservice.util.DateTimeUtils
Merge all contiguous and overlapping intervals in a set together and return the set with the merged intervals.
mergeIntervalToSet(Set<Interval>, Interval) - Static method in class com.yahoo.bard.webservice.util.DateTimeUtils
Merge an interval into the given interval set.
mergeSecurityFilters(Map<Dimension, Set<ApiFilter>>, Set<ApiFilter>) - Method in class com.yahoo.bard.webservice.web.security.RoleDimensionApiFilterRequestMapper
Merge the request filters with the dimension filters for this request.
MESSAGE_FORMAT - Static variable in class com.yahoo.bard.webservice.table.resolver.AggregatableDimensionsMatcher
 
MESSAGE_FORMAT - Static variable in class com.yahoo.bard.webservice.table.resolver.SchemaPhysicalTableMatcher
 
MESSAGE_FORMAT - Static variable in class com.yahoo.bard.webservice.table.resolver.TimeAlignmentPhysicalTableMatcher
 
MessageFormatter - Interface in com.yahoo.bard.webservice
Message Formatter interface provides shared functionality to support classes which provide formatted logging and messaging.
MetadataHttpResponseChannel - Class in com.yahoo.bard.webservice.async
Handles sending job information to the user.
MetadataHttpResponseChannel(AsyncResponse, ObjectWriter) - Constructor for class com.yahoo.bard.webservice.async.MetadataHttpResponseChannel
Builds a channel for sending metadata requests back to the user.
method - Variable in class com.yahoo.bard.webservice.logging.blocks.Preface
 
metric - Variable in class com.yahoo.bard.webservice.data.config.ResourceDictionaries
 
metric - Variable in class com.yahoo.bard.webservice.logging.blocks.MetricRequest
 
METRIC_VALUES_KEY - Static variable in class com.yahoo.bard.webservice.data.ResultSerializationProxy
 
MetricColumn - Class in com.yahoo.bard.webservice.data.metric
Metric.
MetricColumn(String) - Constructor for class com.yahoo.bard.webservice.data.metric.MetricColumn
Constructor.
MetricColumnWithValueType - Class in com.yahoo.bard.webservice.data.metric
The class which contains an information of metric value type.
MetricColumnWithValueType(String, String) - Constructor for class com.yahoo.bard.webservice.data.metric.MetricColumnWithValueType
Constructor.
MetricDictionary - Class in com.yahoo.bard.webservice.data.metric
Map of MetricName to LogicalMetric.
MetricDictionary() - Constructor for class com.yahoo.bard.webservice.data.metric.MetricDictionary
Create a metric dictionary with global scope.
MetricField - Interface in com.yahoo.bard.webservice.druid.model
This marker interface combines Aggregations and PostAggregations so that they can be collectively referenced.
MetricInstance - Class in com.yahoo.bard.webservice.data.config.metric
A Metric instance holds all of the information needed to construct a LogicalMetric.
MetricInstance(String, MetricMaker, String...) - Constructor for class com.yahoo.bard.webservice.data.config.metric.MetricInstance
Deprecated.
logical metric needs more config-richness to not just configure metric name, but also metric long name, description, etc. Use MetricInstance.MetricInstance(LogicalMetricInfo, MetricMaker, String...) instead.
MetricInstance(LogicalMetricInfo, MetricMaker, String...) - Constructor for class com.yahoo.bard.webservice.data.config.metric.MetricInstance
Construct a MetricInstance from Strings with a list of dependencyMetricNames.
MetricInstance(FieldName, MetricMaker, FieldName...) - Constructor for class com.yahoo.bard.webservice.data.config.metric.MetricInstance
Deprecated.
logical metric needs more config-richness to not just configure metric name, but also metric long name, description, etc. Use MetricInstance.MetricInstance(LogicalMetricInfo, MetricMaker, FieldName...) instead.
MetricInstance(LogicalMetricInfo, MetricMaker, FieldName...) - Constructor for class com.yahoo.bard.webservice.data.config.metric.MetricInstance
Construct a MetricInstance from FieldNames with a list of dependencyFields.
MetricInstance(LogicalMetricInfo, MetricMaker) - Constructor for class com.yahoo.bard.webservice.data.config.metric.MetricInstance
Construct a MetricInstance from FieldNames.
metricLoader - Variable in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
 
MetricLoader - Interface in com.yahoo.bard.webservice.data.config.metric
Defines the core interactions for loading metrics into a metric dictionary.
MetricMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker produces new metrics from existing metrics or raw configuration.
MetricMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
Construct a fully specified MetricMaker.
MetricParser - Class in com.yahoo.bard.webservice.web
This class will separate the metrics and associated filters from metricString.
MetricParser() - Constructor for class com.yahoo.bard.webservice.web.MetricParser
 
MetricRegistryFactory - Class in com.yahoo.bard.webservice.application
EVIL - a RegistryFactory: An object which builds an object which builds objects.
MetricRegistryFactory() - Constructor for class com.yahoo.bard.webservice.application.MetricRegistryFactory
 
MetricRequest - Class in com.yahoo.bard.webservice.logging.blocks
Main log of a request served by the MetricsServlet.
MetricRequest(String) - Constructor for class com.yahoo.bard.webservice.logging.blocks.MetricRequest
Constructor.
metrics - Variable in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
The metric dictionary from which dependent metrics will be resolved.
metrics - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
MetricsApiRequest - Interface in com.yahoo.bard.webservice.web.apirequest
Metrics API Request.
MetricsApiRequestImpl - Class in com.yahoo.bard.webservice.web.apirequest
Metrics API Request Implementation binds, validates, and models the parts of a request to the metrics endpoint.
MetricsApiRequestImpl(String, String, String, String, MetricDictionary, UriInfo) - Constructor for class com.yahoo.bard.webservice.web.apirequest.MetricsApiRequestImpl
Parses the API request URL and generates the Api Request object.
MetricServletContextListener - Class in com.yahoo.bard.webservice.application
Servlet Context Listener which initializes the Codahale metrics registry used by the Codahale metrics filter and the metrics servlet.
MetricServletContextListener() - Constructor for class com.yahoo.bard.webservice.application.MetricServletContextListener
 
metricsFilterSetBuilder - Static variable in class com.yahoo.bard.webservice.druid.util.FieldConverterSupplier
 
MetricsFilterSetBuilder - Interface in com.yahoo.bard.webservice.web
An interface containing helper methods to build filtered metrics.
MetricsServlet - Class in com.yahoo.bard.webservice.web.endpoints
Resource code for metric resource endpoints.
MetricsServlet(MetricDictionary, LogicalTableDictionary, RequestMapper, ObjectMappersSuite, ResponseFormatResolver) - Constructor for class com.yahoo.bard.webservice.web.endpoints.MetricsServlet
Constructor.
MetricUnionAvailability - Class in com.yahoo.bard.webservice.table.availability
An implementation of Availability which describes a union of source availabilities, filtered by required metrics and then intersected on time available for required columns.
MetricUnionAvailability(Set<Availability>, Map<Availability, Set<String>>) - Constructor for class com.yahoo.bard.webservice.table.availability.MetricUnionAvailability
Constructor.
MetricUnionCompositeTable - Class in com.yahoo.bard.webservice.table
An implementation of PhysicalTable backed by MetricUnionAvailability.
MetricUnionCompositeTable(TableName, ZonedTimeGrain, Set<Column>, Set<ConfigPhysicalTable>, Map<String, String>, Map<Availability, Set<String>>) - Constructor for class com.yahoo.bard.webservice.table.MetricUnionCompositeTable
Constructor.
MetricUnionCompositeTableDefinition - Class in com.yahoo.bard.webservice.data.config.table
Holds the fields needed to define a Metric Union Composite Table.
MetricUnionCompositeTableDefinition(TableName, ZonedTimeGrain, Set<FieldName>, Set<TableName>, Set<? extends DimensionConfig>) - Constructor for class com.yahoo.bard.webservice.data.config.table.MetricUnionCompositeTableDefinition
Define a physical table using a zoned time grain.
MetricUnionCompositeTableDefinition(TableName, ZonedTimeGrain, Set<FieldName>, Set<TableName>, Set<? extends DimensionConfig>, Map<String, String>) - Constructor for class com.yahoo.bard.webservice.data.config.table.MetricUnionCompositeTableDefinition
Define a physical table with provided logical to physical column name mappings.
MILLISECONDS_PER_NANOSECOND - Static variable in class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
 
MinAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Deprecated.
in favor of LongMinAggregation, since Druid is deprecating MinAggregation
MinAggregation(String, String) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.MinAggregation
Deprecated.
Constructor.
MinMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Deprecated.
MinMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.MinMaker
Deprecated.
Constructor.
MISSING_DEPENDANT_TABLE_FORMAT - Static variable in class com.yahoo.bard.webservice.data.config.table.MetricUnionCompositeTableDefinition
 
MISSING_METRIC_FORMAT - Static variable in class com.yahoo.bard.webservice.data.config.table.MetricUnionCompositeTableDefinition
 
missingIntervals - Variable in class com.yahoo.bard.webservice.web.ResponseData
 
MODULE_CONFIG_FILE_NAME - Static variable in class com.yahoo.bard.webservice.config.ModuleLoader
The file name pattern describing module configuration files.
MODULE_NAME_KEY - Static variable in class com.yahoo.bard.webservice.config.ConfigurationGraph
The special property which uniquely identifies the name of the module.
ModuleLoader - Class in com.yahoo.bard.webservice.config
Utilities to help load resources for the system configuration.
ModuleLoader(ConfigResourceLoader) - Constructor for class com.yahoo.bard.webservice.config.ModuleLoader
Constructor.
MultiClauseFilter - Class in com.yahoo.bard.webservice.druid.model.filter
Filter parent class for filters which take a list of child filters.
MultiClauseFilter(FilterType, List<Filter>) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.MultiClauseFilter
Constructor.
MultiClauseHaving - Class in com.yahoo.bard.webservice.druid.model.having
Abstract parent of having models which take a set of other having filters.
MultiClauseHaving(HavingType, List<Having>) - Constructor for class com.yahoo.bard.webservice.druid.model.having.MultiClauseHaving
Constructor.

N

name - Variable in class com.yahoo.bard.webservice.application.SchedulableTask
 
name() - Method in interface com.yahoo.bard.webservice.config.FeatureFlag
Returns the name of a specific flag included in a class that implements this interface.
NamespaceLookup - Class in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
Lookup property of Lookup Extraction Function using namespace as key value mapping.
NamespaceLookup(String) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.NamespaceLookup
Constructor.
nest() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Transforms a N-pass query into a (N+1)-pass query.
nest() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
Splits an Aggregation for 2-pass aggregation into an inner & outer Aggregation.
nest() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
Cardinality aggregators cannot be safely nested due to correctness constraints which Bard does not currently support.
nest() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CountAggregation
Nesting a 'count' aggregation changes the outer aggregation to a 'longSum' whereas the inner aggregation remains unchanged.
nest() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
Splits an Aggregation for 2-pass aggregation into an inner filtered aggregation & outer aggregation.
nest() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchCountAggregation
Deprecated.
 
newCollector() - Method in class com.yahoo.bard.webservice.data.dimension.impl.TimeLimitingCollectorManager
 
next() - Method in class com.yahoo.bard.webservice.util.IntervalPeriodIterator
 
next - Variable in class com.yahoo.bard.webservice.web.handlers.CacheRequestHandler
 
next - Variable in class com.yahoo.bard.webservice.web.handlers.CacheV2RequestHandler
 
next - Variable in class com.yahoo.bard.webservice.web.handlers.DebugRequestHandler
 
next - Variable in class com.yahoo.bard.webservice.web.handlers.EtagCacheRequestHandler
 
next - Variable in class com.yahoo.bard.webservice.web.handlers.PartialDataRequestHandler
 
next - Variable in class com.yahoo.bard.webservice.web.handlers.SplitQueryRequestHandler
 
next - Variable in class com.yahoo.bard.webservice.web.handlers.VolatileDataRequestHandler
 
next - Variable in class com.yahoo.bard.webservice.web.handlers.WeightCheckRequestHandler
 
NextMacroCalculation - Class in com.yahoo.bard.webservice.web
A Class to compute the current DateTime with the addition of period for the next macro.
NextMacroCalculation() - Constructor for class com.yahoo.bard.webservice.web.NextMacroCalculation
 
NO_LIMIT - Static variable in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
 
NO_OFFSET - Static variable in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
 
NO_OP_MAP_PROVIDER - Static variable in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
 
NO_OP_MAPPER - Static variable in class com.yahoo.bard.webservice.data.config.metric.makers.MetricMaker
 
NO_USER_PRINCIPAL_USER_NAME - Static variable in class com.yahoo.bard.webservice.logging.blocks.Preface
 
NoMatchFoundException - Exception in com.yahoo.bard.webservice.table.resolver
An exception for PhysicalTableMatchers when they return no matches.
NoMatchFoundException(String) - Constructor for exception com.yahoo.bard.webservice.table.resolver.NoMatchFoundException
Constructor.
noneFoundException() - Method in class com.yahoo.bard.webservice.table.resolver.AggregatableDimensionsMatcher
 
noneFoundException() - Method in interface com.yahoo.bard.webservice.table.resolver.PhysicalTableMatcher
Exception to throw if no tables match.
noneFoundException() - Method in class com.yahoo.bard.webservice.table.resolver.SchemaPhysicalTableMatcher
 
noneFoundException() - Method in class com.yahoo.bard.webservice.table.resolver.TimeAlignmentPhysicalTableMatcher
 
NoOpApiJobStore - Class in com.yahoo.bard.webservice.async.jobs.stores
An ApiJobStore that doesn't actually do anything.
NoOpApiJobStore() - Constructor for class com.yahoo.bard.webservice.async.jobs.stores.NoOpApiJobStore
 
NoOpPreResponseStore - Class in com.yahoo.bard.webservice.async.preresponses.stores
A PreResponseStore that doesn't actually do anything.
NoOpPreResponseStore() - Constructor for class com.yahoo.bard.webservice.async.preresponses.stores.NoOpPreResponseStore
 
NoOpRequestMapper<T extends ApiRequest> - Class in com.yahoo.bard.webservice.web
Default RequestMapper implementation.
NoOpRequestMapper(ResourceDictionaries) - Constructor for class com.yahoo.bard.webservice.web.NoOpRequestMapper
Constructor.
NoOpResultSetMapper - Class in com.yahoo.bard.webservice.data.metric.mappers
NoOp Result set mapper.
NoOpResultSetMapper() - Constructor for class com.yahoo.bard.webservice.data.metric.mappers.NoOpResultSetMapper
 
NoOpSearchProvider - Class in com.yahoo.bard.webservice.data.dimension.impl
NoSearchProvider class
NoOpSearchProvider(int) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
Constructor.
NoOpSearchProviderManager - Class in com.yahoo.bard.webservice.data.dimension.impl
NoOpSearchProvider factory.
NoOpSearchProviderManager() - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProviderManager
 
not(Predicate<T>) - Static method in class com.yahoo.bard.webservice.util.StreamUtils
Negate the given predicate.
NotFilter - Class in com.yahoo.bard.webservice.druid.model.filter
Filter for logical NOT applied to filter expression.
NotFilter(Filter) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.NotFilter
Constructor.
NotHaving - Class in com.yahoo.bard.webservice.druid.model.having
Having clause model for logical NOT applied to a having expressions.
NotHaving(Having) - Constructor for class com.yahoo.bard.webservice.druid.model.having.NotHaving
Constructor.
notinFilterOperation(TreeSet<DimensionRow>, ApiFilter) - Method in interface com.yahoo.bard.webservice.data.dimension.FilterDimensionRows
Notin-filter operation.
notinFilterOperation(TreeSet<DimensionRow>, ApiFilter) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
NoVolatileIntervalsFunction - Class in com.yahoo.bard.webservice.data.volatility
Treat no intervals as volatile.
NumberedShardSpec - Class in com.yahoo.bard.webservice.druid.model.metadata
NumberedShardSpec class.
NumberedShardSpec(String, int, int) - Constructor for class com.yahoo.bard.webservice.druid.model.metadata.NumberedShardSpec
Creates a numbered shard specification given a type, a partition number and the total number of partitions.
NumberedShardSpec(NoneShardSpec) - Constructor for class com.yahoo.bard.webservice.druid.model.metadata.NumberedShardSpec
Creates numbered shard spec from an unsharded spec.
numberOfIncoming - Variable in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
numberOfOutgoing - Variable in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
numberOfRows - Variable in class com.yahoo.bard.webservice.logging.blocks.Response
 
numberOfValues - Variable in class com.yahoo.bard.webservice.logging.blocks.Filter
 
numBuckets - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
numEachFilterType - Variable in class com.yahoo.bard.webservice.logging.blocks.DruidFilterInfo
 
NumericHaving - Class in com.yahoo.bard.webservice.druid.model.having
Having clause model for numeric matching expressions.
NumericHaving(HavingType, String, Number) - Constructor for class com.yahoo.bard.webservice.druid.model.having.NumericHaving
Constructor.

O

objectMappers - Variable in class com.yahoo.bard.webservice.data.HttpResponseMaker
 
objectMappers - Variable in class com.yahoo.bard.webservice.web.AbstractResponse
 
objectMappers - Variable in class com.yahoo.bard.webservice.web.endpoints.EndpointServlet
 
objectMappers - Variable in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
 
ObjectMappersSuite - Class in com.yahoo.bard.webservice.application
Gathers all the object mappers that are used for object serialization/deserialization.
ObjectMappersSuite() - Constructor for class com.yahoo.bard.webservice.application.ObjectMappersSuite
No-arg constructor.
of(String) - Static method in interface com.yahoo.bard.webservice.data.config.names.ApiMetricName
Wrap a string in an anonymous instance of ApiMetricName.
of(String) - Static method in interface com.yahoo.bard.webservice.data.config.names.DataSourceName
Wrap a string in an anonymous instance of TableName.
of(String) - Static method in interface com.yahoo.bard.webservice.data.config.names.TableName
Wrap a string in an anonymous instance of TableName.
omitField(JsonNode, String, ObjectMapper) - Static method in class com.yahoo.bard.webservice.util.Utils
Given a field name and a tree of json nodes, empty the contents of all the json nodes matching the field name.
onCompleted() - Method in class com.yahoo.bard.webservice.async.MetadataHttpResponseChannel
 
onCompleted() - Method in class com.yahoo.bard.webservice.data.HttpResponseChannel
 
onCompleted() - Method in class com.yahoo.bard.webservice.util.CacheLastObserver
 
ONE_RESULT - Static variable in class com.yahoo.bard.webservice.web.util.PaginationParameters
Return only the first result.
onError(Throwable) - Method in class com.yahoo.bard.webservice.async.MetadataHttpResponseChannel
 
onError(Throwable) - Method in class com.yahoo.bard.webservice.data.HttpResponseChannel
Method to handle an error case from its observables.
onError(Throwable) - Method in class com.yahoo.bard.webservice.util.CacheLastObserver
 
onEvent(ApplicationEvent) - Method in class com.yahoo.bard.webservice.web.filters.QueryParameterNormalizationFilter
 
onNext(String) - Method in class com.yahoo.bard.webservice.async.MetadataHttpResponseChannel
 
onNext(PreResponse) - Method in class com.yahoo.bard.webservice.data.HttpResponseChannel
 
onNext(T) - Method in class com.yahoo.bard.webservice.util.CacheLastObserver
 
onRequest(RequestEvent) - Method in class com.yahoo.bard.webservice.web.filters.QueryParameterNormalizationFilter
 
open() - Method in interface com.yahoo.bard.webservice.data.dimension.KeyValueStore
Open the store.
open() - Method in class com.yahoo.bard.webservice.data.dimension.MapStore
 
open() - Method in class com.yahoo.bard.webservice.data.dimension.RedisStore
 
operator - Variable in class com.yahoo.bard.webservice.logging.blocks.Filter
 
OrderByColumn - Class in com.yahoo.bard.webservice.druid.model.orderby
OrderByColumn class.
OrderByColumn(LogicalMetric, SortDirection) - Constructor for class com.yahoo.bard.webservice.druid.model.orderby.OrderByColumn
Constructor.
OrderByColumn(Aggregation, SortDirection) - Constructor for class com.yahoo.bard.webservice.druid.model.orderby.OrderByColumn
Constructor.
OrderByColumn(PostAggregation, SortDirection) - Constructor for class com.yahoo.bard.webservice.druid.model.orderby.OrderByColumn
Constructor.
OrderByColumn(String, SortDirection) - Constructor for class com.yahoo.bard.webservice.druid.model.orderby.OrderByColumn
Constructor which accepts generic column with direction.
OrFilter - Class in com.yahoo.bard.webservice.druid.model.filter
Filter for logical OR applied to a set of druid filter expressions.
OrFilter(List<Filter>) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.OrFilter
Constructor.
OrHaving - Class in com.yahoo.bard.webservice.druid.model.having
Having clause model for logical OR applied to a set of druid having expressions.
OrHaving(List<Having>) - Constructor for class com.yahoo.bard.webservice.druid.model.having.OrHaving
Constructor.

P

PageNotFoundException - Exception in com.yahoo.bard.webservice.web
Indicates that a page past the last page of (paginated) results is requested.
PageNotFoundException(int, int, int) - Constructor for exception com.yahoo.bard.webservice.web.PageNotFoundException
Constructor.
pages - Variable in class com.yahoo.bard.webservice.web.AbstractResponse
 
Pagination<T> - Interface in com.yahoo.bard.webservice.util
Interface for pagination.
pagination - Variable in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
pagination - Variable in class com.yahoo.bard.webservice.web.ResponseData
 
PaginationLink - Enum in com.yahoo.bard.webservice.web.util
Enumerates the names of the page links that may show up in the headers and/or bodies of responses that contain pagination.
paginationLinks - Variable in class com.yahoo.bard.webservice.web.ResponseData
 
PaginationMapper - Class in com.yahoo.bard.webservice.data.metric.mappers
Extracts the requested page of data from the Druid results.
PaginationMapper(PaginationParameters, MappingResponseProcessor, UriBuilder) - Constructor for class com.yahoo.bard.webservice.data.metric.mappers.PaginationMapper
Constructor.
paginationParameters - Variable in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
PaginationParameters - Class in com.yahoo.bard.webservice.web.util
A wrapper around the pagination parameters ('perPage' and 'page') to simplify working with pagination requests.
PaginationParameters(String, String) - Constructor for class com.yahoo.bard.webservice.web.util.PaginationParameters
Given a pair of strings, attempts to parse them into ints representing the pagination parameters.
PaginationParameters(int, int) - Constructor for class com.yahoo.bard.webservice.web.util.PaginationParameters
Constructor for already-parsed pagination parameters.
PaginationRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Injects the result set mapper for data pagination if an API request asks for pagination.
PaginationRequestHandler(DataRequestHandler) - Constructor for class com.yahoo.bard.webservice.web.handlers.PaginationRequestHandler
Constructor.
Pair(K, V) - Constructor for class com.yahoo.bard.webservice.data.cache.HashDataCache.Pair
Constructor.
parse(JsonNode, ResultSetSchema, QueryType, DateTimeZone) - Method in class com.yahoo.bard.webservice.data.DruidResponseParser
Parse Druid GroupBy result into ResultSet.
parseAvroFileDimensionRows(Dimension, String, Consumer<DimensionRow>) - Method in class com.yahoo.bard.webservice.data.dimension.AvroDimensionRowParser
Parses the avro file and sends dimension rows to a consumer.
parseAvroFileDimensionRows(Dimension, String) - Method in class com.yahoo.bard.webservice.data.dimension.AvroDimensionRowParser
Parses the avro file and returns the dimension rows.
parseDimensionRow(Map<String, String>) - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Generate a DimensionRow for this dimension from a field name / value map.
parseDimensionRow(Map<String, String>) - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
parseGranularity(String, DateTimeZone) - Method in interface com.yahoo.bard.webservice.data.time.GranularityParser
Parse a granularity from a string and time zone.
parseGranularity(String) - Method in interface com.yahoo.bard.webservice.data.time.GranularityParser
Parse a granularity from a string.
parseGranularity(String, DateTimeZone) - Method in class com.yahoo.bard.webservice.data.time.StandardGranularityParser
 
parseGranularity(String) - Method in class com.yahoo.bard.webservice.data.time.StandardGranularityParser
 
PARTIAL_DATA_HEADER - Static variable in class com.yahoo.bard.webservice.web.handlers.PartialDataRequestHandler
 
PartialDataHandler - Class in com.yahoo.bard.webservice.data
Partial data handler deals with finding the missing intervals for a given request.
PartialDataHandler() - Constructor for class com.yahoo.bard.webservice.data.PartialDataHandler
 
partialDataHandler - Variable in class com.yahoo.bard.webservice.web.handlers.PartialDataRequestHandler
 
partialDataHandler - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
partialDataHandler - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
PartialDataRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
A request handler that builds responses which filter partial data.
PartialDataRequestHandler(DataRequestHandler, PhysicalTableDictionary, PartialDataHandler) - Constructor for class com.yahoo.bard.webservice.web.handlers.PartialDataRequestHandler
PartialDataRequestHandler(DataRequestHandler, PartialDataHandler) - Constructor for class com.yahoo.bard.webservice.web.handlers.PartialDataRequestHandler
Wrap the response processor in a partial data check.
PartialDataResultSetMapper - Class in com.yahoo.bard.webservice.data.metric.mappers
A mapper that removes results which overlap a missing interval set.
PartialDataResultSetMapper(SimplifiedIntervalList, Supplier<SimplifiedIntervalList>) - Constructor for class com.yahoo.bard.webservice.data.metric.mappers.PartialDataResultSetMapper
Build a mapper to filter results over missing intervals from a result set, retaining any that are also volatile.
PartialExtractionFunction - Class in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
Regular Expression ExtractionFunction that returns the dimension value if it matches the regular expression.
PartialExtractionFunction(Pattern) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.PartialExtractionFunction
Constructor.
PartialTimeComparator - Class in com.yahoo.bard.webservice.table.resolver
Comparator to prefer less partial data duration within the query.
PartialTimeComparator(QueryPlanningConstraint, PartialDataHandler) - Constructor for class com.yahoo.bard.webservice.table.resolver.PartialTimeComparator
Constructor.
PartitionAvailability - Class in com.yahoo.bard.webservice.table.availability
An implementation of Availability which describes a union of source availabilities, filtered by request parameters, such that all sources which pertain to a query are considered when calculating availability.
PartitionAvailability(Map<Availability, DataSourceFilter>) - Constructor for class com.yahoo.bard.webservice.table.availability.PartitionAvailability
Constructor.
PartitionCompositeTable - Class in com.yahoo.bard.webservice.table
An implementation of PhysicalTable backed by PartitionAvailability availability.
PartitionCompositeTable(TableName, ZonedTimeGrain, Set<Column>, Map<String, String>, Map<ConfigPhysicalTable, DataSourceFilter>) - Constructor for class com.yahoo.bard.webservice.table.PartitionCompositeTable
Constructor.
partitionsToMapCollector() - Static method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataService
A collector to aggregate all partitions of a segment into a map.
PATCH - Annotation Type in com.yahoo.bard.webservice.web
PATCH HTTP method marker for Jersey routing.
period - Variable in class com.yahoo.bard.webservice.application.LoadTask
 
PERIOD_TYPE_NAME - Static variable in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
 
periodIterator(ReadablePeriod) - Method in class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Create an Iterator using IntervalPeriodInterators to all intervals of this list broken up into pieces of size period.
PermissiveAvailability - Class in com.yahoo.bard.webservice.table.availability
An availability which allows missing intervals, i.e.
PermissiveAvailability(DataSourceName, DataSourceMetadataService) - Constructor for class com.yahoo.bard.webservice.table.availability.PermissiveAvailability
Constructor.
PermissivePhysicalTable - Class in com.yahoo.bard.webservice.table
A sibling of strict physical table, but with permissive availability.
PermissivePhysicalTable(TableName, ZonedTimeGrain, Set<Column>, Map<String, String>, DataSourceMetadataService) - Constructor for class com.yahoo.bard.webservice.table.PermissivePhysicalTable
Create a permissive physical table.
PermissivePhysicalTable(TableName, ZonedTimeGrain, Set<Column>, Map<String, String>, PermissiveAvailability) - Constructor for class com.yahoo.bard.webservice.table.PermissivePhysicalTable
Create a permissive physical table.
PermissivePhysicalTableDefinition - Class in com.yahoo.bard.webservice.data.config.table
Holds the fields needed to define a Permissive Physical Table.
PermissivePhysicalTableDefinition(TableName, ZonedTimeGrain, Set<FieldName>, Set<? extends DimensionConfig>) - Constructor for class com.yahoo.bard.webservice.data.config.table.PermissivePhysicalTableDefinition
Define a permissive physical table.
PermissivePhysicalTableDefinition(TableName, ZonedTimeGrain, Set<FieldName>, Set<? extends DimensionConfig>, Map<String, String>) - Constructor for class com.yahoo.bard.webservice.data.config.table.PermissivePhysicalTableDefinition
Define a permissive physical table with provided logical to physical column name mappings.
PerRequestDictionaryHavingGenerator - Class in com.yahoo.bard.webservice.web.apirequest
A having generator decorator that uses the metrics from the query as the dictionary of metrics for building havings.
PerRequestDictionaryHavingGenerator(DefaultHavingApiGenerator) - Constructor for class com.yahoo.bard.webservice.web.apirequest.PerRequestDictionaryHavingGenerator
Constructor.
physical - Variable in class com.yahoo.bard.webservice.data.config.ResourceDictionaries
 
PhysicalDataSourceConstraint - Class in com.yahoo.bard.webservice.table.resolver
Data source constraint containing physical name of the columns.
PhysicalDataSourceConstraint(DataSourceConstraint, PhysicalTableSchema) - Constructor for class com.yahoo.bard.webservice.table.resolver.PhysicalDataSourceConstraint
Constructor.
PhysicalTable - Interface in com.yahoo.bard.webservice.table
An interface describing a fact level physical table.
PhysicalTableDefinition - Class in com.yahoo.bard.webservice.data.config.table
Common configurations necessary to build a physical table.
PhysicalTableDefinition(TableName, ZonedTimeGrain, Set<FieldName>, Set<? extends DimensionConfig>) - Constructor for class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
Constructor for sub-class to call.
PhysicalTableDefinition(TableName, ZonedTimeGrain, Set<FieldName>, Set<? extends DimensionConfig>, Map<String, String>) - Constructor for class com.yahoo.bard.webservice.data.config.table.PhysicalTableDefinition
Constructor with provided logical to physical name mapping.
PhysicalTableDictionary - Class in com.yahoo.bard.webservice.table
Map of a druid table name to PhysicalTable.
PhysicalTableDictionary() - Constructor for class com.yahoo.bard.webservice.table.PhysicalTableDictionary
 
physicalTableDictionary - Variable in class com.yahoo.bard.webservice.web.handlers.VolatileDataRequestHandler
 
physicalTableDictionary - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
physicalTableDictionary - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
PhysicalTableMatcher - Interface in com.yahoo.bard.webservice.table.resolver
Function to test whether a Physical Table can satisfy a criteria for a request.
PhysicalTableResolver - Interface in com.yahoo.bard.webservice.table.resolver
Physical table resolver selects the best physical table that satisfied a query (if any) from a supply of candidate physical tables.
PhysicalTableSchema - Class in com.yahoo.bard.webservice.table
The schema for a physical table.
PhysicalTableSchema(ZonedTimeGrain, Iterable<Column>, Map<String, String>) - Constructor for class com.yahoo.bard.webservice.table.PhysicalTableSchema
Constructor.
POOL - Static variable in class com.yahoo.bard.webservice.data.dimension.RedisStoreManager
 
PostAggregation - Class in com.yahoo.bard.webservice.druid.model.postaggregation
Base class for model representing post aggregations.
PostAggregation(PostAggregationType, String) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation
Constructor.
PostAggregation.DefaultPostAggregationType - Enum in com.yahoo.bard.webservice.druid.model.postaggregation
Default types of post aggregations.
PostAggregationEvaluator - Class in com.yahoo.bard.webservice.sql.evaluator
Evaluates post aggregations.
PostAggregationEvaluator() - Constructor for class com.yahoo.bard.webservice.sql.evaluator.PostAggregationEvaluator
Constructor.
postAggregations - Variable in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidAggregationQuery
 
PostAggregationType - Interface in com.yahoo.bard.webservice.druid.model.postaggregation
An interface for post aggregation types.
postDruidQuery(RequestContext, SuccessCallback, HttpErrorCallback, FailureCallback, DruidQuery<?>) - Method in interface com.yahoo.bard.webservice.druid.client.DruidWebService
Serializes the provided query and invokes POST on the druid broker.
postDruidQuery(RequestContext, SuccessCallback, HttpErrorCallback, FailureCallback, DruidQuery<?>) - Method in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
 
Preface - Class in com.yahoo.bard.webservice.logging.blocks
Logging block for the "inbound" request information, serving as a preface to the subsequent logging blocks.
Preface(ContainerRequestContext) - Constructor for class com.yahoo.bard.webservice.logging.blocks.Preface
Constructor.
preflightResponse() - Method in class com.yahoo.bard.webservice.web.endpoints.CORSPreflightServlet
Responds to the OPTIONS preflight request.
preOrderRightToLeftTraversal(String) - Method in class com.yahoo.bard.webservice.config.ConfigurationGraph
Find the prioritized stream of configurations for a given module (inclusive of the module itself).
preOrderRightToLeftTraversal(String, List<String>) - Method in class com.yahoo.bard.webservice.config.ConfigurationGraph
Find the prioritized stream of configurations for a given module (inclusive of the module itself).
PreResponse - Class in com.yahoo.bard.webservice.web
PreReponse is an encapsulation of ResultSet and ResponseContext.
PreResponse(ResultSet, ResponseContext) - Constructor for class com.yahoo.bard.webservice.web.PreResponse
Build PreResponse using the given ResultSet and ResponseContext.
PreResponseDeserializer - Class in com.yahoo.bard.webservice.data
Class to de-serialize and prepare the PreResponse object from JSON.
PreResponseDeserializer(DimensionDictionary, ObjectMapper, ObjectMapper, GranularityParser) - Constructor for class com.yahoo.bard.webservice.data.PreResponseDeserializer
Class constructor.
PreResponseSerializationProxy - Class in com.yahoo.bard.webservice.data
Simplified version of PreResponse class for json format serialization.
PreResponseSerializationProxy(PreResponse, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.data.PreResponseSerializationProxy
Constructor.
PreResponseStore - Interface in com.yahoo.bard.webservice.async.preresponses.stores
PreResponseStore is responsible for storing PreResponses.
process(ResultSet) - Method in class com.yahoo.bard.webservice.sql.SqlResultSetProcessor
Reads the result set and converts it into a result that druid would produce.
processResponse(JsonNode, DruidAggregationQuery<?>, LoggingContext) - Method in class com.yahoo.bard.webservice.web.responseprocessors.CacheV2ResponseProcessor
 
processResponse(JsonNode, DruidAggregationQuery<?>, LoggingContext) - Method in class com.yahoo.bard.webservice.web.responseprocessors.CachingResponseProcessor
 
processResponse(JsonNode, DruidAggregationQuery<?>, LoggingContext) - Method in class com.yahoo.bard.webservice.web.responseprocessors.DruidPartialDataResponseProcessor
If status code is 200, do the following Extract uncoveredIntervalsOverflowed from X-Druid-Response-Context inside the JsonNode passed into DruidPartialDataResponseProcessor::processResponse, if it is true, invoke error response saying limit overflowed, Extract uncoveredIntervals from X-Druid-Response-Contex inside the JsonNode passed into DruidPartialDataResponseProcessor::processResponse, Parse both the uncoveredIntervals extracted above and allAvailableIntervals extracted from the union of all the query's datasource's availabilities from DataSourceMetadataService into SimplifiedIntervalLists, Compare both SimplifiedIntervalLists above, if allAvailableIntervals has any overlap with uncoveredIntervals, invoke error response indicating druid is missing some data that are we are expecting to exists.
processResponse(JsonNode, DruidAggregationQuery<?>, LoggingContext) - Method in class com.yahoo.bard.webservice.web.responseprocessors.EtagCacheResponseProcessor
 
processResponse(JsonNode, DruidAggregationQuery<?>, LoggingContext) - Method in interface com.yahoo.bard.webservice.web.responseprocessors.ResponseProcessor
Process the response json and respond to the original web request.
processResponse(JsonNode, DruidAggregationQuery<?>, LoggingContext) - Method in class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessor
 
processResponse(JsonNode, DruidAggregationQuery<?>, LoggingContext) - Method in class com.yahoo.bard.webservice.web.responseprocessors.SplitQueryResponseProcessor
 
processResponse(JsonNode, DruidAggregationQuery<?>, LoggingContext) - Method in class com.yahoo.bard.webservice.web.responseprocessors.WeightCheckResponseProcessor
 
processRow(Map<String, Function<String, Number>>, JsonGenerator, String[]) - Method in class com.yahoo.bard.webservice.sql.SqlResultSetProcessor
Processes a single row of results from the result set.
publish(T) - Method in interface com.yahoo.bard.webservice.async.broadcastchannels.BroadcastChannel
Publish is used to publish a message from a Bard box.
publish(T) - Method in class com.yahoo.bard.webservice.async.broadcastchannels.RedisBroadcastChannel
 
publish(T) - Method in class com.yahoo.bard.webservice.async.broadcastchannels.SimpleBroadcastChannel
 
PUBLISH_ON_CLOSED_ERROR_MESSAGE - Static variable in interface com.yahoo.bard.webservice.async.broadcastchannels.BroadcastChannel
 
put(String, String) - Method in interface com.yahoo.bard.webservice.data.dimension.KeyValueStore
Set a value for the key.
put(String, String) - Method in class com.yahoo.bard.webservice.data.dimension.MapStore
 
put(String, String) - Method in class com.yahoo.bard.webservice.data.dimension.RedisStore
 
put(K, V) - Method in class com.yahoo.bard.webservice.util.DelegatingMap
Adds the key and value to the local map, potentially overshadowing a version in the delegate map.
putAll(Map<String, String>) - Method in interface com.yahoo.bard.webservice.data.dimension.KeyValueStore
Set a multiple key/value pairs.
putAll(Map<String, String>) - Method in class com.yahoo.bard.webservice.data.dimension.MapStore
 
putAll(Map<String, String>) - Method in class com.yahoo.bard.webservice.data.dimension.RedisStore
 
putScope(S, K, V) - Method in interface com.yahoo.bard.webservice.util.Scope
Puts a key value pair into an immediate child scope.

Q

quarterlyRound(DateTime) - Static method in class com.yahoo.bard.webservice.util.DateTimeUtils
Round the date time back to the beginning of the nearest (inclusive) month of January, April, July, October.
query(Dimension, DataSource) - Method in interface com.yahoo.bard.webservice.application.DimensionValueLoader
Queries for a specific Dimension against the given DataSource.
query(Dimension, DataSource) - Method in class com.yahoo.bard.webservice.application.DruidDimensionValueLoader
 
query(Dimension, DataSource) - Method in class com.yahoo.bard.webservice.application.SqlDimensionValueLoader
 
query - Variable in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
QUERY_REQUEST_TOTAL - Static variable in class com.yahoo.bard.webservice.web.handlers.DefaultWebServiceHandlerSelector
 
QUERY_WEIGHT_LIMIT_KEY - Static variable in class com.yahoo.bard.webservice.web.util.QueryWeightUtil
 
QueryContext - Class in com.yahoo.bard.webservice.druid.model.query
QueryContext.
QueryContext(Map<QueryContext.Param, Object>, AtomicLong) - Constructor for class com.yahoo.bard.webservice.druid.model.query.QueryContext
Constructor.
QueryContext(Map<QueryContext.Param, Object>) - Constructor for class com.yahoo.bard.webservice.druid.model.query.QueryContext
Constructor.
QueryContext(QueryContext, Map<QueryContext.Param, Object>) - Constructor for class com.yahoo.bard.webservice.druid.model.query.QueryContext
Constructor.
QueryContext.Param - Enum in com.yahoo.bard.webservice.druid.model.query
Enumeration of the available query context keys that can be set.
QueryDataSource - Class in com.yahoo.bard.webservice.druid.model.datasource
QueryDataSource.
QueryDataSource(DruidFactQuery<?>) - Constructor for class com.yahoo.bard.webservice.druid.model.datasource.QueryDataSource
Constructor.
queryDataSourceMetadata(SingleDataSourcePhysicalTable) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
Deprecated.
Pass the DataSourceName directly, rather than via the PhysicalTable
queryDataSourceMetadata(DataSourceName) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
Queries Druid for updated datasource metadata and then updates the datasource metadata service.
queryDimension(Dimension) - Method in interface com.yahoo.bard.webservice.application.DimensionValueLoader
Queries a specific dimension.
QueryParameterNormalizationFilter - Class in com.yahoo.bard.webservice.web.filters
Normalize all query parameter keys to lowercase.
QueryParameterNormalizationFilter() - Constructor for class com.yahoo.bard.webservice.web.filters.QueryParameterNormalizationFilter
 
QueryPlanningConstraint - Class in com.yahoo.bard.webservice.table.resolver
Constraints used to match and resolve the best table for a given query.
QueryPlanningConstraint(Set<Dimension>, Set<Dimension>, Set<Dimension>, Set<String>, ApiFilters, LogicalTable, Set<Interval>, Set<LogicalMetric>, Granularity, Granularity) - Constructor for class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
Constructor.
QueryPlanningConstraint(DataApiRequest, TemplateDruidQuery) - Constructor for class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
Constructor.
QueryPlanningConstraint(TablesApiRequest) - Constructor for class com.yahoo.bard.webservice.table.resolver.QueryPlanningConstraint
Constructor.
QuerySigningService<T> - Interface in com.yahoo.bard.webservice.metadata
Defines the interface of a service that can hold the segment metadata of physical tables.
querySigningService - Variable in class com.yahoo.bard.webservice.web.handlers.CacheV2RequestHandler
 
querySigningService - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
querySigningService - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
queryType - Variable in class com.yahoo.bard.webservice.druid.model.query.AbstractDruidQuery
 
QueryType - Interface in com.yahoo.bard.webservice.druid.model
Types of queries supported by this application.
queryWeightUtil - Variable in class com.yahoo.bard.webservice.web.handlers.WeightCheckRequestHandler
 
QueryWeightUtil - Class in com.yahoo.bard.webservice.web.util
Query Weight Util provides features used for configuring and adjusting weight query thresholds.
QueryWeightUtil() - Constructor for class com.yahoo.bard.webservice.web.util.QueryWeightUtil
Constructor.

R

RateLimitCleanupOnRequestComplete - Interface in com.yahoo.bard.webservice.web.ratelimit
Cleans up the resources related to a RateLimiter tracking an outstanding request.
rateLimiter - Variable in class com.yahoo.bard.webservice.web.filters.RateLimitFilter
 
RateLimiter - Interface in com.yahoo.bard.webservice.web
An object containing the logic to keep track of and limit the amount of requests being made to the webservice.
RateLimitFilter - Class in com.yahoo.bard.webservice.web.filters
Filter all requests to respond RATE_LIMIT if user/global limits are exceeded.
RateLimitFilter(RateLimiter) - Constructor for class com.yahoo.bard.webservice.web.filters.RateLimitFilter
Constructs a RateLimitFilter using the provided rate limiter.
RateLimitFilter() - Constructor for class com.yahoo.bard.webservice.web.filters.RateLimitFilter
Deprecated.
Use the constructor that takes a RateLimiter
RateLimitRequestToken - Interface in com.yahoo.bard.webservice.web.ratelimit
Resource representing an outstanding request.
RATIO_METRIC_CATEGORY - Static variable in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
RawAggregationMetricMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker which only creates aggregations.
RawAggregationMetricMaker(MetricDictionary, BiFunction<String, String, Aggregation>) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.RawAggregationMetricMaker
Constructor.
readCache - Variable in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
record(LogInfo) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Record logging information in the logging context.
RedisBroadcastChannel<T> - Class in com.yahoo.bard.webservice.async.broadcastchannels
A Redis backed implementation of BroadcastChannel.
RedisBroadcastChannel(RedissonClient) - Constructor for class com.yahoo.bard.webservice.async.broadcastchannels.RedisBroadcastChannel
Builds a Broadcastchannel that knows how to communicate with Redis.
RedisStore - Class in com.yahoo.bard.webservice.data.dimension
A Redis-based implementation of KeyValueStore.
RedisStore(String, JedisPool, String) - Constructor for class com.yahoo.bard.webservice.data.dimension.RedisStore
Build a connection to a Redis provider.
RedisStoreManager - Class in com.yahoo.bard.webservice.data.dimension
Redis Store Manager
RedisStoreManager() - Constructor for class com.yahoo.bard.webservice.data.dimension.RedisStoreManager
 
reduce(Collection<TimeLimitingCollectorManager.AccessibleTimeLimitingCollector>) - Method in class com.yahoo.bard.webservice.data.dimension.impl.TimeLimitingCollectorManager
 
refreshIndex(String, DimensionRow, DimensionRow) - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
Refresh lucene index
refreshIndex(Map<String, HashDataCache.Pair<DimensionRow, DimensionRow>>) - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
 
refreshIndex(String, DimensionRow, DimensionRow) - Method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
 
refreshIndex(Map<String, HashDataCache.Pair<DimensionRow, DimensionRow>>) - Method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
 
refreshIndex(String, DimensionRow, DimensionRow) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
refreshIndex(Map<String, HashDataCache.Pair<DimensionRow, DimensionRow>>) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
refreshIndex(String, DimensionRow, DimensionRow) - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Method to add / update indexes.
refreshIndex(Map<String, HashDataCache.Pair<DimensionRow, DimensionRow>>) - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Method to add / update indexes.
RegexFilteredDimensionSpec - Class in com.yahoo.bard.webservice.druid.model.dimension
Filtered DimensionSpec using Regex pattern on Druid multi-dimensional value dimensions.
RegexFilteredDimensionSpec(DimensionSpec, Pattern) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.RegexFilteredDimensionSpec
Constructor.
RegexSearchQuerySpec - Class in com.yahoo.bard.webservice.druid.model.query
Class for specifying the RegexSearchQuerySpec for DruidSearchQuery.
RegexSearchQuerySpec(String) - Constructor for class com.yahoo.bard.webservice.druid.model.query.RegexSearchQuerySpec
Constructor.
RegisteredLookupDimension - Class in com.yahoo.bard.webservice.data.dimension.impl
RegisteredLookupDimension creates a registered look up dimension based on the lookup chain.
RegisteredLookupDimension(RegisteredLookupDimensionConfig) - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.RegisteredLookupDimension
Constructor.
RegisteredLookupDimensionConfig - Interface in com.yahoo.bard.webservice.data.config.dimension
Defines the information needed to configure a RegisteredLookup Dimension.
RegisteredLookupExtractionFunction - Class in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
RegisteredLookup ExtractionFunction that maps dimension values to some corresponding pre-defined values in druid.
RegisteredLookupExtractionFunction(String, Boolean, String, Boolean, Boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
Constructor.
RegisteredLookupExtractionFunction(String) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
Convenience Constructor, defaults: retainMissingValue=false, replaceMissingValueWith=null, injective=false, optimize=true.
RegisteredLookupMetadataLoadTask - Class in com.yahoo.bard.webservice.metadata
Lookup Load task sends requests to Druid coordinator and returns load statuses of lookup metadata in Druid.
RegisteredLookupMetadataLoadTask(DruidWebService, DimensionDictionary) - Constructor for class com.yahoo.bard.webservice.metadata.RegisteredLookupMetadataLoadTask
Constructor.
registerFilters() - Method in class com.yahoo.bard.webservice.application.ResourceConfig
Register the built-in filters.
registerTime(TimedPhase) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Registers the final duration of a stopped timer with the RequestLog.
registerTime() - Method in class com.yahoo.bard.webservice.logging.TimedPhase
Registers the duration of this timer with the RequestLog.
REGISTRY - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
RegularExpressionExtractionFunction - Class in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
Regular Expression ExtractionFunction that returns the first matching group for the given regular expression.
RegularExpressionExtractionFunction(Pattern) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegularExpressionExtractionFunction
Constructor.
RegularExpressionFilter - Class in com.yahoo.bard.webservice.druid.model.filter
Filter for matching a regular expression against a child filter expression.
RegularExpressionFilter(Dimension, Pattern) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.RegularExpressionFilter
Constructor.
REJECT_REQUEST_TOKEN - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
rejectRequest(Meter, boolean, boolean, String) - Method in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
Do the house keeping needed to reject the request.
rejectUiMeter - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
rejectUserMeter - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
remove(String) - Method in interface com.yahoo.bard.webservice.data.dimension.KeyValueStore
Remove a key from store.
remove(String) - Method in class com.yahoo.bard.webservice.data.dimension.MapStore
 
remove(String) - Method in class com.yahoo.bard.webservice.data.dimension.RedisStore
 
remove(Object) - Method in class com.yahoo.bard.webservice.util.DelegatingMap
Delegating map should be changed in a put-only fashion.
removeAllKeys() - Method in class com.yahoo.bard.webservice.data.dimension.RedisStore
Remove all keys associated with the store.
removeDateTimeSortColumn(Map<String, SortDirection>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Method to remove the dateTime column from map of columns and its direction.
removeInstance(String) - Static method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProviderManager
Cleanup the existing instance.
removeInstance(String) - Static method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProviderManager
Cleanup the existing instance.
removeInstance(String) - Static method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProviderManager
Cleanup the existing instance.
removeInstance(String) - Static method in class com.yahoo.bard.webservice.data.dimension.MapStoreManager
Delete the named singleton instance.
removeInstance(String) - Static method in class com.yahoo.bard.webservice.data.dimension.RedisStoreManager
Delete the named singleton instance.
removeLocal(K) - Method in class com.yahoo.bard.webservice.util.DelegatingMap
Remove from the local map.
renderUri(URI) - Method in class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
Render the URI as a string.
replaceIndex(String) - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
 
replaceIndex(String) - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Replaces index with a new index in hot-swap manner.
replacePostAggregation(SketchSetOperationPostAggFunction, PostAggregation, Map<String, List<FilteredAggregation>>) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
 
replacePostAggregation(SketchSetOperationPostAggFunction, PostAggregation, Map<String, List<FilteredAggregation>>) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
replacePostAggregation(SketchSetOperationPostAggFunction, PostAggregation, Map<String, List<FilteredAggregation>>) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
A method to replace postAggs with new postAggs that access the intersection or union of filteredAggregators.
replacePostAggWithPostAggFromMap(PostAggregation, Map<String, Aggregation>) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
 
replacePostAggWithPostAggFromMap(PostAggregation, Map<String, Aggregation>) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
replacePostAggWithPostAggFromMap(PostAggregation, Map<String, Aggregation>) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
Takes a post aggregation and updates its FieldAccessor if its fieldName is present in the map changed.
replaceStore(String) - Method in interface com.yahoo.bard.webservice.data.dimension.KeyValueStore
Replaces key value store with a new key value store.
REQUEST_LIMIT_GLOBAL_KEY - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
REQUEST_LIMIT_PER_USER_KEY - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
REQUEST_LIMIT_UI_KEY - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
REQUEST_MAPPER_NAMESPACE - Static variable in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
REQUEST_MAPPER_NAMESPACE - Static variable in interface com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequest
 
REQUEST_MAPPER_NAMESPACE - Static variable in interface com.yahoo.bard.webservice.web.apirequest.JobsApiRequest
 
REQUEST_MAPPER_NAMESPACE - Static variable in interface com.yahoo.bard.webservice.web.apirequest.MetricsApiRequest
 
REQUEST_MAPPER_NAMESPACE - Static variable in interface com.yahoo.bard.webservice.web.apirequest.SlicesApiRequest
 
REQUEST_MAPPER_NAMESPACE - Static variable in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
REQUEST_WORKFLOW_TIMER - Static variable in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
REQUEST_WORKFLOW_TIMER - Static variable in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
requestBypassMeter - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
RequestContext - Class in com.yahoo.bard.webservice.web.handlers
A container for state gathered by the web container and used to handle requests.
RequestContext(ContainerRequestContext, boolean) - Constructor for class com.yahoo.bard.webservice.web.handlers.RequestContext
Build a context for a request.
requestedApiDimensionFields - Variable in class com.yahoo.bard.webservice.web.ResponseData
 
RequestedIntervalsFunction - Interface in com.yahoo.bard.webservice.metadata
RequestedIntervalsFunction is an implementation of Function that takes a DruidAggregationQuery and returns a SimplifiedIntervalList.
requestGlobalCounter - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
RequestHandlerUtils - Class in com.yahoo.bard.webservice.web.handlers
A static utility class for assisting request processing.
RequestHandlerUtils() - Constructor for class com.yahoo.bard.webservice.web.handlers.RequestHandlerUtils
 
RequestIdHeaderFilter - Class in com.yahoo.bard.webservice.web.filters
Filter to return X-Request-ID.
RequestIdHeaderFilter() - Constructor for class com.yahoo.bard.webservice.web.filters.RequestIdHeaderFilter
 
requestLimitGlobal - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
requestLimitPerUser - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
requestLimitUi - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
RequestLog - Class in com.yahoo.bard.webservice.logging
Represents the logging framework that provides timing capabilities of arbitrary phases on the handling lifecycle of a request and accumulation of information for such a request in a single mega log line.
RequestMapper<T extends ApiRequest> - Class in com.yahoo.bard.webservice.web
RequestMapper will do post processing on a given ApiRequest, such as rewriting or validating queries.
RequestMapper(ResourceDictionaries) - Constructor for class com.yahoo.bard.webservice.web.RequestMapper
Constructor.
RequestQueryGranularityResolver - Class in com.yahoo.bard.webservice.table.resolver
A function to take an ApiRequest and TemplateDruidQuery and determine a Granularity which must be satisfied by a fact source in order to satisfy this request.
RequestQueryGranularityResolver() - Constructor for class com.yahoo.bard.webservice.table.resolver.RequestQueryGranularityResolver
 
requestUiMeter - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
requestUserMeter - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
RequestValidationException - Exception in com.yahoo.bard.webservice.web
ApiRequest Validation Failed.
RequestValidationException(Response.StatusType, String, String) - Constructor for exception com.yahoo.bard.webservice.web.RequestValidationException
Constructor for RequestValidationException.
RequestValidationException(Response.StatusType, String, Throwable) - Constructor for exception com.yahoo.bard.webservice.web.RequestValidationException
Constructor for RequestValidationException.
RequestWorkflowProvider - Interface in com.yahoo.bard.webservice.web.handlers.workflow
Request workflow provider builds a request processing chain for handing druid data requests.
reset() - Method in enum com.yahoo.bard.webservice.config.BardFeatureFlag
 
reset() - Method in enum com.yahoo.bard.webservice.config.CacheFeatureFlag
 
reset() - Method in interface com.yahoo.bard.webservice.config.FeatureFlag
Restores the feature flag to the startup state (if supported by the underlying conf mechanism).
resetAll() - Static method in enum com.yahoo.bard.webservice.config.CacheFeatureFlag
Because these fields share a common value when that value is updated, clear all the cached values.
resetProperty(String, String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Remove property from the user-defined runtime configuration.
resolve(Collection<PhysicalTable>, QueryPlanningConstraint) - Method in class com.yahoo.bard.webservice.table.resolver.BasePhysicalTableResolver
 
resolve(Collection<PhysicalTable>, QueryPlanningConstraint) - Method in interface com.yahoo.bard.webservice.table.resolver.PhysicalTableResolver
Choose the best fit Physical Table from a table group.
resolveAcceptingGrain(DataApiRequest, TemplateDruidQuery) - Method in class com.yahoo.bard.webservice.table.resolver.RequestQueryGranularityResolver
Get the a granularity which must be satisfied by any answering table granularity for this request.
resolver - Variable in class com.yahoo.bard.webservice.data.DruidQueryBuilder
 
resource - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
resource - Variable in class com.yahoo.bard.webservice.logging.blocks.DimensionRequest
 
resource - Variable in class com.yahoo.bard.webservice.logging.blocks.FeatureFlagRequest
 
resource - Variable in class com.yahoo.bard.webservice.logging.blocks.JobRequest
 
resource - Variable in class com.yahoo.bard.webservice.logging.blocks.MetricRequest
 
resource - Variable in class com.yahoo.bard.webservice.logging.blocks.SliceRequest
 
resource - Variable in class com.yahoo.bard.webservice.logging.blocks.TableRequest
 
RESOURCE_LOADER_PREFIX - Static variable in class com.yahoo.bard.webservice.config.ConfigResourceLoader
 
ResourceConfig - Class in com.yahoo.bard.webservice.application
The resource configuration for the bard web applications, especially core filters.
ResourceConfig() - Constructor for class com.yahoo.bard.webservice.application.ResourceConfig
Constructor.
ResourceDictionaries - Class in com.yahoo.bard.webservice.data.config
Hold the resource dictionaries.
ResourceDictionaries() - Constructor for class com.yahoo.bard.webservice.data.config.ResourceDictionaries
Constructor.
Response - Class in com.yahoo.bard.webservice.logging.blocks
Corresponds mainly to the responding part of a request served by the DataServlet.
Response(int, int, int) - Constructor for class com.yahoo.bard.webservice.logging.blocks.Response
Constructor.
RESPONSE_CONTEXT_KEY - Static variable in class com.yahoo.bard.webservice.data.PreResponseSerializationProxy
 
RESPONSE_WORKFLOW_TIMER - Static variable in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
RESPONSE_WORKFLOW_TIMER - Static variable in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
ResponseCode - Enum in com.yahoo.bard.webservice.web
Additional HTTP Status Codes not defined in javax.ws.rs.core.Response.Status.
responseContext - Variable in class com.yahoo.bard.webservice.web.responseprocessors.MappingResponseProcessor
 
ResponseContext - Class in com.yahoo.bard.webservice.web.responseprocessors
A container to hold context information associated with a response.
ResponseContext() - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.ResponseContext
Constructor.
ResponseContext(LinkedHashMap<Dimension, LinkedHashSet<DimensionField>>) - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.ResponseContext
Build a ResponseContext using dimensionToDimensionFieldMap.
ResponseContextKeys - Enum in com.yahoo.bard.webservice.web.responseprocessors
Enumerates the list of keys expected to be found in the ResponseContext.
ResponseCorsFilter - Class in com.yahoo.bard.webservice.web.filters
The filter which supports CORS security checking.
ResponseCorsFilter() - Constructor for class com.yahoo.bard.webservice.web.filters.ResponseCorsFilter
 
ResponseData - Class in com.yahoo.bard.webservice.web
ResponseData class.
ResponseData(ResultSet, LinkedHashSet<String>, LinkedHashMap<Dimension, LinkedHashSet<DimensionField>>, SimplifiedIntervalList, SimplifiedIntervalList, Pagination, Map<String, URI>) - Constructor for class com.yahoo.bard.webservice.web.ResponseData
Constructor.
ResponseData(ResultSet, DataApiRequest, SimplifiedIntervalList, SimplifiedIntervalList, Pagination, Map<String, URI>) - Constructor for class com.yahoo.bard.webservice.web.ResponseData
Deprecated.
All the values needed to build a Response should be passed explicitly instead of relying on the DataApiRequest
responseEmitter - Variable in class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessor
 
ResponseException - Exception in com.yahoo.bard.webservice.async
Custom helper class to wrap Error Response object attributes in an Exception type.
ResponseException(int, String, String, DruidQuery<?>, Throwable, ObjectWriter) - Constructor for exception com.yahoo.bard.webservice.async.ResponseException
Class constructor with all the parameters to prepare the error response, plus a writer to serialize the Druid query.
ResponseException(Response.StatusType, DruidAggregationQuery<?>, Throwable, ObjectWriter) - Constructor for exception com.yahoo.bard.webservice.async.ResponseException
Class constructor with throwable, other parameters and a mapper for serializing the druid query.
ResponseException(Response.StatusType, DruidAggregationQuery<?>, Throwable) - Constructor for exception com.yahoo.bard.webservice.async.ResponseException
Deprecated.
In order to ensure correct serialization of the Druid Query, an ObjectWriter with all appropriate configuration should be passed in to the constructor
ResponseException(int, String, String, DruidQuery<?>) - Constructor for exception com.yahoo.bard.webservice.async.ResponseException
Deprecated.
In order to ensure correct serialization of the Druid Query, an ObjectWriter with all appropriate configuration should be passed in to the constructor
ResponseException(int, String, String, DruidQuery<?>, Throwable) - Constructor for exception com.yahoo.bard.webservice.async.ResponseException
Deprecated.
In order to ensure correct serialization of the Druid Query, an ObjectWriter with all appropriate configuration should be passed in to the constructor
ResponseFormat - Class in com.yahoo.bard.webservice.web.util
A utility class for sharing Response logic between metadata and data endpoints.
ResponseFormat() - Constructor for class com.yahoo.bard.webservice.web.util.ResponseFormat
 
ResponseFormatResolver - Interface in com.yahoo.bard.webservice.web
A functional interface which allows the logic of resolving response format customizable.
ResponseFormatType - Enum in com.yahoo.bard.webservice.web
Response format type.
ResponseProcessor - Interface in com.yahoo.bard.webservice.web.responseprocessors
Response processing can result in failure or error or on success will receive a JSON document representing the result set for the query.
ResponseProcessorFactory - Interface in com.yahoo.bard.webservice.web.responseprocessors
A ResponseProcessor relies on things that are directly constructed at request time (i.e.
ResponseStream - Interface in com.yahoo.bard.webservice.web
An interface for classes that transform response data to a format representation (e.g.
responseWriter - Variable in class com.yahoo.bard.webservice.data.HttpResponseMaker
 
ResponseWriter - Interface in com.yahoo.bard.webservice.web
The interface for objects that write fully-processed ResultSets back to the user.
ResponseWriterSelector - Interface in com.yahoo.bard.webservice.web
Typically, a Fili program's response writing infrastructure will consist of a collection of unrelated ResponseWriters each responsible for serializing the ResultSet into a specific format, and a single ResponseWriter that chooses the correct one based on the current state of the DataApiRequest.
restore(RequestLog) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Overwrite current thread's request log context.
Result - Class in com.yahoo.bard.webservice.data
A single row of results.
Result(Map<DimensionColumn, DimensionRow>, Map<MetricColumn, Object>, DateTime) - Constructor for class com.yahoo.bard.webservice.data.Result
Constructor.
RESULT_SET_KEY - Static variable in class com.yahoo.bard.webservice.data.PreResponseSerializationProxy
 
RESULTS_KEY - Static variable in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
ResultSerializationProxy - Class in com.yahoo.bard.webservice.data
Simplified version of Result class for json format serialization.
ResultSerializationProxy(Result) - Constructor for class com.yahoo.bard.webservice.data.ResultSerializationProxy
Constructor.
ResultSet - Class in com.yahoo.bard.webservice.data
ResultSet.
ResultSet(ResultSetSchema, List<Result>) - Constructor for class com.yahoo.bard.webservice.data.ResultSet
Constructor.
resultSet - Variable in class com.yahoo.bard.webservice.web.ResponseData
 
ResultSetMapper - Class in com.yahoo.bard.webservice.data.metric.mappers
ResultSetMapper is an abstract class for walking a result set.
ResultSetMapper() - Constructor for class com.yahoo.bard.webservice.data.metric.mappers.ResultSetMapper
 
ResultSetResponseProcessor - Class in com.yahoo.bard.webservice.web.responseprocessors
Callback handler for JSON to be processed into result sets.
ResultSetResponseProcessor(DataApiRequest, Subject<PreResponse, PreResponse>, DruidResponseParser, ObjectMappersSuite, HttpResponseMaker) - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessor
Constructor.
ResultSetResponseProcessorFactory - Class in com.yahoo.bard.webservice.web.responseprocessors
Builds the default Druid response processor: ResultSetResponseProcessor.
ResultSetResponseProcessorFactory() - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.ResultSetResponseProcessorFactory
 
ResultSetSchema - Class in com.yahoo.bard.webservice.data
The schema for a result set.
ResultSetSchema(Granularity, Iterable<Column>) - Constructor for class com.yahoo.bard.webservice.data.ResultSetSchema
Constructor.
ResultSetSerializationProxy - Class in com.yahoo.bard.webservice.data
Simplified version of ResultSet class for json format serialization.
ResultSetSerializationProxy(ResultSet) - Constructor for class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
Constructor.
retrieve(Class) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Retrieve logging information in the logging context.
retrieveAll() - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Returns a map of all the LogInfo blocks currently registered with this thread's RequestLog.
right(R) - Static method in class com.yahoo.bard.webservice.util.Either
Constructs an Either containing a right value.
RoleBasedAuthFilter - Class in com.yahoo.bard.webservice.web.filters
RoleBasedAuthFilter - Filter servlet calls based on the user Role.
RoleBasedAuthFilter(ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.filters.RoleBasedAuthFilter
Constructor.
RoleBasedRoutingRequestMapper<T extends ApiRequest> - Class in com.yahoo.bard.webservice.web.security
A RequestMapper that delegates to the first request mapper in a list which the user has a supporting role for.
RoleBasedRoutingRequestMapper(ResourceDictionaries, LinkedHashMap<String, RequestMapper<T>>, RequestMapper<T>) - Constructor for class com.yahoo.bard.webservice.web.security.RoleBasedRoutingRequestMapper
Constructor.
RoleDimensionApiFilterRequestMapper - Class in com.yahoo.bard.webservice.web.security
A request mapper that ensures that a user has at least one relevant role on a dimension and applies access filters based on roles for that user.
RoleDimensionApiFilterRequestMapper(ResourceDictionaries, Dimension, Map<String, Set<ApiFilter>>, RequestMapper<DataApiRequest>) - Constructor for class com.yahoo.bard.webservice.web.security.RoleDimensionApiFilterRequestMapper
Constructor.
roundCeiling(DateTime) - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
Round the DateTime to the "front edge" (ie.
roundFloor(DateTime) - Method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
 
roundFloor(DateTime) - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
Given a date time find the first instant at or before that date time which starts a time grain.
roundFloor(DateTime) - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
Use the inner grain's round function to round a DateTime, but use the bucketing of this grain's timezone rather than the one from the date time itself.
ROW_KEY_SUFFIX - Static variable in class com.yahoo.bard.webservice.util.DimensionStoreKeyUtils
 
RowLimitReachedException - Exception in com.yahoo.bard.webservice.web
A request-related or resources-related limit has been reached.
RowLimitReachedException() - Constructor for exception com.yahoo.bard.webservice.web.RowLimitReachedException
Constructor.
RowLimitReachedException(String) - Constructor for exception com.yahoo.bard.webservice.web.RowLimitReachedException
Constructor.
RowLimitReachedException(String, Throwable) - Constructor for exception com.yahoo.bard.webservice.web.RowLimitReachedException
Constructor.
RowNumMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to provide row nums in result set processing.
RowNumMaker(MetricDictionary) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.RowNumMaker
Constructor.
RowNumMapper - Class in com.yahoo.bard.webservice.data.metric.mappers
Mapper to add row numbers to each result in a result set.
RowNumMapper() - Constructor for class com.yahoo.bard.webservice.data.metric.mappers.RowNumMapper
 
run() - Method in class com.yahoo.bard.webservice.application.DimensionValueLoadTask
 
run() - Method in class com.yahoo.bard.webservice.application.LoadTask
 
run() - Method in class com.yahoo.bard.webservice.application.SchedulableTask
 
run() - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataLoadTask
 
run() - Method in class com.yahoo.bard.webservice.metadata.RegisteredLookupMetadataLoadTask
 

S

satisfiedBy(Granularity) - Method in class com.yahoo.bard.webservice.data.time.AllGranularity
Any granularity can be rolled up into all.
satisfiedBy(TimeGrain) - Method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
 
satisfiedBy(Granularity) - Method in interface com.yahoo.bard.webservice.data.time.Granularity
Determine if this granularity can be fulfilled by an aggregate of another granularity.
satisfiedBy(TimeGrain) - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
True if the argument grain can be used to build this grain.
satisfiedBy(Granularity) - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
 
satisfiedBy(TimeGrain) - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
satisfies(Granularity) - Method in interface com.yahoo.bard.webservice.data.time.Granularity
Determine the reciprocal relationship to satisfiedBy, that this granularity fulfils an aggregate of another granularity.
save(JobRow) - Method in interface com.yahoo.bard.webservice.async.jobs.stores.ApiJobStore
Returns a cold Observable that emits the JobRow that has been stored.
save(JobRow) - Method in class com.yahoo.bard.webservice.async.jobs.stores.HashJobStore
 
save(JobRow) - Method in class com.yahoo.bard.webservice.async.jobs.stores.NoOpApiJobStore
 
save(String, PreResponse) - Method in class com.yahoo.bard.webservice.async.preresponses.stores.NoOpPreResponseStore
 
save(String, PreResponse) - Method in interface com.yahoo.bard.webservice.async.preresponses.stores.PreResponseStore
Saves the specified PreResponse in the store.
ScanSearchProvider - Class in com.yahoo.bard.webservice.data.dimension.impl
Search provider using scan on dimension rows.
ScanSearchProvider() - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
Constructor.
ScanSearchProviderManager - Class in com.yahoo.bard.webservice.data.dimension.impl
Scan search provider instances factory.
ScanSearchProviderManager() - Constructor for class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProviderManager
 
SchedulableTask<V> - Class in com.yahoo.bard.webservice.application
Defines a task that is scheduled to run at a given time, periodically or in a one-off fashion.
SchedulableTask(Runnable, V, RunnableScheduledFuture<V>) - Constructor for class com.yahoo.bard.webservice.application.SchedulableTask
Creates a task that can be scheduled with TaskScheduler.
SchedulableTask(Callable<V>, RunnableScheduledFuture<V>) - Constructor for class com.yahoo.bard.webservice.application.SchedulableTask
Creates a task that can be scheduled with TaskScheduler.
scheduleLoader(LoadTask<?>) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Schedule a loadTask task.
Schema - Interface in com.yahoo.bard.webservice.table
An interface describing a table or table-like entity composed of sets of columns.
SCHEMA_DIM_COLUMNS - Static variable in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
SCHEMA_GRANULARITY - Static variable in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
SCHEMA_KEY - Static variable in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
SCHEMA_METRIC_COLUMNS - Static variable in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
SCHEMA_METRIC_COLUMNS_TYPE - Static variable in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
SCHEMA_TIMEZONE - Static variable in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
SchemaPhysicalTableMatcher - Class in com.yahoo.bard.webservice.table.resolver
Use the granularity and columns of a query to determine whether or not tables can satisfy this query.
SchemaPhysicalTableMatcher(QueryPlanningConstraint) - Constructor for class com.yahoo.bard.webservice.table.resolver.SchemaPhysicalTableMatcher
Constructor saves metrics, dimensions, coarsest time grain, and logical table name (for logging).
Scope<S,K,V,T extends Scope<S,K,V,T>> - Interface in com.yahoo.bard.webservice.util
A Scope represents a tree of delegating maps.
ScopeMap<S,K,V,T extends ScopeMap<S,K,V,T>> - Class in com.yahoo.bard.webservice.util
ScopeMap implements Scope using a factory method to create child scopes when requested by getScope()
ScopeMap() - Constructor for class com.yahoo.bard.webservice.util.ScopeMap
Build a scope with no parent scope and empty children.
ScopeMap(Map<K, V>) - Constructor for class com.yahoo.bard.webservice.util.ScopeMap
Build a scope with a parent scope.
searchableHeaders - Variable in class com.yahoo.bard.webservice.web.handlers.RequestContext
 
searchDimensions - Variable in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
SearchFilter - Class in com.yahoo.bard.webservice.druid.model.filter
Filter for a search.
SearchFilter(Dimension, SearchFilter.QueryType, String) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.SearchFilter
Constructor.
SearchFilter.QueryType - Enum in com.yahoo.bard.webservice.druid.model.filter
Query type for the search.
SearchProvider - Interface in com.yahoo.bard.webservice.data.dimension
Provides the capability to search through dimension metadata.
SearchProviderHealthCheck - Class in com.yahoo.bard.webservice.application.healthchecks
A health check to test search provider health status.
SearchProviderHealthCheck(SearchProvider) - Constructor for class com.yahoo.bard.webservice.application.healthchecks.SearchProviderHealthCheck
Constructor.
SearchQuerySpec - Class in com.yahoo.bard.webservice.druid.model.query
Baseclass for specifying SearchQuerySpec for DruidSearchQuery.
SearchQuerySpec(SearchQueryType) - Constructor for class com.yahoo.bard.webservice.druid.model.query.SearchQuerySpec
Constructor.
SearchQueryType - Interface in com.yahoo.bard.webservice.druid.model.query
An interface for DruidSearchQuery query types.
SearchSortDirection - Interface in com.yahoo.bard.webservice.druid.model.orderby
Interface for DruidSearchQuery sort direction.
SECURITY_SIGNUP_MESSAGE_KEY - Static variable in class com.yahoo.bard.webservice.web.security.RoleDimensionApiFilterRequestMapper
 
SecurityErrorMessageFormat - Enum in com.yahoo.bard.webservice.web.security
Message formats for security module errors.
SEG_LOADER_HC_LAST_RUN_PERIOD_MILLIS - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
SegmentInfo - Class in com.yahoo.bard.webservice.metadata
A class that holds the useful information of a partition of a druid segment in bard.
SegmentInfo(DataSegment) - Constructor for class com.yahoo.bard.webservice.metadata.SegmentInfo
Given a druid data segment constructs an object to hold the information of this partition.
SegmentIntervalsHashIdGenerator - Class in com.yahoo.bard.webservice.metadata
An implementation of the QuerySigningService that generates segment id for requested interval.
SegmentIntervalsHashIdGenerator(PhysicalTableDictionary, DataSourceMetadataService, Map<Class, RequestedIntervalsFunction>) - Constructor for class com.yahoo.bard.webservice.metadata.SegmentIntervalsHashIdGenerator
Deprecated.
phyiscalTableDictionary is not used
SegmentIntervalsHashIdGenerator(DataSourceMetadataService, Map<Class, RequestedIntervalsFunction>) - Constructor for class com.yahoo.bard.webservice.metadata.SegmentIntervalsHashIdGenerator
Build a SegmentIntervalsHashIdGenerator that generates a segmentId using the provided signingFunctions.
SegmentIntervalsHashIdGenerator(PhysicalTableDictionary, DataSourceMetadataService) - Constructor for class com.yahoo.bard.webservice.metadata.SegmentIntervalsHashIdGenerator
Deprecated.
phyiscalTableDictionary is not used
SegmentIntervalsHashIdGenerator(DataSourceMetadataService) - Constructor for class com.yahoo.bard.webservice.metadata.SegmentIntervalsHashIdGenerator
Build a SegmentIntervalsHashIdGenerator that uses the raw simplified intervals of a druidAggregationQuery to create a segmentId.
SegmentMetadata - Class in com.yahoo.bard.webservice.metadata
The segment metadata from a particular physical table/druid data source.
SegmentMetadata(Map<String, Map<String, List<String>>>) - Constructor for class com.yahoo.bard.webservice.metadata.SegmentMetadata
Create a map of dimension and metric intervals from a map of intervals to dimensions and metrics.
SegmentMetadataQuery - Class in com.yahoo.bard.webservice.druid.model.query
Druid segment metadata query.
SegmentMetadataQuery(DataSource, Collection<Interval>, QueryContext, boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.query.SegmentMetadataQuery
Constructor.
SegmentMetadataQuery(DataSource, Collection<Interval>) - Constructor for class com.yahoo.bard.webservice.druid.model.query.SegmentMetadataQuery
Constructor.
select(ApiRequest) - Method in class com.yahoo.bard.webservice.web.FiliResponseWriterSelector
Selects a ResponseWriter given the format type from request.
select(DruidAggregationQuery<?>, DataApiRequest, RequestContext) - Method in class com.yahoo.bard.webservice.web.handlers.DefaultWebServiceHandlerSelector
 
select(DruidAggregationQuery<?>, DataApiRequest, RequestContext) - Method in interface com.yahoo.bard.webservice.web.handlers.WebServiceHandlerSelector
Select which web service to use, based on the request information.
select(ApiRequest) - Method in interface com.yahoo.bard.webservice.web.ResponseWriterSelector
Select ResponseWriter given certain type of format from DataApiRequest.
SelectorFilter - Class in com.yahoo.bard.webservice.druid.model.filter
Filter for exactly matching a column and value in druid.
SelectorFilter(Dimension, String) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.SelectorFilter
Constructor.
SelectorFilter(Dimension, String, ExtractionFunction) - Constructor for class com.yahoo.bard.webservice.druid.model.filter.SelectorFilter
Constructor.
sendRequest(SuccessCallback, HttpErrorCallback, FailureCallback, BoundRequestBuilder, String, AtomicLong) - Method in class com.yahoo.bard.webservice.druid.client.impl.AsyncDruidWebServiceImpl
Serializes the provided query and invokes a request on the druid broker.
sequenceNumber - Variable in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
SerializationException - Exception in com.yahoo.bard.webservice.data
Exception during serialization.
SerializationException(String) - Constructor for exception com.yahoo.bard.webservice.data.SerializationException
Constructor.
SerializationException(Throwable) - Constructor for exception com.yahoo.bard.webservice.data.SerializationException
Constructor.
SerializationException(String, Throwable) - Constructor for exception com.yahoo.bard.webservice.data.SerializationException
Constructor.
serialize(Dimension, JsonGenerator, SerializerProvider) - Method in class com.yahoo.bard.webservice.druid.serializers.DimensionToDefaultDimensionSpec
 
serialize(Dimension, JsonGenerator, SerializerProvider) - Method in class com.yahoo.bard.webservice.druid.serializers.DimensionToNameSerializer
 
serialize(HasDruidName, JsonGenerator, SerializerProvider) - Method in class com.yahoo.bard.webservice.druid.serializers.HasDruidNameSerializer
 
serialize(ExtractionFunctionDimension, JsonGenerator, SerializerProvider) - Method in class com.yahoo.bard.webservice.druid.serializers.LookupDimensionToDimensionSpec
 
SerializerUtil - Class in com.yahoo.bard.webservice.druid.serializers
Utility functions for druid serializers.
SerializerUtil() - Constructor for class com.yahoo.bard.webservice.druid.serializers.SerializerUtil
 
serializeWithType(HasDruidName, JsonGenerator, SerializerProvider, TypeSerializer) - Method in class com.yahoo.bard.webservice.druid.serializers.HasDruidNameSerializer
Default implementation will write type prefix, call regular serialization method (since assumption is that value itself does not need JSON Array or Object start/end markers), and then write type suffix.
serialVersionUID - Static variable in interface com.yahoo.bard.webservice.util.Pagination
 
set(String, T) - Method in interface com.yahoo.bard.webservice.data.cache.DataCache
Put a value on a key in a data cache.
set(String, T) - Method in class com.yahoo.bard.webservice.data.cache.HashDataCache
 
set(String, T) - Method in class com.yahoo.bard.webservice.data.cache.MemDataCache
 
set(String, T, V) - Method in class com.yahoo.bard.webservice.data.cache.MemTupleDataCache
 
set(String, T) - Method in class com.yahoo.bard.webservice.data.cache.StubDataCache
 
set(K, M, V) - Method in interface com.yahoo.bard.webservice.data.cache.TupleDataCache
Given a key, put a complete data entry in the data cache.
setAvailability(Availability) - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
Deprecated.
Should avoid this method and refine testing strategy to remove this method
setDateTime(int, SqlDatePartFunction, MutableDateTime) - Method in class com.yahoo.bard.webservice.sql.helper.SqlTimeConverter
Sets the correct part of a DateTime corresponding to a SqlDatePartFunction.
setDimension(Dimension) - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
 
setDimension(Dimension) - Method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
 
setDimension(Dimension) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
setDimension(Dimension) - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Setter for dimension.
setErrorCallback(HttpErrorCallback) - Method in interface com.yahoo.bard.webservice.application.DimensionValueLoader
Set a callback if an error occurs while querying.
setErrorCallback(HttpErrorCallback) - Method in class com.yahoo.bard.webservice.application.DruidDimensionValueLoader
 
setErrorCallback(HttpErrorCallback) - Method in class com.yahoo.bard.webservice.application.SqlDimensionValueLoader
 
setFailureCallback(FailureCallback) - Method in interface com.yahoo.bard.webservice.application.DimensionValueLoader
Set a callback if an exception occurs while querying.
setFailureCallback(FailureCallback) - Method in class com.yahoo.bard.webservice.application.DruidDimensionValueLoader
 
setFailureCallback(FailureCallback) - Method in class com.yahoo.bard.webservice.application.SqlDimensionValueLoader
 
setKeyValueStore(KeyValueStore) - Method in class com.yahoo.bard.webservice.data.dimension.impl.LuceneSearchProvider
 
setKeyValueStore(KeyValueStore) - Method in class com.yahoo.bard.webservice.data.dimension.impl.NoOpSearchProvider
 
setKeyValueStore(KeyValueStore) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
setKeyValueStore(KeyValueStore) - Method in interface com.yahoo.bard.webservice.data.dimension.SearchProvider
Setter for store.
setLastUpdated(DateTime) - Method in interface com.yahoo.bard.webservice.data.dimension.Dimension
Setter for lastUpdated.
setLastUpdated(DateTime) - Method in class com.yahoo.bard.webservice.data.dimension.DimensionUpdateDate
 
setLastUpdated(DateTime) - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
setLookupTiers(Set<String>) - Method in class com.yahoo.bard.webservice.metadata.RegisteredLookupMetadataLoadTask
Updates list of configured lookup tiers.
setMaxTime(String) - Method in class com.yahoo.bard.webservice.metadata.TimeBoundaryResponse
 
setMerge(Set<T>, Set<T>) - Static method in class com.yahoo.bard.webservice.util.StreamUtils
Merge two sets without modifying either.
setMinTime(String) - Method in class com.yahoo.bard.webservice.metadata.TimeBoundaryResponse
 
setOn(Boolean) - Method in enum com.yahoo.bard.webservice.config.BardFeatureFlag
 
setOn(Boolean) - Method in enum com.yahoo.bard.webservice.config.CacheFeatureFlag
 
setOn(Boolean) - Method in interface com.yahoo.bard.webservice.config.FeatureFlag
Sets the status of the feature flag.
setProperty(String, String) - Method in interface com.yahoo.bard.webservice.config.SystemConfig
Set property value for a key.
setTimeGrain(TimeGrain) - Method in class com.yahoo.wiki.webservice.data.config.auto.TableConfig
Sets TimeGrain of the datasource.
setupDataSourceMetaData(HealthCheckRegistry, DataSourceMetadataLoadTask) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Schedule a datasource metadata loader and register its health check.
setupDruidDimensionsLoader(HealthCheckRegistry, DimensionValueLoadTask) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Schedule DimensionValueLoadTask and register its health check.
setupGauges() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Register global gauges.
setupHealthChecks(HealthCheckRegistry, DimensionDictionary) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Register required core health checks.
setupLookUpMetadataLoader(HealthCheckRegistry, RegisteredLookupMetadataLoadTask) - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Schedule a lookup metadata loader and register its health check.
ShardSpecMixIn - Class in com.yahoo.bard.webservice.druid.model.metadata
Defines a mix-in that is used to deserialize shard spec from json.
ShardSpecMixIn() - Constructor for class com.yahoo.bard.webservice.druid.model.metadata.ShardSpecMixIn
 
shutdown() - Method in class com.yahoo.bard.webservice.application.TaskScheduler
 
shutdownLoaderScheduler() - Method in class com.yahoo.bard.webservice.application.AbstractBinderFactory
Shutdown the scheduler for loader tasks.
shutdownNow() - Method in class com.yahoo.bard.webservice.application.TaskScheduler
 
SimpleBroadcastChannel<T> - Class in com.yahoo.bard.webservice.async.broadcastchannels
A simple implementation of BroadcastChannel backed by a Subject intended for use in systems with a single Bard instance.
SimpleBroadcastChannel(Subject<T, T>) - Constructor for class com.yahoo.bard.webservice.async.broadcastchannels.SimpleBroadcastChannel
Construct a SimpleBroadcastChannel using a Hot Observable.
SimplifiedIntervalList - Class in com.yahoo.bard.webservice.util
A simplified interval list is a list of intervals, ordered by time, expressed in as few intervals as possible (i.e.
SimplifiedIntervalList() - Constructor for class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Constructor.
SimplifiedIntervalList(Collection<Interval>) - Constructor for class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Simplify then build a list.
SimplifiedIntervalList(SimplifiedIntervalList) - Constructor for class com.yahoo.bard.webservice.util.SimplifiedIntervalList
If the intervals are already simplified, simply copy the list.
SimplifiedIntervalList.IsSubinterval - Class in com.yahoo.bard.webservice.util
A predicate for testing whether the test interval is a complete subinterval of part of the supply of intervals.
SimplifiedIntervalList.SkippingIntervalPredicate - Class in com.yahoo.bard.webservice.util
A predicate to scan a Simplified Interval List using an iterator and a test predicate.
simplifyIntervals(Collection<Interval>...) - Static method in class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Takes one or more lists of intervals, and combines them into a single, sorted list with the minimum number of intervals needed to capture exactly the same instants as the original intervals.
SingleDataSourcePhysicalTable - Class in com.yahoo.bard.webservice.table
A Physical Table that should be backed by a Metadata-based Availability that has only a single data source.
SingleDataSourcePhysicalTable(TableName, ZonedTimeGrain, Iterable<Column>, Map<String, String>, BaseMetadataAvailability) - Constructor for class com.yahoo.bard.webservice.table.SingleDataSourcePhysicalTable
Constructor.
SinglePagePagination<T> - Class in com.yahoo.bard.webservice.util
Pagination class that contains only one page of data.
SinglePagePagination(List<T>, PaginationParameters, int) - Constructor for class com.yahoo.bard.webservice.util.SinglePagePagination
Constructor.
size() - Method in class com.yahoo.bard.webservice.util.DelegatingMap
 
SketchAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Base type for sketch aggregations.
SketchAggregation(String, String, int) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.SketchAggregation
Constructor.
sketchConverter - Static variable in class com.yahoo.bard.webservice.druid.util.FieldConverterSupplier
 
SketchCountAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Deprecated.
To consider the latest version of sketch Library. This class is replaced by ThetaSketchAggregation
SketchCountAggregation(String, String, int) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.SketchCountAggregation
Deprecated.
Constructor.
SketchCountMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Deprecated.
To consider the latest version of sketch Library. This class is replaced by ThetaSketchMaker
SketchCountMaker(MetricDictionary, int) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.SketchCountMaker
Deprecated.
Constructor.
SketchEstimatePostAggregation - Class in com.yahoo.bard.webservice.druid.model.postaggregation
Deprecated.
To consider the latest version of sketch Library. This class is replaced by ThetaSketchEstimatePostAggregation class
SketchEstimatePostAggregation(String, PostAggregation) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.SketchEstimatePostAggregation
Deprecated.
Constructor accepting fields as list of field accessor post aggs.
SketchFieldConverter - Class in com.yahoo.bard.webservice.druid.util
Deprecated.
To consider the latest version of sketch Library. This class is replaced by ThetaSketchFieldConverter class
SketchFieldConverter() - Constructor for class com.yahoo.bard.webservice.druid.util.SketchFieldConverter
Deprecated.
 
SketchMergeAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Deprecated.
To consider the latest version of sketch Library. This class is replaced by ThetaSketchAggregation
SketchMergeAggregation(String, String, int) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.SketchMergeAggregation
Deprecated.
Constructor.
SketchRoundUpMapper - Class in com.yahoo.bard.webservice.data.metric.mappers
Mapper to round floating point values to their ceiling.
SketchRoundUpMapper(FieldName) - Constructor for class com.yahoo.bard.webservice.data.metric.mappers.SketchRoundUpMapper
The column name to round.
SketchRoundUpMapper(String) - Constructor for class com.yahoo.bard.webservice.data.metric.mappers.SketchRoundUpMapper
The column name to round.
SketchSetOperationHelper - Class in com.yahoo.bard.webservice.data.config.metric.makers
Deprecated.
To consider the latest version of sketch Library. This class is replaced by ThetaSketchSetOperationHelper
SketchSetOperationHelper() - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.SketchSetOperationHelper
Deprecated.
 
SketchSetOperationMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Deprecated.
To consider the latest version of sketch Library. This class is replaced by ThetaSketchSetOperationMaker
SketchSetOperationMaker(MetricDictionary, SketchSetOperationPostAggFunction) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.SketchSetOperationMaker
Deprecated.
Constructor.
SketchSetOperationPostAggFunction - Enum in com.yahoo.bard.webservice.druid.model.postaggregation
Enumeration of the possible sketch set post aggregation operations.
SketchSetOperationPostAggregation - Class in com.yahoo.bard.webservice.druid.model.postaggregation
Deprecated.
To consider the latest version of sketch Library. This class is replaced by ThetaSketchSetOperationPostAggregation class
SketchSetOperationPostAggregation(String, SketchSetOperationPostAggFunction, List<PostAggregation>, Integer) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
Constructor accepting a list of post aggregations as fields as well as an explicit sketch size.
SketchSetOperationPostAggregation(String, SketchSetOperationPostAggFunction, List<PostAggregation>) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
Constructor accepting a list of post aggregations as fields while leaving the sketch size of the resulting postaggregation undefined.
skipCache - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
SkippingIntervalPredicate(SimplifiedIntervalList, BiPredicate<Interval, Interval>, boolean) - Constructor for class com.yahoo.bard.webservice.util.SimplifiedIntervalList.SkippingIntervalPredicate
Constructor to build a predicate that applies an arbitrary predicate to not-before intervals from the iterator.
skipWeightCheckQuery(DruidAggregationQuery<?>) - Method in class com.yahoo.bard.webservice.web.util.QueryWeightUtil
Indicate if the weight check query can be skipped based on heuristics.
slice - Variable in class com.yahoo.bard.webservice.logging.blocks.SliceRequest
 
sliceIntervals(Interval, TimeGrain) - Static method in class com.yahoo.bard.webservice.util.DateTimeUtils
Slices the intervals into smaller intervals of the timeGrain duration.
SliceRequest - Class in com.yahoo.bard.webservice.logging.blocks
Main log of a request served by the SlicesServlet.
SliceRequest(String) - Constructor for class com.yahoo.bard.webservice.logging.blocks.SliceRequest
Constructor.
SlicesApiRequest - Interface in com.yahoo.bard.webservice.web.apirequest
Slices API Request.
SlicesApiRequestImpl - Class in com.yahoo.bard.webservice.web.apirequest
Slices API Request Implementation binds, validates, and models the parts of a request to the Slices endpoint.
SlicesApiRequestImpl(String, String, String, String, PhysicalTableDictionary, DataSourceMetadataService, UriInfo) - Constructor for class com.yahoo.bard.webservice.web.apirequest.SlicesApiRequestImpl
Parses the API request URL and generates the Api Request object.
SlicesServlet - Class in com.yahoo.bard.webservice.web.endpoints
SlicesServlet supports discovery of performance slices (aka webService PhysicalTables or druid dataSources) and their current data availability intervals.
SlicesServlet(PhysicalTableDictionary, RequestMapper, DataSourceMetadataService, ObjectMappersSuite, ResponseFormatResolver) - Constructor for class com.yahoo.bard.webservice.web.endpoints.SlicesServlet
Constructor.
sort - Variable in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
SortDirection - Enum in com.yahoo.bard.webservice.druid.model.orderby
Enum for sort direction.
split(String) - Static method in class com.yahoo.bard.webservice.util.FilterTokenizer
Split a string into tokens based on CSV rules.
SPLIT_QUERIES - Static variable in class com.yahoo.bard.webservice.web.handlers.SplitQueryRequestHandler
 
SplitQueryRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Request handler breaks a query up into smaller time grain queries for parallel processing.
SplitQueryRequestHandler(DataRequestHandler) - Constructor for class com.yahoo.bard.webservice.web.handlers.SplitQueryRequestHandler
Build a Split Query Request Handler.
SplitQueryResponseProcessor - Class in com.yahoo.bard.webservice.web.responseprocessors
This response processor receives a list of expected intervals.
SplitQueryResponseProcessor(ResponseProcessor, DataApiRequest, DruidAggregationQuery<?>, Map<Interval, AtomicInteger>, RequestLog) - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.SplitQueryResponseProcessor
Constructor.
SPLITS - Static variable in class com.yahoo.bard.webservice.web.handlers.SplitQueryRequestHandler
 
SqlAggregation - Class in com.yahoo.bard.webservice.sql.aggregation
A sql aggregation value object containing all the necessary information to build a sql aggregation.
SqlAggregation(String, SqlAggFunction) - Constructor for class com.yahoo.bard.webservice.sql.aggregation.SqlAggregation
Constructor.
SqlAggregationQuery - Class in com.yahoo.bard.webservice.sql
Wrapper around an DruidAggregationQuery which always reports itself as a DefaultQueryType.GROUP_BY.
SqlAggregationQuery(DruidAggregationQuery<?>) - Constructor for class com.yahoo.bard.webservice.sql.SqlAggregationQuery
Wraps a query as a GroupBy Query.
SqlAggregationType - Interface in com.yahoo.bard.webservice.sql.aggregation
A type which can build a sql aggregation given a supported druid aggregation.
SqlBackedClient - Interface in com.yahoo.bard.webservice.sql
Allows queries to be executed on a sql backend from a DruidQuery.
SqlDimensionValueLoader - Class in com.yahoo.bard.webservice.application
The SqlDimensionValueLoader sends values to the configured sql backend to load dimension values into the dimension cache.
SqlDimensionValueLoader(PhysicalTableDictionary, DimensionDictionary, List<String>, SqlBackedClient) - Constructor for class com.yahoo.bard.webservice.application.SqlDimensionValueLoader
SqlDimensionValueLoader fetches data from Sql and adds it to the dimension cache.
SqlPhysicalTable - Class in com.yahoo.bard.webservice.table
An implementation of BasePhysicalTable specific for Sql Backed datasources.
SqlPhysicalTable(TableName, ZonedTimeGrain, Iterable<Column>, Map<String, String>, Availability, String, String) - Constructor for class com.yahoo.bard.webservice.table.SqlPhysicalTable
Create a physical table.
SqlRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
A handler for queries made against a sql backend.
SqlRequestHandler(DataRequestHandler, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.SqlRequestHandler
Constructor.
SqlResultSetProcessor - Class in com.yahoo.bard.webservice.sql
Process the results from a DruidQuery to a sql backend.
SqlResultSetProcessor(DruidAggregationQuery<?>, ApiToFieldMapper, ObjectMapper, SqlTimeConverter) - Constructor for class com.yahoo.bard.webservice.sql.SqlResultSetProcessor
Builds something to process a set of sql results and return them as the same format as a GroupBy query to Druid.
SqlTimeConverter - Class in com.yahoo.bard.webservice.sql.helper
Handles converting between a DefaultTimeGrain and a list of SqlDatePartFunction to create groupBy statements on intervals of time.
SqlTimeConverter() - Constructor for class com.yahoo.bard.webservice.sql.helper.SqlTimeConverter
Builds a sql time converter which can group by, filter, and reparse dateTimes from a row in a ResultSet using the buildDefaultGranularityToDateFunctionsMap() map.
SqlTimeConverter(Map<Granularity, List<SqlDatePartFunction>>) - Constructor for class com.yahoo.bard.webservice.sql.helper.SqlTimeConverter
Builds a sql time converter which can group by, filter, and reparse dateTimes from a row in a ResultSet.
SqlWorkflow - Class in com.yahoo.bard.webservice.web.handlers.workflow
The Druid Workflow proceeds until a druid data request is returned or an error response is written.
SqlWorkflow(DataCache<?>, DruidWebService, QueryWeightUtil, PhysicalTableDictionary, PartialDataHandler, QuerySigningService<?>, VolatileIntervalsService, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
Constructor.
StandardGranularityParser - Class in com.yahoo.bard.webservice.data.time
StandardGranularityParser implements a time grain dictionary, as well as factory methods to dynamically build zoned time grains.
StandardGranularityParser(GranularityDictionary) - Constructor for class com.yahoo.bard.webservice.data.time.StandardGranularityParser
Constructor.
StandardGranularityParser() - Constructor for class com.yahoo.bard.webservice.data.time.StandardGranularityParser
Constructor.
start() - Method in class com.yahoo.bard.webservice.logging.TimedPhase
Start the phase.
startswithFilterOperation(TreeSet<DimensionRow>, ApiFilter) - Method in interface com.yahoo.bard.webservice.data.dimension.FilterDimensionRows
Startswith-filter operation.
startswithFilterOperation(TreeSet<DimensionRow>, ApiFilter) - Method in class com.yahoo.bard.webservice.data.dimension.impl.ScanSearchProvider
 
startTiming(Object) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Start a stopwatch.
startTiming(String) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Start a stopwatch.
status - Variable in class com.yahoo.bard.webservice.logging.blocks.Epilogue
 
stop() - Method in class com.yahoo.bard.webservice.logging.TimedPhase
Stop the phase.
stopMostRecentTimer() - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Deprecated.
Stopping a timer based on context is brittle, and prone to unexpected changes. Timers should be stopped explicitly, or started in a try-with-resources block
stopTiming(Object) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Pause a stopwatch.
stopTiming(String) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Pause a stopwatch.
StorageStrategy - Enum in com.yahoo.bard.webservice.data.dimension.metadata
Allows clients to be notified if a dimension's values are browsable and searchable.
StreamUtils - Class in com.yahoo.bard.webservice.util
Utils for dealing with streams.
StreamUtils() - Constructor for class com.yahoo.bard.webservice.util.StreamUtils
 
StrictAvailability - Class in com.yahoo.bard.webservice.table.availability
An availability that provides column and table available interval services for strict physical tables.
StrictAvailability(DataSourceName, DataSourceMetadataService) - Constructor for class com.yahoo.bard.webservice.table.availability.StrictAvailability
Constructor.
StrictPhysicalTable - Class in com.yahoo.bard.webservice.table
An implementation of Physical table that is backed by a single fact table and has intersect availability.
StrictPhysicalTable(TableName, ZonedTimeGrain, Set<Column>, Map<String, String>, DataSourceMetadataService) - Constructor for class com.yahoo.bard.webservice.table.StrictPhysicalTable
Create a strict physical table.
StrictPhysicalTable(TableName, ZonedTimeGrain, Set<Column>, Map<String, String>, StrictAvailability) - Constructor for class com.yahoo.bard.webservice.table.StrictPhysicalTable
Create a strict physical table with the availability on this table built externally.
StubDataCache<T extends Serializable> - Class in com.yahoo.bard.webservice.data.cache
Dummy Cache implementation.
StubDataCache() - Constructor for class com.yahoo.bard.webservice.data.cache.StubDataCache
 
subtract(SimplifiedIntervalList) - Method in class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Return the subtracted list of all intervals in this that are not in that.
SuccessCallback - Interface in com.yahoo.bard.webservice.druid.client
Callback from the async HTTP client on success.
switchTiming(String) - Static method in class com.yahoo.bard.webservice.logging.RequestLog
Deprecated.
This method is too dependent on context that can be too easily changed by internal method calls. Each timer should be explicitly started by RequestLog.startTiming(String) and stopped by RequestLog.stopTiming(String) instead
SYNCHRONOUS_ASYNC_AFTER_VALUE - Static variable in interface com.yahoo.bard.webservice.web.apirequest.ApiRequest
 
SYSTEM_ALIGNMENT_EPOCH - Static variable in class com.yahoo.bard.webservice.util.IntervalUtils
 
SYSTEM_CONFIG - Static variable in class com.yahoo.bard.webservice.data.PreResponseDeserializer
 
SYSTEM_CONFIG - Static variable in class com.yahoo.bard.webservice.data.ResultSetSerializationProxy
 
SYSTEM_CONFIG - Static variable in class com.yahoo.bard.webservice.util.IntervalUtils
 
SYSTEM_CONFIG - Static variable in class com.yahoo.bard.webservice.web.handlers.SqlRequestHandler
 
SYSTEM_CONFIG - Static variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
SYSTEM_CONFIG_TIMEZONE_KEY - Static variable in class com.yahoo.bard.webservice.application.AbstractBinderFactory
 
SystemConfig - Interface in com.yahoo.bard.webservice.config
System Config provides an interface for retrieving configuration values, allowing for implicit type conversion, defaulting, and use of a runtime properties interface to override configured settings.
SystemConfigException - Error in com.yahoo.bard.webservice.config
Exception for failures from the system configuration code.
SystemConfigException(String) - Constructor for error com.yahoo.bard.webservice.config.SystemConfigException
Constructor that accepts a message.
SystemConfigException(Throwable) - Constructor for error com.yahoo.bard.webservice.config.SystemConfigException
Constructor that accepts a Throwable.
SystemConfigException(String, Throwable) - Constructor for error com.yahoo.bard.webservice.config.SystemConfigException
Constructor that accepts a Throwable and a message.
SystemConfigProvider - Class in com.yahoo.bard.webservice.config
A class to provide a system configuration instance.
SystemConfigProvider() - Constructor for class com.yahoo.bard.webservice.config.SystemConfigProvider
 

T

table - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
table - Variable in class com.yahoo.bard.webservice.logging.blocks.TableRequest
 
Table - Interface in com.yahoo.bard.webservice.table
Table has a schema and a name.
TableConfig - Class in com.yahoo.wiki.webservice.data.config.auto
TableConfig to hold all metrics, dimensions, valid time grain, and the name of a datasource.
TableConfig(String) - Constructor for class com.yahoo.wiki.webservice.data.config.auto.TableConfig
Construct the TableConfig from a name.
TableDataSource - Class in com.yahoo.bard.webservice.druid.model.datasource
TableDataSource class.
TableDataSource(ConstrainedTable) - Constructor for class com.yahoo.bard.webservice.druid.model.datasource.TableDataSource
Constructor.
tableDictionary - Variable in class com.yahoo.bard.webservice.data.DruidQueryBuilder
 
TableFullViewProcessor - Class in com.yahoo.bard.webservice.web
Class to support custom endpoint of the tables with complete view of each table grains and associated metrics & dimensions.
TableFullViewProcessor() - Constructor for class com.yahoo.bard.webservice.web.TableFullViewProcessor
 
TableGrainView - Class in com.yahoo.bard.webservice.web
Type-def for building a response view of a LogicalTable.
TableGrainView() - Constructor for class com.yahoo.bard.webservice.web.TableGrainView
Constructor.
TableGroup - Class in com.yahoo.bard.webservice.table
A TableGroup is a list of schemas.
TableGroup(LinkedHashSet<PhysicalTable>, Set<ApiMetricName>, Set<Dimension>) - Constructor for class com.yahoo.bard.webservice.table.TableGroup
Builds a TableGroup.
TableGroup(LinkedHashSet<PhysicalTable>, Set<ApiMetricName>) - Constructor for class com.yahoo.bard.webservice.table.TableGroup
Deprecated.
TableGroup should not be deriving its dimensions from physical tables, because a logical table may only surface a subset of the dimensions on its PhysicalTable
TableIdentifier - Class in com.yahoo.bard.webservice.table
Identifies a table by it's logical name and time grain.
TableIdentifier(String, Granularity) - Constructor for class com.yahoo.bard.webservice.table.TableIdentifier
Constructor.
TableIdentifier(String, Optional<ReadablePeriod>) - Constructor for class com.yahoo.bard.webservice.table.TableIdentifier
Constructor.
TableIdentifier(LogicalTable) - Constructor for class com.yahoo.bard.webservice.table.TableIdentifier
Constructor.
tableLoader - Variable in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
 
TableLoader - Interface in com.yahoo.bard.webservice.data.config.table
Defines the core interactions to load logical tables, physical tables, and table groups into the resource dictionaries.
TableMetadataFormatter - Interface in com.yahoo.bard.webservice.web
Interface for transforming logical tables into views that are grain-aware.
TableName - Interface in com.yahoo.bard.webservice.data.config.names
Marker interface for objects that can be treated as a table name.
TableRequest - Class in com.yahoo.bard.webservice.logging.blocks
Main log of a request served by the TablesServlet.
TableRequest(String, String) - Constructor for class com.yahoo.bard.webservice.logging.blocks.TableRequest
Constructor.
TablesApiRequest - Interface in com.yahoo.bard.webservice.web.apirequest
Tables API Request.
TablesApiRequestImpl - Class in com.yahoo.bard.webservice.web.apirequest
Tables API Request Implementation binds, validates, and models the parts of a request to the table endpoint.
TablesApiRequestImpl(String, String, String, String, String, UriInfo, BardConfigResources) - Constructor for class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
Parses the API request URL and generates the Api Request object.
TablesApiRequestImpl(String, String, String, String, String, UriInfo, BardConfigResources, List<PathSegment>, String, String, String, String) - Constructor for class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
Parses the API request URL and generates the API Request object with specified query constraints, i.e.
TablesServlet - Class in com.yahoo.bard.webservice.web.endpoints
Resource code for table resource endpoints.
TablesServlet(ResourceDictionaries, RequestMapper, ObjectMappersSuite, GranularityParser, ResponseFormatResolver) - Constructor for class com.yahoo.bard.webservice.web.endpoints.TablesServlet
Constructor.
TableUtils - Class in com.yahoo.bard.webservice.util
Methods to support table operations and table resolution.
TableUtils() - Constructor for class com.yahoo.bard.webservice.util.TableUtils
 
TableView - Class in com.yahoo.bard.webservice.web
Interface for transforming logical tables into views.
TableView() - Constructor for class com.yahoo.bard.webservice.web.TableView
Constructor.
TableView(String, Object) - Constructor for class com.yahoo.bard.webservice.web.TableView
Constructor.
Tag - Interface in com.yahoo.bard.webservice.data.dimension
Interface for tags used for tagging dimension fields to add additional properties implicitly specified by its name.
TaggedDimensionField - Interface in com.yahoo.bard.webservice.data.dimension
Interface for Dimension fields that expects unique tags to be attached to it to add expressiveness.
TaskFailureCallback() - Constructor for class com.yahoo.bard.webservice.application.LoadTask.TaskFailureCallback
 
TaskHttpErrorCallback() - Constructor for class com.yahoo.bard.webservice.application.LoadTask.TaskHttpErrorCallback
 
TaskScheduler - Class in com.yahoo.bard.webservice.application
Defines a scheduler that runs tasks that load data from Druid periodically or in one-off fashion.
TaskScheduler(int) - Constructor for class com.yahoo.bard.webservice.application.TaskScheduler
Creates a new scheduler for loaders with the given thread pool size.
TemplateDruidQuery - Class in com.yahoo.bard.webservice.data.metric
Template Druid Query.
TemplateDruidQuery(Collection<Aggregation>, Collection<PostAggregation>) - Constructor for class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Template Query constructor for a non nested template query.
TemplateDruidQuery(Collection<Aggregation>, Collection<PostAggregation>, ZonelessTimeGrain) - Constructor for class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Template Query constructor for a non nested template query with a bound time grain.
TemplateDruidQuery(Collection<Aggregation>, Collection<PostAggregation>, TemplateDruidQuery) - Constructor for class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Template Query constructor for a nested template query.
TemplateDruidQuery(Collection<Aggregation>, Collection<PostAggregation>, TemplateDruidQuery, ZonelessTimeGrain) - Constructor for class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Template Query constructor for a nested template query with a bound time grain.
TemplateDruidQueryMerger - Class in com.yahoo.bard.webservice.data.metric
Merges TemplateDruidQueries together.
TemplateDruidQueryMerger() - Constructor for class com.yahoo.bard.webservice.data.metric.TemplateDruidQueryMerger
 
test(PhysicalTable) - Method in interface com.yahoo.bard.webservice.table.availability.IsTableAligned
Test for alignment between a table and a criteria.
test(PhysicalTable) - Method in class com.yahoo.bard.webservice.table.availability.IsTableStartAlignedWithIntervals
Test whether table aligns with the interval collection supplied.
test(PhysicalTable) - Method in class com.yahoo.bard.webservice.table.resolver.AggregatableDimensionsMatcher
 
test(PhysicalTable) - Method in interface com.yahoo.bard.webservice.table.resolver.PhysicalTableMatcher
Determines whether this table matches a requirement.
test(PhysicalTable) - Method in class com.yahoo.bard.webservice.table.resolver.SchemaPhysicalTableMatcher
 
test(PhysicalTable) - Method in class com.yahoo.bard.webservice.table.resolver.TimeAlignmentPhysicalTableMatcher
 
test(Interval) - Method in class com.yahoo.bard.webservice.util.SimplifiedIntervalList.SkippingIntervalPredicate
Skip through the supply intervals until an active interval matches (that is, one which is at or after the test interval) is located and then test it against the testPredicate.
ThetaSketchAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
Aggregation for custom sketches aggregations.
ThetaSketchAggregation(String, String, int) - Constructor for class com.yahoo.bard.webservice.druid.model.aggregation.ThetaSketchAggregation
Constructor.
ThetaSketchEstimatePostAggregation - Class in com.yahoo.bard.webservice.druid.model.postaggregation
Model representing post aggregation numeric estimates from sketches.
ThetaSketchEstimatePostAggregation(String, PostAggregation) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchEstimatePostAggregation
Constructor accepting fields as list of field accessor post aggs.
ThetaSketchFieldConverter - Class in com.yahoo.bard.webservice.druid.util
Converts Sketch fields (Aggregations and PostAggregations) to other Sketch fields.
ThetaSketchFieldConverter() - Constructor for class com.yahoo.bard.webservice.druid.util.ThetaSketchFieldConverter
 
ThetaSketchMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to wrap sketch metric aggregations.
ThetaSketchMaker(MetricDictionary, int) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.ThetaSketchMaker
Constructor.
ThetaSketchSetOperationHelper - Class in com.yahoo.bard.webservice.data.config.metric.makers
A Helper class for ThetaSketchSetOperationMaker that builds a ThetaSketchSetOperationPostAggregation from the intersection of filteredAggregators.
ThetaSketchSetOperationHelper() - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.ThetaSketchSetOperationHelper
 
ThetaSketchSetOperationMaker - Class in com.yahoo.bard.webservice.data.config.metric.makers
Metric maker to support sketch set post aggregations.
ThetaSketchSetOperationMaker(MetricDictionary, SketchSetOperationPostAggFunction) - Constructor for class com.yahoo.bard.webservice.data.config.metric.makers.ThetaSketchSetOperationMaker
Constructor.
ThetaSketchSetOperationPostAggregation - Class in com.yahoo.bard.webservice.druid.model.postaggregation
Model representing a post aggregation of sketch set operations.
ThetaSketchSetOperationPostAggregation(String, SketchSetOperationPostAggFunction, List<PostAggregation>, Integer) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
Constructor accepting a list of post aggregations as fields as well as an explicit sketch size.
ThetaSketchSetOperationPostAggregation(String, SketchSetOperationPostAggFunction, List<PostAggregation>) - Constructor for class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
Constructor accepting a list of post aggregations as fields while leaving the sketch size of the resulting postaggregation undefined.
Threads - Class in com.yahoo.bard.webservice.logging.blocks
Records the names of all the threads that handled part of this request.
Threads(Set<String>) - Constructor for class com.yahoo.bard.webservice.logging.blocks.Threads
Constructor.
threads - Variable in class com.yahoo.bard.webservice.logging.blocks.Threads
 
throwing(Throwable) - Static method in class com.yahoo.bard.webservice.util.CompletedFuture
Creates a completed Future which will throw the given exception.
throwingMerger() - Static method in class com.yahoo.bard.webservice.util.StreamUtils
Returns a merge function, suitable for use in Map.merge() or toMap(), which always throws IllegalStateException.
ticket - Variable in class com.yahoo.bard.webservice.logging.blocks.JobRequest
 
TimeAlignmentPhysicalTableMatcher - Class in com.yahoo.bard.webservice.table.resolver
Tests whether a physical table aligns with the request time and period.
TimeAlignmentPhysicalTableMatcher(QueryPlanningConstraint) - Constructor for class com.yahoo.bard.webservice.table.resolver.TimeAlignmentPhysicalTableMatcher
Stores the request table name and intervals and creates a predicate to test a physical table based on request intervals.
TimeBoundaryQuery - Class in com.yahoo.bard.webservice.druid.model.query
Druid time boundary query.
TimeBoundaryQuery(DataSource, QueryContext, boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.query.TimeBoundaryQuery
Constructor.
TimeBoundaryQuery(DataSource) - Constructor for class com.yahoo.bard.webservice.druid.model.query.TimeBoundaryQuery
Constructor.
TimeBoundaryResponse - Class in com.yahoo.bard.webservice.metadata
Represents a druid timeBoundary response.
TimeBoundaryResponse() - Constructor for class com.yahoo.bard.webservice.metadata.TimeBoundaryResponse
 
TimedPhase - Class in com.yahoo.bard.webservice.logging
Represents a phase that is timed.
TimedPhase(String) - Constructor for class com.yahoo.bard.webservice.logging.TimedPhase
Constructor.
TimeFormatExtractionFunction - Class in com.yahoo.bard.webservice.druid.model.dimension.extractionfunction
An extraction function that returns the dimension value formatted according to given format string, time zone, and locale.
TimeFormatExtractionFunction() - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
Constructor.
TimeFormatExtractionFunction(String, Locale, DateTimeZone, Granularity, Boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
Constructor.
TimeGrain - Interface in com.yahoo.bard.webservice.data.time
TimeGrain represents a strategy for Granularities to map time into monotonic increasing time buckets.
timeGrain - Variable in class com.yahoo.bard.webservice.logging.blocks.DataRequest
 
timeGrainToDatePartFunctions(Granularity) - Method in class com.yahoo.bard.webservice.sql.helper.SqlTimeConverter
Gets a list of SqlDatePartFunction to be performed on a timestamp which can be used to group by the given Granularity.
TimeLimitingCollectorManager - Class in com.yahoo.bard.webservice.data.dimension.impl
Splits a time limited lucene search for parallel execution.
TimeMacro - Enum in com.yahoo.bard.webservice.web
TimeMacro.
TimeOffsetVolatileIntervalsFunction - Class in com.yahoo.bard.webservice.data.volatility
Describe intervals as volatile from some fixed offset in the past to one in the future.
TimeOffsetVolatileIntervalsFunction(long) - Constructor for class com.yahoo.bard.webservice.data.volatility.TimeOffsetVolatileIntervalsFunction
Build a time offset volatile intervals function which marks all intervals from past to the value of FAR_FUTURE as volatile.
TimeOffsetVolatileIntervalsFunction(long, long) - Constructor for class com.yahoo.bard.webservice.data.volatility.TimeOffsetVolatileIntervalsFunction
Constructor.
TimeoutException - Exception in com.yahoo.bard.webservice.data.dimension
Exception used by search providers to timeout queries.
TimeoutException(String) - Constructor for exception com.yahoo.bard.webservice.data.dimension.TimeoutException
Constructor.
TimeoutException(String, Throwable) - Constructor for exception com.yahoo.bard.webservice.data.dimension.TimeoutException
Constructor.
TimeSeriesQuery - Class in com.yahoo.bard.webservice.druid.model.query
Druid timeseries query.
TimeSeriesQuery(DataSource, Granularity, Filter, Collection<Aggregation>, Collection<PostAggregation>, Collection<Interval>, QueryContext, boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
Constructor.
TimeSeriesQuery(DataSource, Granularity, Filter, Collection<Aggregation>, Collection<PostAggregation>, Collection<Interval>) - Constructor for class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
Constructor.
TIMESTAMP_KEY - Static variable in class com.yahoo.bard.webservice.data.ResultSerializationProxy
 
timestampFromDateTime(DateTime) - Static method in class com.yahoo.bard.webservice.sql.helper.TimestampUtils
Creates a timestamp from a DateTime.
timestampFromString(String) - Static method in class com.yahoo.bard.webservice.sql.helper.TimestampUtils
Parses a timestamp from a String.
TimestampUtils - Class in com.yahoo.bard.webservice.sql.helper
Utility function for creating timestamps.
TIMEZONE - Static variable in class com.yahoo.bard.webservice.data.config.ConfigurationLoader
 
toDictionary(Function<? super S, ? extends K>, Supplier<M>) - Static method in class com.yahoo.bard.webservice.util.StreamUtils
Return a collector that creates a dictionary using the given key function and the given map supplier.
toJson() - Method in enum com.yahoo.bard.webservice.druid.model.datasource.DefaultDataSourceType
Get the DataSourceType as a Json value.
toJson() - Method in enum com.yahoo.bard.webservice.druid.model.DefaultQueryType
 
toJson() - Method in enum com.yahoo.bard.webservice.druid.model.dimension.DimensionSpec.DefaultDimensionSpecType
Get the JSON representation of this class.
toJson() - Method in enum com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.ExtractionFunction.DefaultExtractionFunctionType
Get the JSON representation of this class.
toJson() - Method in enum com.yahoo.bard.webservice.druid.model.filter.Filter.DefaultFilterType
Get the JSON representation of this class.
toJson() - Method in enum com.yahoo.bard.webservice.druid.model.orderby.TopNMetric.TopNMetricType
Get the TopNMetricType as a Json value.
toJson() - Method in enum com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation.DefaultPostAggregationType
 
toJson() - Method in interface com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregationType
Return the json equivalent of this post aggregation type.
toJson() - Method in interface com.yahoo.bard.webservice.druid.model.QueryType
Get the JSON serialization of the query type.
toLinkedDictionary(Function<? super S, ? extends K>) - Static method in class com.yahoo.bard.webservice.util.StreamUtils
Return a collector that creates a LinkedHashMap dictionary using the given key function.
toLinkedMap(Function<? super S, ? extends K>, Function<? super S, ? extends V>) - Static method in class com.yahoo.bard.webservice.util.StreamUtils
Return a collector that creates a LinkedHashMap using the given key and value functions.
toMap(Function<? super S, ? extends K>, Function<? super S, ? extends V>, Supplier<M>) - Static method in class com.yahoo.bard.webservice.util.StreamUtils
Return a collector that creates a Map using the given key and value functions.
TooManyDruidFiltersException - Exception in com.yahoo.bard.webservice.exception
Unchecked exception for situations when too many Druid filters a generated for a Druid query.
TooManyDruidFiltersException(String) - Constructor for exception com.yahoo.bard.webservice.exception.TooManyDruidFiltersException
Constructor.
TooManyDruidFiltersException(Throwable) - Constructor for exception com.yahoo.bard.webservice.exception.TooManyDruidFiltersException
Constructor.
TooManyDruidFiltersException(String, Throwable) - Constructor for exception com.yahoo.bard.webservice.exception.TooManyDruidFiltersException
Constructor.
TopNMapperRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Adds the topN result set mapper to allow for top N aggregations based on general group by druid queries.
TopNMapperRequestHandler(DataRequestHandler) - Constructor for class com.yahoo.bard.webservice.web.handlers.TopNMapperRequestHandler
Build a topN request handler.
TopNMetric - Class in com.yahoo.bard.webservice.druid.model.orderby
TopNMetric class corresponding to the Druid TopNMetricSpec.
TopNMetric(String) - Constructor for class com.yahoo.bard.webservice.druid.model.orderby.TopNMetric
Constructs a numeric sort of the given metric with default sorting order (descending).
TopNMetric(String, SortDirection) - Constructor for class com.yahoo.bard.webservice.druid.model.orderby.TopNMetric
Constructs a numeric sort of the given metric and explicitly specifies the order (ascending or descending).
TopNMetric(TopNMetric.TopNMetricType, String) - Constructor for class com.yahoo.bard.webservice.druid.model.orderby.TopNMetric
Constructs a sort of the given type with a starting point.
TopNMetric(TopNMetric.TopNMetricType, String, SortDirection) - Constructor for class com.yahoo.bard.webservice.druid.model.orderby.TopNMetric
Constructs a sort of the given type with a starting point and explicitly specifies the order (ascending or descending).
TopNMetric.TopNMetricType - Enum in com.yahoo.bard.webservice.druid.model.orderby
Types of topN metrics.
TopNQuery - Class in com.yahoo.bard.webservice.druid.model.query
Druid topN query.
TopNQuery(DataSource, Granularity, Dimension, Filter, Collection<Aggregation>, Collection<PostAggregation>, Collection<Interval>, long, TopNMetric, QueryContext, boolean) - Constructor for class com.yahoo.bard.webservice.druid.model.query.TopNQuery
Constructor.
TopNQuery(DataSource, Granularity, Dimension, Filter, Collection<Aggregation>, Collection<PostAggregation>, Collection<Interval>, long, TopNMetric) - Constructor for class com.yahoo.bard.webservice.druid.model.query.TopNQuery
Constructor.
TopNResultSetMapper - Class in com.yahoo.bard.webservice.data.metric.mappers
Mapper to truncate a result set produced by a groupby druid query to the requested top N rows.
TopNResultSetMapper(int) - Constructor for class com.yahoo.bard.webservice.data.metric.mappers.TopNResultSetMapper
Constructor.
toResponse(Throwable) - Method in class com.yahoo.bard.webservice.web.exceptionmappers.LogExceptionMapper
 
toString() - Method in class com.yahoo.bard.webservice.application.LoadTask
 
toString() - Method in enum com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobField
 
toString() - Method in class com.yahoo.bard.webservice.async.jobs.jobrows.JobRow
 
toString() - Method in enum com.yahoo.bard.webservice.data.config.dimension.DefaultDimensionField
 
toString() - Method in class com.yahoo.bard.webservice.data.config.ResourceDictionaries
 
toString() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionColumn
 
toString() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionDictionary
 
toString() - Method in class com.yahoo.bard.webservice.data.dimension.DimensionUpdateDate
 
toString() - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
 
toString() - Method in class com.yahoo.bard.webservice.data.dimension.impl.LookupDimension
 
toString() - Method in class com.yahoo.bard.webservice.data.dimension.impl.RegisteredLookupDimension
 
toString() - Method in enum com.yahoo.bard.webservice.data.dimension.metadata.StorageStrategy
 
toString() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetric
 
toString() - Method in class com.yahoo.bard.webservice.data.metric.LogicalMetricColumn
 
toString() - Method in class com.yahoo.bard.webservice.data.metric.MetricColumn
 
toString() - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
toString() - Method in class com.yahoo.bard.webservice.data.Result
 
toString() - Method in class com.yahoo.bard.webservice.data.ResultSet
 
toString() - Method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
 
toString() - Method in interface com.yahoo.bard.webservice.data.time.TimeGrain
 
toString() - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
 
toString() - Method in class com.yahoo.bard.webservice.druid.client.DruidServiceConfig
 
toString() - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
 
toString() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation
 
toString() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation
 
toString() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
 
toString() - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
 
toString() - Method in enum com.yahoo.bard.webservice.druid.model.query.DefaultSearchQueryType
 
toString() - Method in class com.yahoo.bard.webservice.metadata.SegmentInfo
 
toString() - Method in class com.yahoo.bard.webservice.table.availability.BaseMetadataAvailability
 
toString() - Method in class com.yahoo.bard.webservice.table.availability.MetricUnionAvailability
 
toString() - Method in class com.yahoo.bard.webservice.table.availability.PartitionAvailability
 
toString() - Method in class com.yahoo.bard.webservice.table.availability.PermissiveAvailability
 
toString() - Method in class com.yahoo.bard.webservice.table.availability.StrictAvailability
 
toString() - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
 
toString() - Method in class com.yahoo.bard.webservice.table.BaseSchema
 
toString() - Method in class com.yahoo.bard.webservice.table.PermissivePhysicalTable
 
toString() - Method in class com.yahoo.bard.webservice.table.PhysicalTableSchema
 
toString() - Method in class com.yahoo.bard.webservice.table.SingleDataSourcePhysicalTable
 
toString() - Method in class com.yahoo.bard.webservice.table.StrictPhysicalTable
 
toString() - Method in class com.yahoo.bard.webservice.table.TableGroup
 
toString() - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
toString() - Method in enum com.yahoo.bard.webservice.web.DimensionFieldSpecifierKeywords
 
toString() - Method in enum com.yahoo.bard.webservice.web.ResponseFormatType
 
toString() - Method in enum com.yahoo.bard.webservice.web.TimeMacro
 
toString() - Method in class com.yahoo.bard.webservice.web.util.PaginationParameters
 
toString() - Method in enum com.yahoo.wiki.webservice.data.config.dimension.WikiDimensionField
 
toString() - Method in class com.yahoo.wiki.webservice.data.config.metric.DruidMetricName
 
toString() - Method in class com.yahoo.wiki.webservice.data.config.metric.FiliApiMetricName
 
toString() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiMetricName
 
toString() - Method in enum com.yahoo.wiki.webservice.data.config.names.WikiDruidMetricName
 
TOTAL_TIMER - Static variable in class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
 
totalQueries - Variable in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
toUnmodifiableSet(Stream<T>) - Static method in class com.yahoo.bard.webservice.util.StreamUtils
Collect a stream into an unmodifiable set preserving first-in ordering.
TupleDataCache<K,M extends Serializable,V extends Serializable> - Interface in com.yahoo.bard.webservice.data.cache
Versatile data cache interface that allows for parametrized types for the key, the metadata and the raw data value of an entry.
TupleDataCache.DataEntry<K,M,V> - Interface in com.yahoo.bard.webservice.data.cache
A data cache entry defined as a tuple consisting of key, metadata, and value fields.
type - Variable in class com.yahoo.bard.webservice.druid.model.query.SearchQuerySpec
 
TypeAwareDimensionLoader - Class in com.yahoo.bard.webservice.data.config.dimension
Load dimensions based on the type of the dimension.
TypeAwareDimensionLoader(Iterable<DimensionConfig>) - Constructor for class com.yahoo.bard.webservice.data.config.dimension.TypeAwareDimensionLoader
Constructor.

U

unApply(String) - Method in class com.yahoo.bard.webservice.sql.ApiToFieldMapper
Finds the api name given a field name and if none are found then it returns the given input.
unBind() - Method in class com.yahoo.bard.webservice.web.ratelimit.BypassRateLimitRequestToken
 
unBind() - Method in class com.yahoo.bard.webservice.web.ratelimit.CallbackRateLimitRequestToken
 
unBind() - Method in interface com.yahoo.bard.webservice.web.ratelimit.RateLimitRequestToken
Release the token's counters.
uncheckedCast(Class<R>) - Static method in class com.yahoo.bard.webservice.util.StreamUtils
Return a function that can be used to do unchecked casts without generating a compiler warning.
unconstrained(PhysicalTable) - Static method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
Build a constraint which should not filter away any part of a given table.
underscoreSeparatedConverter() - Static method in interface com.yahoo.bard.webservice.data.dimension.DimensionFieldNameMapper
A default implementation of the converter method which uses underscore as a separator.
UNEXPECTED_INTERVAL_FORMAT - Static variable in class com.yahoo.bard.webservice.web.responseprocessors.SplitQueryResponseProcessor
 
union(SimplifiedIntervalList) - Method in class com.yahoo.bard.webservice.util.SimplifiedIntervalList
Return the union of this simplified interval list and the intervals of another.
union(ApiFilter, ApiFilter) - Static method in class com.yahoo.bard.webservice.web.ApiFilter
Take two Api filters which differ only by value sets and union their value sets.
UnionDataSource - Class in com.yahoo.bard.webservice.druid.model.datasource
Represents a Druid Union data source.
UnionDataSource(ConstrainedTable) - Constructor for class com.yahoo.bard.webservice.druid.model.datasource.UnionDataSource
Constructor.
unionMergeFilterValues(Stream<ApiFilter>) - Static method in class com.yahoo.bard.webservice.web.security.RoleDimensionApiFilterRequestMapper
For a set of ApiFilters collect by dimension, field and operation, and union their value sets.
update(PhysicalTable, DataSourceMetadata) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataService
Deprecated.
Pass the DataSourceName directly, rather than via the PhysicalTable
update(DataSourceName, DataSourceMetadata) - Method in class com.yahoo.bard.webservice.metadata.DataSourceMetadataService
Update the information with respect to the segment metadata of a particular data source.
updateDimension(Dimension) - Method in interface com.yahoo.bard.webservice.application.DimensionValueLoader
Tell the dimension it's been updated.
updateDimensionLastUpdated(String, String) - Method in class com.yahoo.bard.webservice.web.endpoints.DimensionCacheLoaderServlet
Endpoint to update a dimensions lastUpdated field.
updateDimensionLastUpdated(String) - Method in class com.yahoo.bard.webservice.web.endpoints.DimensionCacheLoaderServlet
Endpoint to update cache status.
updateDimensionWithValue(Dimension, DimensionRow) - Method in interface com.yahoo.bard.webservice.application.DimensionValueLoader
Adds dimension row values to a dimension.
updateNestedQueryPostAggs(Collection<PostAggregation>, Map<String, String>, String) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
Update the nested query post agg names if they are not of the type CONSTANT.
updateNestedQueryPostAggs(Collection<PostAggregation>, Map<String, String>, String) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
updateNestedQueryPostAggs(Collection<PostAggregation>, Map<String, String>, String) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
Update the nested query post agg names if they are not of the type CONSTANT.
updateOuterQuery(TemplateDruidQuery, Map<String, String>) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
A method to update outer query aggregations & postAggregations.
updateOuterQuery(TemplateDruidQuery, Map<String, String>) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
updateOuterQuery(TemplateDruidQuery, Map<String, String>) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
A method to update outer query aggregations and postAggregations.
updateQueryAggs(Set<Aggregation>, Map<String, String>, Map<String, Aggregation>) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
Update the outer query aggs if their respective inner post agg names are updated.
updateQueryAggs(Set<Aggregation>, Map<String, String>, Map<String, Aggregation>) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
updateQueryAggs(Set<Aggregation>, Map<String, String>, Map<String, Aggregation>) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
Update the outer query aggs if their respective inner post agg names are updated.
updateTemplateDruidQuery(TemplateDruidQuery, JsonNode, DimensionDictionary, LogicalTable, DataApiRequest) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
 
updateTemplateDruidQuery(TemplateDruidQuery, JsonNode, DimensionDictionary, LogicalTable, DataApiRequest) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
updateTemplateDruidQuery(TemplateDruidQuery, JsonNode, DimensionDictionary, LogicalTable, DataApiRequest) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
Method to update a given query by changing aggregators to filteredAggregators and updating postAggs to reference the filteredAggregators.
uri - Variable in class com.yahoo.bard.webservice.logging.blocks.Preface
 
URI_CSV - Static variable in class com.yahoo.bard.webservice.web.DefaultResponseFormatResolver
 
URI_JSON - Static variable in class com.yahoo.bard.webservice.web.DefaultResponseFormatResolver
 
URI_JSONAPI - Static variable in class com.yahoo.bard.webservice.web.DefaultResponseFormatResolver
 
uriInfo - Variable in class com.yahoo.bard.webservice.web.AbstractResponse
 
uriInfo - Variable in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
 
user - Variable in class com.yahoo.bard.webservice.logging.blocks.Preface
 
userCounts - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
usersCounter - Variable in class com.yahoo.bard.webservice.web.ratelimit.DefaultRateLimiter
 
Utils - Class in com.yahoo.bard.webservice.util
Utils.
Utils() - Constructor for class com.yahoo.bard.webservice.util.Utils
 
uuid - Variable in class com.yahoo.bard.webservice.logging.LogBlock
 

V

validateAggregatability(Set<Dimension>, Map<Dimension, Set<ApiFilter>>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
Validate that the request references any non-aggregatable dimensions in a valid way.
validateDuplicateMetrics(ArrayNode) - Method in class com.yahoo.bard.webservice.web.FilteredSketchMetricsHelper
Deprecated.
 
validateDuplicateMetrics(ArrayNode) - Method in class com.yahoo.bard.webservice.web.FilteredThetaSketchMetricsHelper
 
validateDuplicateMetrics(ArrayNode) - Method in interface com.yahoo.bard.webservice.web.MetricsFilterSetBuilder
This method checks if the metric query contains duplicate metrics and throws a BadApiRequestException in case it does find duplicate metrics.
validateField(QueryContext.Param, Object) - Static method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
Validate that the given field and value are allowed in the context.
validateMetrics(Set<LogicalMetric>, LogicalTable) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Validate that all metrics are part of the logical table.
validateModuleName(String) - Static method in class com.yahoo.bard.webservice.config.ModuleLoader
A method used to apply validation rules to module names found in resource property files.
validateRequestDimensions(Set<Dimension>, LogicalTable) - Method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Ensure all request dimensions are part of the logical table.
validateSecurityFilters(Principal, Set<ApiFilter>) - Method in class com.yahoo.bard.webservice.web.security.RoleDimensionApiFilterRequestMapper
Verify that, given this user, that at least some of the whitelisted filters have been collected.
validateTimeAlignment(Granularity, Set<Interval>) - Static method in class com.yahoo.bard.webservice.web.apirequest.ApiRequestImpl
Throw an exception if any of the intervals are not accepted by this granularity.
VALIDATION_ERROR_FORMAT - Static variable in class com.yahoo.bard.webservice.data.config.table.MetricUnionCompositeTableDefinition
 
validationExceptionMapper(ResourceDictionaries, BiFunction<ApiRequest, ContainerRequestContext, RequestValidationException>) - Static method in class com.yahoo.bard.webservice.web.security.DataApiRequestMapperUtils
Create a requestMapper that always throws a validation exception based on the request.
value - Variable in class com.yahoo.bard.webservice.druid.model.query.InsensitiveContainsSearchQuerySpec
 
valueOf(String) - Static method in enum com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.config.BardFeatureFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.config.CacheFeatureFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.config.ConfigMessageFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.data.Columns
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.data.config.dimension.DefaultDimensionField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.data.dimension.impl.DefaultDimensionFieldTag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.data.dimension.metadata.StorageStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.datasource.DefaultDataSourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.DefaultQueryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.dimension.DimensionSpec.DefaultDimensionSpecType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.ExtractionFunction.DefaultExtractionFunctionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.filter.Filter.DefaultFilterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.filter.SearchFilter.QueryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.having.Having.DefaultHavingType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.orderby.DefaultSearchSortDirection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.orderby.SortDirection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.orderby.TopNMetric.TopNMetricType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation.ArithmeticPostAggregationFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation.DefaultPostAggregationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.query.DefaultSearchQueryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.druid.model.query.QueryContext.Param
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.sql.aggregation.DefaultSqlAggregationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.DimensionFieldSpecifierKeywords
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.ErrorMessageFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.FilterOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.filters.BouncerAuthorizationStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.HavingOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.ResponseCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.ResponseFormatType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.responseprocessors.DruidJsonRequestContentKeys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.responseprocessors.DruidJsonResponseContentKeys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.responseprocessors.ResponseContextKeys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.security.SecurityErrorMessageFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.TimeMacro
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.bard.webservice.web.util.PaginationLink
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.wiki.webservice.data.config.dimension.WikiDimensionField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiDimensionConfigInfo
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiMetricName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.wiki.webservice.data.config.names.WikiDruidMetricName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.wiki.webservice.data.config.names.WikiDruidTableName
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.yahoo.wiki.webservice.data.config.names.WikiLogicalTableName
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.async.jobs.jobrows.DefaultJobStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.config.BardFeatureFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.config.CacheFeatureFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.config.ConfigMessageFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.data.Columns
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.data.config.dimension.DefaultDimensionField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.data.dimension.impl.DefaultDimensionFieldTag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.data.dimension.metadata.StorageStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.data.time.DefaultTimeGrain
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.datasource.DefaultDataSourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.DefaultQueryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.dimension.DimensionSpec.DefaultDimensionSpecType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.ExtractionFunction.DefaultExtractionFunctionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.filter.Filter.DefaultFilterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.filter.SearchFilter.QueryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.having.Having.DefaultHavingType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.orderby.DefaultSearchSortDirection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.orderby.SortDirection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.orderby.TopNMetric.TopNMetricType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation.ArithmeticPostAggregationFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation.DefaultPostAggregationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.query.DefaultSearchQueryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.druid.model.query.QueryContext.Param
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.sql.aggregation.DefaultSqlAggregationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.yahoo.bard.webservice.util.DelegatingMap
 
values() - Static method in enum com.yahoo.bard.webservice.web.DimensionFieldSpecifierKeywords
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.ErrorMessageFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.FilterOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.filters.BouncerAuthorizationStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.HavingOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.ResponseCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.ResponseFormatType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.responseprocessors.DruidJsonRequestContentKeys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.responseprocessors.DruidJsonResponseContentKeys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.responseprocessors.ResponseContextKeys
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.security.SecurityErrorMessageFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.TimeMacro
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.bard.webservice.web.util.PaginationLink
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.wiki.webservice.data.config.dimension.WikiDimensionField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiDimensionConfigInfo
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.wiki.webservice.data.config.names.WikiApiMetricName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.wiki.webservice.data.config.names.WikiDruidMetricName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.wiki.webservice.data.config.names.WikiDruidTableName
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.yahoo.wiki.webservice.data.config.names.WikiLogicalTableName
Returns an array containing the constants of this enum type, in the order they are declared.
VERSION_KEY - Static variable in class com.yahoo.bard.webservice.application.healthchecks.VersionHealthCheck
 
VersionHealthCheck - Class in com.yahoo.bard.webservice.application.healthchecks
Displays version in /status.html.
VersionHealthCheck() - Constructor for class com.yahoo.bard.webservice.application.healthchecks.VersionHealthCheck
Constructor using the default version key property name.
VersionHealthCheck(String, String) - Constructor for class com.yahoo.bard.webservice.application.healthchecks.VersionHealthCheck
Constructor.
VolatileDataRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
A request handler that loads the volatile intervals for a request into the response context.
VolatileDataRequestHandler(DataRequestHandler, PhysicalTableDictionary, VolatileIntervalsService) - Constructor for class com.yahoo.bard.webservice.web.handlers.VolatileDataRequestHandler
Detect volatile intervals and attach metadata describing the intervals to the request.
volatileIntervals - Variable in class com.yahoo.bard.webservice.web.ResponseData
 
VolatileIntervalsFunction - Interface in com.yahoo.bard.webservice.data.volatility
A function that returns volatile intervals.
VolatileIntervalsService - Interface in com.yahoo.bard.webservice.data.volatility
A Volatile Intervals Service determines which requested interval buckets are volatile on a query.
volatileIntervalsService - Variable in class com.yahoo.bard.webservice.web.handlers.VolatileDataRequestHandler
 
volatileIntervalsService - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
volatileIntervalsService - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
VolatileTimeComparator - Class in com.yahoo.bard.webservice.table.resolver
Comparator that prefers tables that contain more data in volatile requested intervals.
VolatileTimeComparator(QueryPlanningConstraint, PartialDataHandler, VolatileIntervalsService) - Constructor for class com.yahoo.bard.webservice.table.resolver.VolatileTimeComparator
Builds a table comparator that compares tables based on how much data there is in their volatile intervals.

W

webService - Variable in class com.yahoo.bard.webservice.web.handlers.WeightCheckRequestHandler
 
webService - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
webService - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
WebServiceHandler - Class in com.yahoo.bard.webservice.web.handlers
WebServiceHandler carries the web service through the chain of request handlers so we know who to send the request to when the request handlers finish.
WebServiceHandler(DruidWebService, DataRequestHandler) - Constructor for class com.yahoo.bard.webservice.web.handlers.WebServiceHandler
Constructor.
WebServiceHandlerSelector - Interface in com.yahoo.bard.webservice.web.handlers
WebServiceHandlerSelectors are responsible for choosing the right web service with the right broker URL to call.
WebServiceSelectorRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
The Webservice selector routes requests in one of several ways, described below.
WebServiceSelectorRequestHandler(DruidWebService, DataRequestHandler, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.WebServiceSelectorRequestHandler
Constructor.
WebServiceSelectorRequestHandler(WebServiceHandlerSelector, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.WebServiceSelectorRequestHandler
Constructor.
WEIGHT_CHECK - Static variable in class com.yahoo.bard.webservice.logging.blocks.BardQueryInfo
 
WeightCheckRequestHandler - Class in com.yahoo.bard.webservice.web.handlers
Weight check request handler determines whether a request should be processed based on estimated query cost.
WeightCheckRequestHandler(DataRequestHandler, DruidWebService, QueryWeightUtil, ObjectMapper) - Constructor for class com.yahoo.bard.webservice.web.handlers.WeightCheckRequestHandler
Build a weight checking request handler.
WeightCheckResponseProcessor - Class in com.yahoo.bard.webservice.web.responseprocessors
A response processor which wraps a timer around the outer most response processor only in the event of an error response.
WeightCheckResponseProcessor(ResponseProcessor) - Constructor for class com.yahoo.bard.webservice.web.responseprocessors.WeightCheckResponseProcessor
Constructor.
WeightEvaluationQuery - Class in com.yahoo.bard.webservice.druid.model.query
Query to generate weight to evaluate the query.
WeightEvaluationQuery(DruidAggregationQuery<?>, int) - Constructor for class com.yahoo.bard.webservice.druid.model.query.WeightEvaluationQuery
Generate a query that calculates the even weight of the response cardinality of the given query.
weightUtil - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.DruidWorkflow
 
weightUtil - Variable in class com.yahoo.bard.webservice.web.handlers.workflow.SqlWorkflow
 
WikiApiDimensionConfigInfo - Enum in com.yahoo.wiki.webservice.data.config.names
Hold all the Wikipedia API dimension names.
WikiApiMetricName - Enum in com.yahoo.wiki.webservice.data.config.names
Hold the list of API metric names.
WikiBinderFactory - Class in com.yahoo.wiki.webservice.application
Wiki specialization of the Abstract Binder factory, applying Wiki configuration objects.
WikiBinderFactory() - Constructor for class com.yahoo.wiki.webservice.application.WikiBinderFactory
 
WikiDimensionField - Enum in com.yahoo.wiki.webservice.data.config.dimension
DimensionField enum.
WikiDimensions - Class in com.yahoo.wiki.webservice.data.config.dimension
Hold all the dimension configurations for the sample Bard instance.
WikiDimensions() - Constructor for class com.yahoo.wiki.webservice.data.config.dimension.WikiDimensions
Construct the dimension configurations.
WikiDruidMetricName - Enum in com.yahoo.wiki.webservice.data.config.names
Hold the list of raw Druid metric names.
WikiDruidTableName - Enum in com.yahoo.wiki.webservice.data.config.names
Hold the list of raw Druid table names.
WikiLogicalTableName - Enum in com.yahoo.wiki.webservice.data.config.names
Hold the list of logical table names.
WikiMain - Class in com.yahoo.wiki.webservice.application
Launch Bard in Embedded Jetty.
WikiMain() - Constructor for class com.yahoo.wiki.webservice.application.WikiMain
 
WikiMetricLoader - Class in com.yahoo.wiki.webservice.data.config.metric
Load the Wiki-specific metrics.
WikiMetricLoader() - Constructor for class com.yahoo.wiki.webservice.data.config.metric.WikiMetricLoader
Constructs a WikiMetricLoader using the default sketch size.
WikiMetricLoader(int) - Constructor for class com.yahoo.wiki.webservice.data.config.metric.WikiMetricLoader
Constructs a WikiMetricLoader using the given sketch size.
WikiTableLoader - Class in com.yahoo.wiki.webservice.data.config.table
Load the Wikipedia-specific table configuration.
WikiTableLoader(DataSourceMetadataService) - Constructor for class com.yahoo.wiki.webservice.data.config.table.WikiTableLoader
Constructor.
withAddColumn(Column) - Method in class com.yahoo.bard.webservice.data.ResultSetSchema
Create a new result set with an additional final column.
withAggregation(Aggregation) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
Creates a new Filtered Aggregation with the provided aggregation.
withAggregation(String) - Method in class com.yahoo.bard.webservice.druid.model.having.NumericHaving
Get a new instance of this having with the given aggregation.
withAggregations(Collection<Aggregation>) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Makes a copy of the template query and any sub query(s), changing aggregations.
withAggregations(Collection<Aggregation>) - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidAggregationQuery
Returns a copy of this query with the specified aggregations.
withAggregations(Collection<Aggregation>) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withAggregations(Collection<Aggregation>) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withAggregations(Collection<Aggregation>) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
 
withAggregations(Collection<Aggregation>) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withAggregations(Collection<Aggregation>) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withAllIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
withAllIntervals(Collection<Interval>) - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidFactQuery
Returns a copy of this query with the specified intervals set in this and all inner queries.
withAllIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
withAllIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withAllIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withAllIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
 
withAllIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withAllIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withAsMillis(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
Returns a new TimeFormatExtractionFunction with a specified config on "asMillis".
withAsyncAfter(long) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withAsyncAfter(long) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withBuilder(Response.ResponseBuilder) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withBuilder(Response.ResponseBuilder) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withBuilder(Response.ResponseBuilder) - Method in interface com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequest
 
withBuilder(Response.ResponseBuilder) - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
 
withBuilder(Response.ResponseBuilder) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withBuilder(Response.ResponseBuilder) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withByRow(boolean) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
Build a copy with a given byRow values.
withBySegment(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
withColumnName(String) - Method in interface com.yahoo.bard.webservice.data.metric.mappers.ColumnMapper
Deprecated.
Returns a copy of this ResultSetMapper with the specified columnName.
withColumnName(String) - Method in class com.yahoo.bard.webservice.data.metric.mappers.NoOpResultSetMapper
Deprecated.
withColumnName(String) - Method in class com.yahoo.bard.webservice.data.metric.mappers.SketchRoundUpMapper
Deprecated.
withColumns(LinkedHashSet<OrderByColumn>) - Method in class com.yahoo.bard.webservice.druid.model.orderby.LimitSpec
 
withConstraint(DataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.BasePhysicalTable
Create a constrained copy of this table.
withConstraint(DataSourceConstraint) - Method in class com.yahoo.bard.webservice.table.ConstrainedTable
Create a constrained copy of the source table.
withConstraint(DataSourceConstraint) - Method in interface com.yahoo.bard.webservice.table.PhysicalTable
Create a constrained copy of this table.
withContext(QueryContext) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
withContext(QueryContext) - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidQuery
Returns a copy of this query with the specified context.
withContext(QueryContext) - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
withContext(QueryContext) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withContext(QueryContext) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withContext(QueryContext) - Method in class com.yahoo.bard.webservice.druid.model.query.SegmentMetadataQuery
 
withContext(QueryContext) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeBoundaryQuery
 
withContext(QueryContext) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
 
withContext(QueryContext) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withContext(QueryContext) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withCount(int) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withCount(int) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withDataSource(DataSource) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
withDataSource(DataSource) - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidQuery
Returns a copy of this query with the specified data source.
withDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
withDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.SegmentMetadataQuery
 
withDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeBoundaryQuery
 
withDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
 
withDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withDataSource(DataSource) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withDelegate(DimensionSpec) - Method in class com.yahoo.bard.webservice.druid.model.dimension.ListFilteredDimensionSpec
 
withDelegate(DimensionSpec) - Method in class com.yahoo.bard.webservice.druid.model.dimension.RegexFilteredDimensionSpec
 
withDependencyMetricNames(List<String>) - Method in class com.yahoo.bard.webservice.data.config.metric.MetricInstance
Makes a copy of the metric instance with new dependencyMetricNames.
withDimension(String) - Method in class com.yahoo.bard.webservice.druid.model.dimension.DefaultDimensionSpec
 
withDimension(String) - Method in class com.yahoo.bard.webservice.druid.model.dimension.ExtractionDimensionSpec
 
withDimension(Dimension) - Method in class com.yahoo.bard.webservice.druid.model.filter.DimensionalFilter
Get a new instance of this filter with the given Dimension.
withDimension(Dimension) - Method in class com.yahoo.bard.webservice.druid.model.filter.ExtractionFilter
Deprecated.
 
withDimension(Dimension) - Method in class com.yahoo.bard.webservice.druid.model.filter.InFilter
 
withDimension(Dimension) - Method in class com.yahoo.bard.webservice.druid.model.filter.RegularExpressionFilter
 
withDimension(Dimension) - Method in class com.yahoo.bard.webservice.druid.model.filter.SearchFilter
 
withDimension(Dimension) - Method in class com.yahoo.bard.webservice.druid.model.filter.SelectorFilter
 
withDimension(Dimension) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withDimension(Dimension) - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
withDimensionField(DimensionField) - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
withDimensions(Set<Dimension>) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
Build a copy with a modified base set of dimensions.
withDimensions(Collection<Dimension>) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withDimensions(Collection<Dimension>) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withDimensions(Set<Dimension>) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withDimensions(Set<Dimension>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withDimensions(LinkedHashSet<Dimension>) - Method in interface com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequest
 
withDimensions(LinkedHashSet<Dimension>) - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
 
withDimensions(Set<Dimension>) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withDimensions(Set<Dimension>) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withExtractionFn(ExtractionFunction) - Method in class com.yahoo.bard.webservice.druid.model.filter.SelectorFilter
Get a new instance of this filter with the given value.
withExtractionFunction(ExtractionFunction) - Method in class com.yahoo.bard.webservice.druid.model.dimension.ExtractionDimensionSpec
 
withExtractionFunction(ExtractionFunction) - Method in class com.yahoo.bard.webservice.druid.model.filter.ExtractionFilter
Deprecated.
Get a new instance of this filter with the given ExtractionFunction.
withExtractionFunctions(List<ExtractionFunction>) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.CascadeExtractionFunction
 
withField(Filter) - Method in class com.yahoo.bard.webservice.druid.model.filter.NotFilter
Get a new instance of this filter with the given field.
withField(PostAggregation) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FuzzySetPostAggregation
Creates a new FuzzySetPostAggregation with the provided field.
withField(PostAggregation) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchEstimatePostAggregation
Deprecated.
 
withField(PostAggregation) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchEstimatePostAggregation
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
Creates a new Aggregation with the provided field name.
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
Field name copy constructor is unsupported because cardinality metrics are built using dimensions backed by dimension druid names.
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CountAggregation
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.DoubleMaxAggregation
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.DoubleMinAggregation
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.DoubleSumAggregation
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.LongMaxAggregation
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.LongMinAggregation
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.LongSumAggregation
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.MaxAggregation
Deprecated.
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.MinAggregation
Deprecated.
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchCountAggregation
Deprecated.
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchMergeAggregation
Deprecated.
 
withFieldName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.ThetaSketchAggregation
 
withFields(List<Filter>) - Method in class com.yahoo.bard.webservice.druid.model.filter.AndFilter
 
withFields(List<Filter>) - Method in class com.yahoo.bard.webservice.druid.model.filter.MultiClauseFilter
Get a new instance of this filter with the given fields.
withFields(List<Filter>) - Method in class com.yahoo.bard.webservice.druid.model.filter.OrFilter
 
withFields(List<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation
 
withFields(List<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FuzzySetPostAggregation
SketchEstimate converts the sketch into a number.
withFields(List<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchEstimatePostAggregation
Deprecated.
SketchEstimate converts the sketch into a number.
withFields(List<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
Get a new instance of this PostAggregation with the given fields.
withFields(List<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchEstimatePostAggregation
SketchEstimate converts the sketch into a number.
withFields(List<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
Get a new instance of this PostAggregation with the given fields.
WithFields<T extends PostAggregation> - Interface in com.yahoo.bard.webservice.druid.model.postaggregation
An Interface to getFields from a PostAggregation and return a PosAggregation constructed from the given fields.
withFields(List<PostAggregation>) - Method in interface com.yahoo.bard.webservice.druid.model.postaggregation.WithFields
withFields provides new instance of respective class created from fields.
withFieldValue(JobField, String) - Method in class com.yahoo.bard.webservice.async.jobs.jobrows.JobRow
Returns a copy of this JobRow with the specified field set to the specified value.
withFilter(Filter) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
withFilter(Filter) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
Creates a new Filtered Aggregation with the provided filter.
withFilter(Filter) - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidFactQuery
Returns a copy of this query with the specified filter.
withFilter(Filter) - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
withFilter(Filter) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withFilter(Filter) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withFilter(Filter) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
 
withFilter(Filter) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withFilter(Filter) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withFilterBuilder(DruidFilterBuilder) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withFilterBuilder(DruidFilterBuilder) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withFilters(ApiFilters) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withFilters(ApiFilters) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withFilters(Set<ApiFilter>) - Method in interface com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequest
 
withFilters(Set<ApiFilter>) - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
 
withFilters(Map<Dimension, Set<ApiFilter>>) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withFilters(Map<Dimension, Set<ApiFilter>>) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withFinalize(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
withFn(ArithmeticPostAggregation.ArithmeticPostAggregationFunction) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation
Get a new instance of this with the given function.
withFormat(String) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
Returns a new TimeFormatExtractionFunction with a specified format.
withFormat(ResponseFormatType) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withFormat(ResponseFormatType) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withFormat(ResponseFormatType) - Method in interface com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequest
 
withFormat(ResponseFormatType) - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
 
withFormat(ResponseFormatType) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withFormat(ResponseFormatType) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withFunc(SketchSetOperationPostAggFunction) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
Get a new instance of this PostAggregation with the given func.
withFunc(SketchSetOperationPostAggFunction) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
Get a new instance of this PostAggregation with the given func.
withGranularity(ZonelessTimeGrain) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Makes a copy of the template query and any sub query(s), changing time grain on the outermost level only.
withGranularity(Granularity) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
With granularity is partially implemented because TemplateDruidQuery supports only ZonelessTimeGrains.
withGranularity(Granularity) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
Returns a new TimeFormatExtractionFunction with a specified granularity.
withGranularity(Granularity) - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidFactQuery
Returns a copy of this query with the specified time grain.
withGranularity(Granularity) - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
withGranularity(Granularity) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withGranularity(Granularity) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withGranularity(Granularity) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
 
withGranularity(Granularity) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withGranularity(Granularity) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withGranularity(Granularity) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withGranularity(Granularity) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withGranularity(Set<LogicalTable>) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withGranularity(Set<LogicalTable>) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withHaving(Having) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withHaving(Having) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withHaving(Having) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withHaving(Having) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withHaving(Having) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withHavings(List<Having>) - Method in class com.yahoo.bard.webservice.druid.model.having.AndHaving
 
withHavings(List<Having>) - Method in class com.yahoo.bard.webservice.druid.model.having.MultiClauseHaving
Get a new instance of this having with the given Havings.
withHavings(List<Having>) - Method in class com.yahoo.bard.webservice.druid.model.having.OrHaving
 
withHavings(Map<LogicalMetric, Set<ApiHaving>>) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withHavings(Map<LogicalMetric, Set<ApiHaving>>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withInjective(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
withInjective(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
withInnermostDataSource(DataSource) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
withInnermostDataSource(DataSource) - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidQuery
Returns a copy of this query with the specified data source on the innermost query.
withInnermostDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
withInnermostDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withInnermostDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withInnermostDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.SegmentMetadataQuery
 
withInnermostDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeBoundaryQuery
 
withInnermostDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
 
withInnermostDataSource(DataSource) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withInnermostDataSource(DataSource) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withInnerQuery(TemplateDruidQuery) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Makes a copy of the template query, changing nested query.
withInnerQueryPostAggregations(Collection<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
Update the postAggregations of the nested inner query.
withIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
 
withIntervals(Collection<Interval>) - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidFactQuery
Returns a copy of this query with the specified intervals.
withIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.DruidSearchQuery
 
withIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.SegmentMetadataQuery
Returns a copy of this query with the specified intervals.
withIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
 
withIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withIntervals(Collection<Interval>) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withIntervals(Set<Interval>) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withIntervals(Set<Interval>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withIntervals(Set<Interval>) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withIntervals(Set<Interval>) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withIsWhiteList(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.dimension.ListFilteredDimensionSpec
 
withJobField(JobField) - Method in class com.yahoo.bard.webservice.async.jobs.stores.JobRowFilter
Construct an JobRowFilter object using the same FilterOperation and values as the object on which this method is called and using the supplied JobField.
withLimit(OptionalInt) - Method in class com.yahoo.bard.webservice.druid.model.orderby.LimitSpec
 
withLimitSpec(LimitSpec) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withLimitSpec(LimitSpec) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withLocale(Locale) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
Returns a new TimeFormatExtractionFunction with a specified locale.
withLogicalMetric(LogicalMetric) - Method in class com.yahoo.bard.webservice.web.ApiHaving
 
withLogicalMetrics(Set<LogicalMetric>) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withLogicalMetrics(Set<LogicalMetric>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withLookbackOffsets(List<Period>) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withLookbackPrefix(List<String>) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withLookbackQueryPostAggregations(Collection<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
Update the postAggregations of the LookbackQuery(outer query).
withLookup(Lookup) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
withLookup(String) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
withMaker(MetricMaker) - Method in class com.yahoo.bard.webservice.data.config.metric.MetricInstance
Makes a copy of the metric instance with new maker.
withMapping(Map<String, String>) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.MapLookup
 
withMetric(TopNMetric) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withMetricDictionary(Map<String, LogicalMetric>) - Method in class com.yahoo.bard.webservice.web.apirequest.DefaultHavingApiGenerator
Rebuild this having generator with a custom metric dictionary.
withMetricIntersection(Set<String>) - Method in class com.yahoo.bard.webservice.table.resolver.DataSourceConstraint
Create a new DataSourceConstraint instance with a new subset of metric names.
withMetricIntersection(Set<String>) - Method in class com.yahoo.bard.webservice.table.resolver.PhysicalDataSourceConstraint
Create a new PhysicalDataSourceConstraint instance with a new subset of metric names.
withMetrics(Set<LogicalMetric>) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withMetrics(Set<LogicalMetric>) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withMetricValue(MetricColumn, Object) - Method in class com.yahoo.bard.webservice.data.Result
Copy the result, adding or replacing the value of a metric
withName(String) - Method in class com.yahoo.bard.webservice.data.config.metric.MetricInstance
Makes a copy of the metric instance with new metric name.
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.Aggregation
Creates a new Aggregation with the provided name.
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CardinalityAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.CountAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.DoubleMaxAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.DoubleMinAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.DoubleSumAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.FilteredAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.LongMaxAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.LongMinAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.LongSumAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.MaxAggregation
Deprecated.
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.MinAggregation
Deprecated.
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchCountAggregation
Deprecated.
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchMergeAggregation
Deprecated.
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.ThetaSketchAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ArithmeticPostAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ConstantPostAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FieldAccessorPostAggregation
Not implemented, since FieldAccessorPostAggregation doesn't take a name.
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.FuzzySetPostAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.PostAggregation
Get a new instance of this PostAggregation with the given name.
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchEstimatePostAggregation
Deprecated.
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchEstimatePostAggregation
 
withName(String) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
 
withNamespace(String) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.NamespaceLookup
 
withOperation(FilterOperation) - Method in class com.yahoo.bard.webservice.async.jobs.stores.JobRowFilter
Construct an JobRowFilter object using the same JobField and values as the object on which this method is called and using the supplied FilterOperation.
withOperation(FilterOperation) - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
withOperation(HavingOperation) - Method in class com.yahoo.bard.webservice.web.ApiHaving
 
withOptimize(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
withOptimize(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
withOrderBy(LimitSpec) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withOrderBy(LimitSpec) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withOrderBy(LimitSpec) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withOutputName(String) - Method in class com.yahoo.bard.webservice.druid.model.dimension.DefaultDimensionSpec
 
withOutputName(String) - Method in class com.yahoo.bard.webservice.druid.model.dimension.ExtractionDimensionSpec
 
withPage(String) - Method in class com.yahoo.bard.webservice.web.util.PaginationParameters
Returns a new PaginationParameters object with the specified page value.
withPaginationParameters(Optional<PaginationParameters>) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withPaginationParameters(Optional<PaginationParameters>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withPaginationParameters(Optional<PaginationParameters>) - Method in interface com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequest
 
withPaginationParameters(Optional<PaginationParameters>) - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
 
withPaginationParameters(Optional<PaginationParameters>) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withPaginationParameters(Optional<PaginationParameters>) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withPattern(Pattern) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.PartialExtractionFunction
Get a new instance of this filter with the given pattern.
withPattern(Pattern) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegularExpressionExtractionFunction
Get a new instance of this filter with the given pattern.
withPattern(Pattern) - Method in class com.yahoo.bard.webservice.druid.model.dimension.RegexFilteredDimensionSpec
 
withPattern(Pattern) - Method in class com.yahoo.bard.webservice.druid.model.filter.RegularExpressionFilter
Get a new instance of this filter with the given pattern.
withPerDimensionFields(LinkedHashMap<Dimension, LinkedHashSet<DimensionField>>) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withPerDimensionFields(LinkedHashMap<Dimension, LinkedHashSet<DimensionField>>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withPerPage(String) - Method in class com.yahoo.bard.webservice.web.util.PaginationParameters
Returns a new PaginationParameters object with the specified perPage value.
withPopulateCache(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
withPostAggregations(Collection<PostAggregation>) - Method in class com.yahoo.bard.webservice.data.metric.TemplateDruidQuery
Makes a copy of the template query and any sub query(s), changing post-aggregations.
withPostAggregations(Collection<PostAggregation>) - Method in interface com.yahoo.bard.webservice.druid.model.query.DruidAggregationQuery
Returns a copy of this query with the specified post aggregations.
withPostAggregations(Collection<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.query.GroupByQuery
 
withPostAggregations(Collection<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.query.LookbackQuery
 
withPostAggregations(Collection<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.query.TimeSeriesQuery
 
withPostAggregations(Collection<PostAggregation>) - Method in class com.yahoo.bard.webservice.druid.model.query.TopNQuery
 
withPostAggregations(Collection<PostAggregation>) - Method in class com.yahoo.bard.webservice.sql.SqlAggregationQuery
 
withPriority(Integer) - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
withQueryId(String) - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
withQueryType(SearchFilter.QueryType) - Method in class com.yahoo.bard.webservice.druid.model.filter.SearchFilter
 
withReplaceMissingValueWith(String) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
withReplaceMissingValueWith(String) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
withRetainMissingValue(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.LookupExtractionFunction
 
withRetainMissingValue(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.RegisteredLookupExtractionFunction
 
withRight(ImmutablePair<T, U>, V) - Static method in class com.yahoo.bard.webservice.util.Utils
Given an ImmutablePair, and a right value, returns a new ImmutablePair with the same left value, and the specified right value.
withSize(int) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchAggregation
Creates a SketchAggregation with the provided bucketSize.
withSize(int) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchCountAggregation
Deprecated.
 
withSize(int) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.SketchMergeAggregation
Deprecated.
 
withSize(int) - Method in class com.yahoo.bard.webservice.druid.model.aggregation.ThetaSketchAggregation
 
withSize(int) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.SketchSetOperationPostAggregation
Deprecated.
Get a new instance of this PostAggregation with the given size.
withSize(int) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ThetaSketchSetOperationPostAggregation
Get a new instance of this PostAggregation with the given size.
withSorts(LinkedHashSet<OrderByColumn>) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withSorts(LinkedHashSet<OrderByColumn>) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withStorageStrategy(StorageStrategy) - Method in class com.yahoo.bard.webservice.data.dimension.impl.KeyValueStoreDimension
Constructs a new KeyValueStoreDimension with specified StorageStrategy.
withTable(LogicalTable) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withTable(LogicalTable) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withTable(LogicalTable) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withTable(LogicalTable) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withTables(Set<LogicalTable>) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withTables(Granularity) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withTables(Set<LogicalTable>) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withTables(Granularity) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withTimeout(Integer) - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
withTimeZone(DateTimeZone) - Method in class com.yahoo.bard.webservice.druid.model.dimension.extractionfunction.TimeFormatExtractionFunction
Returns a new TimeFormatExtractionFunction with a specified time zone.
withTimeZone(DateTimeZone) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withTimeZone(DateTimeZone) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withTopN(int) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withTopN(int) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withType(HavingType) - Method in class com.yahoo.bard.webservice.druid.model.having.NumericHaving
Get a new instance of this having with the given type.
withUncoveredIntervalsLimit(Integer) - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
withUriInfo(UriInfo) - Method in interface com.yahoo.bard.webservice.web.apirequest.DataApiRequest
 
withUriInfo(UriInfo) - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
 
withUriInfo(UriInfo) - Method in interface com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequest
 
withUriInfo(UriInfo) - Method in class com.yahoo.bard.webservice.web.apirequest.DimensionsApiRequestImpl
 
withUriInfo(UriInfo) - Method in interface com.yahoo.bard.webservice.web.apirequest.TablesApiRequest
 
withUriInfo(UriInfo) - Method in class com.yahoo.bard.webservice.web.apirequest.TablesApiRequestImpl
 
withUseCache(Boolean) - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
 
withUuid(String) - Method in class com.yahoo.bard.webservice.logging.LogBlock
Create a new LogBlock with the same body but updated uuid.
withValue(String) - Method in class com.yahoo.bard.webservice.druid.model.filter.ExtractionFilter
Deprecated.
Get a new instance of this filter with the given value.
withValue(String) - Method in class com.yahoo.bard.webservice.druid.model.filter.SearchFilter
 
withValue(String) - Method in class com.yahoo.bard.webservice.druid.model.filter.SelectorFilter
Get a new instance of this filter with the given value.
withValue(Number) - Method in class com.yahoo.bard.webservice.druid.model.having.NumericHaving
Get a new instance of this having with the given value.
withValue(double) - Method in class com.yahoo.bard.webservice.druid.model.postaggregation.ConstantPostAggregation
Get a new instance of this with the given value.
withValue(QueryContext.Param, Object) - Method in class com.yahoo.bard.webservice.druid.model.query.QueryContext
Copy-mutate the context on the given field with the given value.
withValues(Set<String>) - Method in class com.yahoo.bard.webservice.async.jobs.stores.JobRowFilter
Construct an JobRowFilter object using the same JobField and FilterOperation as the object on which this method is called and using the supplied values.
withValues(List<String>) - Method in class com.yahoo.bard.webservice.druid.model.dimension.ListFilteredDimensionSpec
 
withValues(List<String>) - Method in class com.yahoo.bard.webservice.druid.model.filter.InFilter
 
withValues - Variable in class com.yahoo.bard.webservice.logging.blocks.DimensionRequest
 
withValues(Set<String>) - Method in class com.yahoo.bard.webservice.web.ApiFilter
 
withValues(List<Double>) - Method in class com.yahoo.bard.webservice.web.ApiHaving
 
withZone(DateTimeZone) - Method in class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
Create a ZonedTimeGrain with the same base grain and a different time zone.
write(OutputStream) - Method in class com.yahoo.bard.webservice.web.AbstractResponse
Write the response to the output stream.
write(OutputStream) - Method in class com.yahoo.bard.webservice.web.CsvResponse
Writes CSV response.
write(ApiRequest, ResponseData, OutputStream) - Method in class com.yahoo.bard.webservice.web.CsvResponseWriter
 
write(ApiRequest, ResponseData, OutputStream) - Method in class com.yahoo.bard.webservice.web.FiliResponseWriter
 
write(ApiRequest, ResponseData, OutputStream) - Method in class com.yahoo.bard.webservice.web.JsonApiResponseWriter
Writes JSON-API response.
write(OutputStream) - Method in class com.yahoo.bard.webservice.web.JsonResponse
Generates JSON response.
write(ApiRequest, ResponseData, OutputStream) - Method in class com.yahoo.bard.webservice.web.JsonResponseWriter
Writes JSON response.
write(ApiRequest, ResponseData, OutputStream) - Method in interface com.yahoo.bard.webservice.web.ResponseWriter
Serializes the ResultSet (pulled from the ResponseData) and any desired metadata and adds it to the specified output stream.
writeMetaObject(JsonGenerator, UriBuilder) - Method in class com.yahoo.bard.webservice.web.AbstractResponse
Builds the meta data entry of the page if such data is present.
writeMetaObject(JsonGenerator, Collection<Interval>, SimplifiedIntervalList, ResponseData) - Method in class com.yahoo.bard.webservice.web.JsonAndJsonApiResponseWriter
Builds the meta object for the JSON response.
writeNumberField(JsonGenerator, String, Number) - Static method in class com.yahoo.bard.webservice.sql.SqlResultSetProcessor
Writes a Number as either a Double or Long in json.
writer - Variable in class com.yahoo.bard.webservice.web.handlers.BaseDataRequestHandler
 
writer - Variable in class com.yahoo.bard.webservice.web.responseprocessors.CacheV2ResponseProcessor
 
writer - Variable in class com.yahoo.bard.webservice.web.responseprocessors.CachingResponseProcessor
 
writeSql(SqlPrettyWriter, RelToSqlConverter, RelNode) - Method in class com.yahoo.bard.webservice.sql.DruidQueryToSqlConverter
Converts a RelBuilder into a sql string.

X

X_REQUEST_ID - Static variable in class com.yahoo.bard.webservice.web.filters.RequestIdHeaderFilter
 
X_REQUEST_ID_HEADER - Static variable in class com.yahoo.bard.webservice.web.filters.BardLoggingFilter
 

Z

ZonedSchema - Class in com.yahoo.bard.webservice.table
Deprecated.
This class is no longer used as a subclass for ResultSetSchema. Use that class directly now.
ZonedSchema(Granularity, DateTimeZone, Iterable<Column>) - Constructor for class com.yahoo.bard.webservice.table.ZonedSchema
Deprecated.
Constructor.
ZonedSchema(ZonedSchema) - Constructor for class com.yahoo.bard.webservice.table.ZonedSchema
Deprecated.
Constructor.
ZonedTimeGrain - Class in com.yahoo.bard.webservice.data.time
TimeGrain with a time zone and a Zoneless Time Grain.
ZonedTimeGrain(ZonelessTimeGrain, DateTimeZone) - Constructor for class com.yahoo.bard.webservice.data.time.ZonedTimeGrain
Create a Zoned Time grain wrapping a ZonelessTimeGrain and a joda DateTimeZone.
ZonelessTimeGrain - Interface in com.yahoo.bard.webservice.data.time
An interface to support classes which implement a Time Grain without Zone information.
A B C D E F G H I J K L M N O P Q R S T U V W X Z 
Skip navigation links

Copyright © 2016–2018 Yahoo! Inc.. All rights reserved.