- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- DimensionValueLoadTask(Collection<DimensionValueLoader>) - Constructor for class com.yahoo.bard.webservice.application.DimensionValueLoadTask
-
DimensionLoaderTask tells all of the
DimensionValueLoader
s 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
-
- DruidSqlAggregationConverter() - Constructor for class com.yahoo.bard.webservice.sql.aggregation.DruidSqlAggregationConverter
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- getAvailableIntervals(PhysicalDataSourceConstraint) - Method in interface com.yahoo.bard.webservice.table.availability.Availability
-
- getAvailableIntervals(DataSourceConstraint) - Method in interface com.yahoo.bard.webservice.table.availability.Availability
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
ApiFilter
s.
- getDruidFilter() - Method in class com.yahoo.bard.webservice.web.apirequest.DataApiRequestImpl
-
Builds and returns the Druid filters from this request's
ApiFilter
s.
- 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
-
- getDruidNonUiTimeout() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
-
- getDruidNonUiUrl() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
-
- 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
-
- getDruidUiTimeout() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
-
- getDruidUiUrl() - Static method in class com.yahoo.bard.webservice.druid.client.DruidClientConfigHelper
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- SchedulableTask(Callable<V>, RunnableScheduledFuture<V>) - Constructor for class com.yahoo.bard.webservice.application.SchedulableTask
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- SketchFieldConverter() - Constructor for class com.yahoo.bard.webservice.druid.util.SketchFieldConverter
-
Deprecated.
- SketchMergeAggregation - Class in com.yahoo.bard.webservice.druid.model.aggregation
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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.
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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.