Modifier and Type | Method and Description |
---|---|
com.metamx.common.guava.Sequence<T> |
DirectDruidClient.run(Query<T> query,
Map<String,Object> context) |
com.metamx.common.guava.Sequence<T> |
CachingQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
CachingClusteredClient.run(Query<T> query,
Map<String,Object> responseContext) |
Modifier and Type | Method and Description |
---|---|
protected com.metamx.common.guava.Sequence<T> |
CachingClusteredClient.mergeCachedAndUncachedSequences(List<com.metamx.common.guava.Sequence<T>> sequencesByInterval,
QueryToolChest<T,Query<T>> toolChest) |
Modifier and Type | Method and Description |
---|---|
boolean |
CacheConfig.isQueryCacheable(Query query) |
Modifier and Type | Method and Description |
---|---|
com.metamx.common.Pair<String,ServerDiscoverySelector> |
HostSelector.select(Query<T> query) |
Modifier and Type | Field and Description |
---|---|
Map<Class<? extends Query>,Class<? extends QueryToolChest>> |
QueryToolChestModule.mappings |
Modifier and Type | Method and Description |
---|---|
static com.google.inject.multibindings.MapBinder<Class<? extends Query>,QueryRunnerFactory> |
DruidBinders.queryRunnerFactoryBinder(com.google.inject.Binder binder) |
static com.google.inject.multibindings.MapBinder<Class<? extends Query>,QueryToolChest> |
DruidBinders.queryToolChestBinder(com.google.inject.Binder binder) |
Modifier and Type | Method and Description |
---|---|
<T> QueryRunner<T> |
Task.getQueryRunner(Query<T> query)
Returns query runners for this task.
|
<T> QueryRunner<T> |
RealtimeIndexTask.getQueryRunner(Query<T> query) |
<T> QueryRunner<T> |
AbstractTask.getQueryRunner(Query<T> query) |
Modifier and Type | Method and Description |
---|---|
<T> QueryRunner<T> |
ThreadPoolTaskRunner.getQueryRunnerForIntervals(Query<T> query,
Iterable<org.joda.time.Interval> intervals) |
<T> QueryRunner<T> |
ThreadPoolTaskRunner.getQueryRunnerForSegments(Query<T> query,
Iterable<io.druid.query.SegmentDescriptor> specs) |
Modifier and Type | Interface and Description |
---|---|
interface |
CacheStrategy<T,CacheType,QueryType extends Query<T>> |
interface |
QueryRunnerFactory<T,QueryType extends Query<T>>
An interface that defines the nitty gritty implementation detauls of a Query on a Segment
|
class |
QueryToolChest<ResultType,QueryType extends Query<ResultType>>
The broker-side (also used by server in some cases) API for a specific Query type.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseQuery<T> |
Modifier and Type | Method and Description |
---|---|
<T,QueryType extends Query<T>> |
QueryRunnerFactoryConglomerate.findFactory(QueryType query) |
<T,QueryType extends Query<T>> |
DefaultQueryRunnerFactoryConglomerate.findFactory(QueryType query) |
<T,QueryType extends Query<T>> |
ReflectionQueryToolChestWarehouse.getToolChest(QueryType query)
Deprecated.
|
<T,QueryType extends Query<T>> |
QueryToolChestWarehouse.getToolChest(QueryType query) |
<T,QueryType extends Query<T>> |
MapQueryToolChestWarehouse.getToolChest(QueryType query) |
Modifier and Type | Method and Description |
---|---|
Query |
QueryDataSource.getQuery() |
Query<T> |
Query.withDataSource(DataSource dataSource) |
Query<T> |
Query.withId(String id) |
Query |
BaseQuery.withId(String id) |
Query<T> |
Query.withOverriddenContext(Map<String,Object> contextOverride) |
Query<T> |
Query.withQuerySegmentSpec(QuerySegmentSpec spec) |
Modifier and Type | Method and Description |
---|---|
protected abstract com.metamx.common.guava.nary.BinaryFn<T,T,T> |
ResultMergeQueryRunner.createMergeFn(Query<T> query) |
com.metamx.common.guava.Sequence<T> |
ResultMergeQueryRunner.doRun(QueryRunner<T> baseRunner,
Query<T> query,
Map<String,Object> context) |
protected abstract com.metamx.common.guava.Sequence<T> |
BySegmentSkippingQueryRunner.doRun(QueryRunner<T> baseRunner,
Query<T> query,
Map<String,Object> context) |
<T> QueryRunner<T> |
QuerySegmentWalker.getQueryRunnerForIntervals(Query<T> query,
Iterable<org.joda.time.Interval> intervals)
Gets the Queryable for a given interval, the Queryable returned can be any version(s) or partitionNumber(s)
such that it represents the interval.
|
<T> QueryRunner<T> |
QuerySegmentWalker.getQueryRunnerForSegments(Query<T> query,
Iterable<io.druid.query.SegmentDescriptor> specs)
Gets the Queryable for a given list of SegmentSpecs.
|
protected abstract com.google.common.collect.Ordering<T> |
ResultMergeQueryRunner.makeOrdering(Query<T> query) |
static <T> com.metamx.emitter.service.ServiceMetricEvent.Builder |
DruidMetrics.makePartialQueryTimeMetric(Query<T> query) |
static <T> com.metamx.emitter.service.ServiceMetricEvent.Builder |
DruidMetrics.makeQueryTimeMetric(com.fasterxml.jackson.databind.ObjectMapper jsonMapper,
Query<T> query,
String remoteAddr) |
void |
QueryWatcher.registerQuery(Query query,
com.google.common.util.concurrent.ListenableFuture future)
QueryRunners must use this method to register any pending queries.
|
com.metamx.common.guava.Sequence<T> |
UnionQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
SubqueryQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
RetryQueryRunner.run(Query<T> query,
Map<String,Object> context) |
com.metamx.common.guava.Sequence<T> |
ReportTimelineMissingSegmentQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
ReferenceCountingSegmentQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
QueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
NoopQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
MetricsEmittingQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
IntervalChunkingQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
GroupByParallelQueryRunner.run(Query<T> queryParam,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
FinalizeResultsQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
ConcatQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
ChainedExecutionQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
BySegmentSkippingQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
BySegmentQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
com.metamx.common.guava.Sequence<T> |
AsyncQueryRunner.run(Query<T> query,
Map<String,Object> responseContext) |
Modifier and Type | Method and Description |
---|---|
<T> QueryRunner<T> |
IntervalChunkingQueryRunnerDecorator.decorate(QueryRunner<T> delegate,
QueryToolChest<T,? extends Query<T>> toolChest) |
Constructor and Description |
---|
QueryDataSource(Query query) |
Constructor and Description |
---|
DefaultQueryRunnerFactoryConglomerate(Map<Class<? extends Query>,QueryRunnerFactory> factories) |
FinalizeResultsQueryRunner(QueryRunner<T> baseRunner,
QueryToolChest<T,Query<T>> toolChest) |
IntervalChunkingQueryRunner(QueryRunner<T> baseRunner,
QueryToolChest<T,Query<T>> toolChest,
ExecutorService executor,
QueryWatcher queryWatcher,
com.metamx.emitter.service.ServiceEmitter emitter) |
MapQueryToolChestWarehouse(Map<Class<? extends Query>,QueryToolChest> toolchests) |
MetricsEmittingQueryRunner(com.metamx.emitter.service.ServiceEmitter emitter,
com.google.common.base.Function<Query<T>,com.metamx.emitter.service.ServiceMetricEvent.Builder> builderFn,
QueryRunner<T> queryRunner) |
MetricsEmittingQueryRunner(com.metamx.emitter.service.ServiceEmitter emitter,
com.google.common.base.Function<Query<T>,com.metamx.emitter.service.ServiceMetricEvent.Builder> builderFn,
QueryRunner<T> queryRunner,
long creationTime,
String metricName,
Map<String,String> userDimensions) |
MetricsEmittingQueryRunner(com.metamx.emitter.service.ServiceEmitter emitter,
com.google.common.base.Function<Query<T>,com.metamx.emitter.service.ServiceMetricEvent.Builder> builderFn,
QueryRunner<T> queryRunner,
String metricName,
Map<String,String> userDimensions) |
ReferenceCountingSegmentQueryRunner(QueryRunnerFactory<T,Query<T>> factory,
ReferenceCountingSegment adapter) |
RetryQueryRunner(QueryRunner<T> baseRunner,
QueryToolChest<T,Query<T>> toolChest,
RetryQueryRunnerConfig config,
com.fasterxml.jackson.databind.ObjectMapper jsonMapper) |
UnionQueryRunner(Iterable<QueryRunner> baseRunners,
QueryToolChest<T,Query<T>> toolChest) |
Modifier and Type | Class and Description |
---|---|
class |
DataSourceMetadataQuery |
Modifier and Type | Method and Description |
---|---|
Query<Result<DataSourceMetadataResultValue>> |
DataSourceMetadataQuery.withDataSource(DataSource dataSource) |
Modifier and Type | Class and Description |
---|---|
class |
GroupByQuery |
Modifier and Type | Method and Description |
---|---|
Query<io.druid.data.input.Row> |
GroupByQuery.withDataSource(DataSource dataSource) |
Modifier and Type | Method and Description |
---|---|
GroupByQuery.Builder |
GroupByQuery.Builder.setDataSource(Query query) |
Modifier and Type | Class and Description |
---|---|
class |
SegmentMetadataQuery |
Modifier and Type | Method and Description |
---|---|
Query<SegmentAnalysis> |
SegmentMetadataQuery.withDataSource(DataSource dataSource) |
Query<SegmentAnalysis> |
SegmentMetadataQuery.withOverriddenContext(Map<String,Object> contextOverride) |
Query<SegmentAnalysis> |
SegmentMetadataQuery.withQuerySegmentSpec(QuerySegmentSpec spec) |
Modifier and Type | Method and Description |
---|---|
com.metamx.common.guava.Sequence<Result<SearchResultValue>> |
SearchQueryRunner.run(Query<Result<SearchResultValue>> input,
Map<String,Object> responseContext) |
Modifier and Type | Class and Description |
---|---|
class |
SearchQuery |
Modifier and Type | Method and Description |
---|---|
Query<Result<SearchResultValue>> |
SearchQuery.withDataSource(DataSource dataSource) |
Modifier and Type | Class and Description |
---|---|
class |
SelectQuery |
Modifier and Type | Method and Description |
---|---|
Query<Result<SelectResultValue>> |
SelectQuery.withDataSource(DataSource dataSource) |
Modifier and Type | Method and Description |
---|---|
<T> QueryRunner<T> |
SpecificSegmentSpec.lookup(Query<T> query,
QuerySegmentWalker walker) |
<T> QueryRunner<T> |
QuerySegmentSpec.lookup(Query<T> query,
QuerySegmentWalker walker) |
<T> QueryRunner<T> |
MultipleSpecificSegmentSpec.lookup(Query<T> query,
QuerySegmentWalker walker) |
<T> QueryRunner<T> |
MultipleIntervalSegmentSpec.lookup(Query<T> query,
QuerySegmentWalker walker) |
com.metamx.common.guava.Sequence<T> |
SpecificSegmentQueryRunner.run(Query<T> input,
Map<String,Object> responseContext) |
Modifier and Type | Class and Description |
---|---|
class |
TimeBoundaryQuery |
Modifier and Type | Method and Description |
---|---|
Query<Result<TimeBoundaryResultValue>> |
TimeBoundaryQuery.withDataSource(DataSource dataSource) |
Modifier and Type | Class and Description |
---|---|
class |
TimeseriesQuery |
Modifier and Type | Method and Description |
---|---|
Query<Result<TimeseriesResultValue>> |
TimeseriesQuery.withDataSource(DataSource dataSource) |
Modifier and Type | Class and Description |
---|---|
class |
TopNQuery |
Modifier and Type | Method and Description |
---|---|
Query<Result<TopNResultValue>> |
TopNQuery.withDataSource(DataSource dataSource) |
Modifier and Type | Method and Description |
---|---|
<T> QueryRunner<T> |
RealtimeManager.getQueryRunnerForIntervals(Query<T> query,
Iterable<org.joda.time.Interval> intervals) |
<T> QueryRunner<T> |
RealtimeManager.getQueryRunnerForSegments(Query<T> query,
Iterable<io.druid.query.SegmentDescriptor> specs) |
Modifier and Type | Method and Description |
---|---|
<T> QueryRunner<T> |
RealtimePlumber.getQueryRunner(Query<T> query) |
<T> QueryRunner<T> |
Plumber.getQueryRunner(Query<T> query) |
Modifier and Type | Method and Description |
---|---|
Query |
RequestLogLine.getQuery() |
Modifier and Type | Method and Description |
---|---|
<T> QueryRunner<T> |
DirectClientQuerySegmentWalker.getQueryRunnerForIntervals(Query<T> query,
Iterable<org.joda.time.Interval> intervals) |
<T> QueryRunner<T> |
ClientQuerySegmentWalker.getQueryRunnerForIntervals(Query<T> query,
Iterable<org.joda.time.Interval> intervals) |
<T> QueryRunner<T> |
DirectClientQuerySegmentWalker.getQueryRunnerForSegments(Query<T> query,
Iterable<io.druid.query.SegmentDescriptor> specs) |
<T> QueryRunner<T> |
ClientQuerySegmentWalker.getQueryRunnerForSegments(Query<T> query,
Iterable<io.druid.query.SegmentDescriptor> specs) |
void |
QueryManager.registerQuery(Query query,
com.google.common.util.concurrent.ListenableFuture future) |
Constructor and Description |
---|
RequestLogLine(org.joda.time.DateTime timestamp,
String remoteAddr,
Query query,
QueryStats queryStats) |
Modifier and Type | Method and Description |
---|---|
<T> QueryRunner<T> |
BridgeQuerySegmentWalker.getQueryRunnerForIntervals(Query<T> query,
Iterable<org.joda.time.Interval> intervals) |
<T> QueryRunner<T> |
BridgeQuerySegmentWalker.getQueryRunnerForSegments(Query<T> query,
Iterable<io.druid.query.SegmentDescriptor> specs) |
Modifier and Type | Method and Description |
---|---|
<T> QueryRunner<T> |
ServerManager.getQueryRunnerForIntervals(Query<T> query,
Iterable<org.joda.time.Interval> intervals) |
<T> QueryRunner<T> |
ServerManager.getQueryRunnerForSegments(Query<T> query,
Iterable<io.druid.query.SegmentDescriptor> specs) |
Modifier and Type | Method and Description |
---|---|
Query |
EmittingRequestLogger.RequestLogEvent.getQuery() |
Modifier and Type | Method and Description |
---|---|
String |
JavaScriptTieredBrokerSelectorStrategy.SelectorFunction.apply(TieredBrokerConfig config,
Query query) |
Server |
QueryHostFinder.findServer(Query<T> query) |
com.google.common.base.Optional<String> |
TimeBoundaryTieredBrokerSelectorStrategy.getBrokerServiceName(TieredBrokerConfig tierConfig,
Query query) |
com.google.common.base.Optional<String> |
TieredBrokerSelectorStrategy.getBrokerServiceName(TieredBrokerConfig config,
Query query) |
com.google.common.base.Optional<String> |
PriorityTieredBrokerSelectorStrategy.getBrokerServiceName(TieredBrokerConfig tierConfig,
Query query) |
com.google.common.base.Optional<String> |
JavaScriptTieredBrokerSelectorStrategy.getBrokerServiceName(TieredBrokerConfig config,
Query query) |
String |
QueryHostFinder.getHost(Query<T> query) |
com.metamx.common.Pair<String,ServerDiscoverySelector> |
TieredBrokerHostSelector.select(Query<T> query) |
Modifier and Type | Method and Description |
---|---|
List<Map<String,Object>> |
QueryResourceTestClient.query(Query query) |
Modifier and Type | Method and Description |
---|---|
Query |
QueryWithResults.getQuery() |
Constructor and Description |
---|
QueryWithResults(Query query,
List<Map<String,Object>> expectedResults) |
Copyright © 2011–2015. All rights reserved.