| Modifier and Type | Method and Description | 
|---|---|
static <T,QueryType extends Query<T>> | 
QueryBenchmarkUtil.makeQueryRunner(QueryRunnerFactory<T,QueryType> factory,
               String segmentId,
               Segment adapter)  | 
| Modifier and Type | Method and Description | 
|---|---|
<T> QueryRunner<T> | 
CachingClusteredClient.getQueryRunnerForIntervals(Query<T> query,
                          Iterable<org.joda.time.Interval> intervals)  | 
<T> QueryRunner<T> | 
CachingClusteredClient.getQueryRunnerForSegments(Query<T> query,
                         Iterable<SegmentDescriptor> specs)  | 
static Map<String,Object> | 
DirectDruidClient.makeResponseContextForQuery(Query query,
                           long startTimeMillis)  | 
static <T> boolean | 
CacheUtil.populateCacheOnBrokers(Query<T> query,
                      CacheStrategy<T,Object,Query<T>> strategy,
                      CacheConfig cacheConfig)  | 
static <T> boolean | 
CacheUtil.populateCacheOnDataNodes(Query<T> query,
                        CacheStrategy<T,Object,Query<T>> strategy,
                        CacheConfig cacheConfig)  | 
static <T> boolean | 
CacheUtil.useCacheOnBrokers(Query<T> query,
                 CacheStrategy<T,Object,Query<T>> strategy,
                 CacheConfig cacheConfig)  | 
static <T> boolean | 
CacheUtil.useCacheOnDataNodes(Query<T> query,
                   CacheStrategy<T,Object,Query<T>> strategy,
                   CacheConfig cacheConfig)  | 
| Modifier and Type | Method and Description | 
|---|---|
static <T> boolean | 
CacheUtil.populateCacheOnBrokers(Query<T> query,
                      CacheStrategy<T,Object,Query<T>> strategy,
                      CacheConfig cacheConfig)  | 
static <T> boolean | 
CacheUtil.populateCacheOnDataNodes(Query<T> query,
                        CacheStrategy<T,Object,Query<T>> strategy,
                        CacheConfig cacheConfig)  | 
static <T> boolean | 
CacheUtil.useCacheOnBrokers(Query<T> query,
                 CacheStrategy<T,Object,Query<T>> strategy,
                 CacheConfig cacheConfig)  | 
static <T> boolean | 
CacheUtil.useCacheOnDataNodes(Query<T> query,
                   CacheStrategy<T,Object,Query<T>> strategy,
                   CacheConfig cacheConfig)  | 
| Modifier and Type | Method and Description | 
|---|---|
boolean | 
CacheConfig.isQueryCacheable(Query 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> | 
KafkaIndexTask.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<SegmentDescriptor> specs)  | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
CacheStrategy<T,CacheType,QueryType extends Query<T>>  | 
class  | 
DefaultQueryMetrics<QueryType extends Query<?>>
DefaultQueryMetrics is unsafe for use from multiple threads. 
 | 
interface  | 
QueryMetrics<QueryType extends Query<?>>
Abstraction wrapping  
ServiceMetricEvent.Builder and allowing to control what
 metrics are actually emitted, what dimensions do they have, etc. | 
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 extends Comparable<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<T> | 
QueryPlus.getQuery()  | 
Query | 
QueryDataSource.getQuery()  | 
static <T> Query<T> | 
QueryContexts.verifyMaxQueryTimeout(Query<T> query,
                     long maxQueryTimeout)  | 
Query<T> | 
Query.withDataSource(DataSource dataSource)  | 
static <T> Query<T> | 
QueryContexts.withDefaultTimeout(Query<T> query,
                  long defaultTimeout)  | 
Query<T> | 
Query.withId(String id)  | 
Query | 
BaseQuery.withId(String id)  | 
static <T> Query<T> | 
QueryContexts.withMaxScatterGatherBytes(Query<T> query,
                         long maxScatterGatherBytesLimit)  | 
Query<T> | 
Query.withOverriddenContext(Map<String,Object> contextOverride)  | 
Query<T> | 
Query.withQuerySegmentSpec(QuerySegmentSpec spec)  | 
static <T> Query<T> | 
QueryContexts.withTimeout(Query<T> query,
           long timeout)  | 
| Modifier and Type | Method and Description | 
|---|---|
QueryMetrics<Query<?>> | 
GenericQueryMetricsFactory.makeMetrics(Query<?> query)
Creates a  
QueryMetrics for query, which doesn't have predefined QueryMetrics subclass. | 
QueryMetrics<Query<?>> | 
DefaultGenericQueryMetricsFactory.makeMetrics(Query<?> query)  | 
| Modifier and Type | Method and Description | 
|---|---|
protected abstract BinaryFn<T,T,T> | 
ResultMergeQueryRunner.createMergeFn(Query<T> query)  | 
static <T> String | 
QueryContexts.getChunkPeriod(Query<T> query)  | 
static <T> long | 
QueryContexts.getMaxScatterGatherBytes(Query<T> query)  | 
static <T> int | 
QueryContexts.getPriority(Query<T> query)  | 
static <T> int | 
QueryContexts.getPriority(Query<T> query,
           int defaultValue)  | 
<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<SegmentDescriptor> specs)
Gets the Queryable for a given list of SegmentSpecs. 
 | 
static <T> long | 
QueryContexts.getTimeout(Query<T> query)  | 
static <T> long | 
QueryContexts.getTimeout(Query<T> query,
          long defaultTimeout)  | 
static <T> int | 
QueryContexts.getUncoveredIntervalsLimit(Query<T> query)  | 
static <T> int | 
QueryContexts.getUncoveredIntervalsLimit(Query<T> query,
                          int defaultValue)  | 
static <T> boolean | 
QueryContexts.hasTimeout(Query<T> query)  | 
static <T> boolean | 
QueryContexts.isBySegment(Query<T> query)  | 
static <T> boolean | 
QueryContexts.isBySegment(Query<T> query,
           boolean defaultValue)  | 
static <T> boolean | 
QueryContexts.isFinalize(Query<T> query,
          boolean defaultValue)  | 
static <T> boolean | 
QueryContexts.isPopulateCache(Query<T> query)  | 
static <T> boolean | 
QueryContexts.isPopulateCache(Query<T> query,
               boolean defaultValue)  | 
static <T> boolean | 
QueryContexts.isSerializeDateTimeAsLong(Query<T> query,
                         boolean defaultValue)  | 
static <T> boolean | 
QueryContexts.isSerializeDateTimeAsLongInner(Query<T> query,
                              boolean defaultValue)  | 
static <T> boolean | 
QueryContexts.isUseCache(Query<T> query)  | 
static <T> boolean | 
QueryContexts.isUseCache(Query<T> query,
          boolean defaultValue)  | 
QueryMetrics<Query<?>> | 
GenericQueryMetricsFactory.makeMetrics(Query<?> query)
Creates a  
QueryMetrics for query, which doesn't have predefined QueryMetrics subclass. | 
QueryMetrics<Query<?>> | 
DefaultGenericQueryMetricsFactory.makeMetrics(Query<?> query)  | 
protected abstract com.google.common.collect.Ordering<T> | 
ResultMergeQueryRunner.makeOrdering(Query<T> query)  | 
static <T> QueryMetrics<?> | 
DruidMetrics.makeRequestMetrics(GenericQueryMetricsFactory queryMetricsFactory,
                  QueryToolChest<T,Query<T>> toolChest,
                  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. 
 | 
static <T> Query<T> | 
QueryContexts.verifyMaxQueryTimeout(Query<T> query,
                     long maxQueryTimeout)  | 
static <T> Query<T> | 
QueryContexts.withDefaultTimeout(Query<T> query,
                  long defaultTimeout)  | 
static <T> Query<T> | 
QueryContexts.withMaxScatterGatherBytes(Query<T> query,
                         long maxScatterGatherBytesLimit)  | 
<U> QueryPlus<U> | 
QueryPlus.withQuery(Query<U> replacementQuery)
Returns a QueryPlus object with  
QueryMetrics from this QueryPlus object, and the provided Query. | 
static <T> Query<T> | 
QueryContexts.withTimeout(Query<T> query,
           long timeout)  | 
static <T> QueryPlus<T> | 
QueryPlus.wrap(Query<T> query)
Returns the minimum bare QueryPlus object with the given query. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
<T> QueryRunner<T> | 
IntervalChunkingQueryRunnerDecorator.decorate(QueryRunner<T> delegate,
        QueryToolChest<T,? extends Query<T>> toolChest)  | 
static <T> QueryMetrics<?> | 
DruidMetrics.makeRequestMetrics(GenericQueryMetricsFactory queryMetricsFactory,
                  QueryToolChest<T,Query<T>> toolChest,
                  Query<T> query,
                  String remoteAddr)  | 
static <T> QueryRunner<T> | 
CPUTimeMetricQueryRunner.safeBuild(QueryRunner<T> delegate,
         QueryToolChest<T,? extends Query<T>> queryToolChest,
         ServiceEmitter emitter,
         AtomicLong accumulator,
         boolean report)  | 
QueryPlus<T> | 
QueryPlus.withQueryMetrics(QueryToolChest<T,? extends Query<T>> queryToolChest)
Returns the same QueryPlus object, if it already has  
QueryMetrics (QueryPlus.getQueryMetrics() returns not
 null), or returns a new QueryPlus object with Query from this QueryPlus and QueryMetrics created using the
 given QueryToolChest, via QueryToolChest.makeMetrics(Query) method. | 
| 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)  | 
FluentQueryRunnerBuilder(QueryToolChest<T,Query<T>> toolChest)  | 
IntervalChunkingQueryRunner(QueryRunner<T> baseRunner,
                           QueryToolChest<T,Query<T>> toolChest,
                           ExecutorService executor,
                           QueryWatcher queryWatcher,
                           ServiceEmitter emitter)  | 
MapQueryToolChestWarehouse(Map<Class<? extends Query>,QueryToolChest> toolchests)  | 
MetricsEmittingQueryRunner(ServiceEmitter emitter,
                          QueryToolChest<T,? extends Query<T>> queryToolChest,
                          QueryRunner<T> queryRunner,
                          ObjLongConsumer<? super QueryMetrics<?>> reportMetric,
                          Consumer<QueryMetrics<?>> applyCustomDimensions)  | 
ReferenceCountingSegmentQueryRunner(QueryRunnerFactory<T,Query<T>> factory,
                                   ReferenceCountingSegment adapter,
                                   SegmentDescriptor descriptor)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DataSourceMetadataQuery  | 
| Modifier and Type | Method and Description | 
|---|---|
Query<Result<DataSourceMetadataResultValue>> | 
DataSourceMetadataQuery.withDataSource(DataSource dataSource)  | 
| Modifier and Type | Method and Description | 
|---|---|
QueryMetrics<Query<?>> | 
DataSourceQueryQueryToolChest.makeMetrics(DataSourceMetadataQuery query)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
GroupByQuery  | 
| Modifier and Type | Method and Description | 
|---|---|
Query<Row> | 
GroupByQuery.withDataSource(DataSource dataSource)  | 
| Modifier and Type | Method and Description | 
|---|---|
GroupByQuery.Builder | 
GroupByQuery.Builder.setDataSource(Query query)  | 
| Modifier and Type | Method and Description | 
|---|---|
static Sequence<Row> | 
GroupByRowProcessor.process(Query queryParam,
       Sequence<Row> rows,
       Map<String,ValueType> rowSignature,
       GroupByQueryConfig config,
       GroupByQueryResource resource,
       com.fasterxml.jackson.databind.ObjectMapper spillMapper,
       String processingTmpDir,
       int mergeBufferSize)  | 
| Modifier and Type | Method and Description | 
|---|---|
QueryMetrics<Query<?>> | 
SegmentMetadataQueryQueryToolChest.makeMetrics(SegmentMetadataQuery query)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SegmentMetadataQuery  | 
| Modifier and Type | Method and Description | 
|---|---|
Query<SegmentAnalysis> | 
SegmentMetadataQuery.withColumns(ColumnIncluderator includerator)  | 
Query<SegmentAnalysis> | 
SegmentMetadataQuery.withDataSource(DataSource dataSource)  | 
Query<SegmentAnalysis> | 
SegmentMetadataQuery.withOverriddenContext(Map<String,Object> contextOverride)  | 
Query<SegmentAnalysis> | 
SegmentMetadataQuery.withQuerySegmentSpec(QuerySegmentSpec spec)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ScanQuery  | 
| Modifier and Type | Method and Description | 
|---|---|
Query<ScanResultValue> | 
ScanQuery.withDataSource(DataSource dataSource)  | 
Query<ScanResultValue> | 
ScanQuery.withOverriddenContext(Map<String,Object> contextOverrides)  | 
Query<ScanResultValue> | 
ScanQuery.withQuerySegmentSpec(QuerySegmentSpec querySegmentSpec)  | 
| Modifier and Type | Method and Description | 
|---|---|
QueryMetrics<Query<?>> | 
ScanQueryQueryToolChest.makeMetrics(ScanQuery query)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SearchQuery  | 
| Modifier and Type | Method and Description | 
|---|---|
Query<Result<SearchResultValue>> | 
SearchQuery.withDataSource(DataSource dataSource)  | 
| Constructor and Description | 
|---|
DefaultSearchQueryMetrics(QueryMetrics<Query<?>> queryMetrics)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SelectQuery  | 
| Modifier and Type | Method and Description | 
|---|---|
Query<Result<SelectResultValue>> | 
SelectQuery.withDataSource(DataSource dataSource)  | 
| Constructor and Description | 
|---|
DefaultSelectQueryMetrics(QueryMetrics<Query<?>> queryMetrics)  | 
| 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)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
TimeBoundaryQuery  | 
| Modifier and Type | Method and Description | 
|---|---|
Query<Result<TimeBoundaryResultValue>> | 
TimeBoundaryQuery.withDataSource(DataSource dataSource)  | 
| Modifier and Type | Method and Description | 
|---|---|
QueryMetrics<Query<?>> | 
TimeBoundaryQueryQueryToolChest.makeMetrics(TimeBoundaryQuery query)  | 
| 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 | 
|---|---|
static Filter | 
Filters.convertToCNFFromQueryContext(Query query,
                            Filter filter)  | 
| 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<SegmentDescriptor> specs)  | 
| Modifier and Type | Method and Description | 
|---|---|
<T> QueryRunner<T> | 
AppenderatorPlumber.getQueryRunner(Query<T> query)  | 
<T> QueryRunner<T> | 
SinkQuerySegmentWalker.getQueryRunnerForIntervals(Query<T> query,
                          Iterable<org.joda.time.Interval> intervals)  | 
<T> QueryRunner<T> | 
AppenderatorImpl.getQueryRunnerForIntervals(Query<T> query,
                          Iterable<org.joda.time.Interval> intervals)  | 
<T> QueryRunner<T> | 
SinkQuerySegmentWalker.getQueryRunnerForSegments(Query<T> query,
                         Iterable<SegmentDescriptor> specs)  | 
<T> QueryRunner<T> | 
AppenderatorImpl.getQueryRunnerForSegments(Query<T> query,
                         Iterable<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 | 
|---|---|
static <T,QueryType extends Query<T>> | 
SetAndVerifyContextQueryRunner.withTimeoutAndMaxScatterGatherBytes(QueryType query,
                                   ServerConfig serverConfig)  | 
| Modifier and Type | Method and Description | 
|---|---|
Query | 
RequestLogLine.getQuery()  | 
Query | 
QueryLifecycle.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<SegmentDescriptor> specs)  | 
<T> QueryRunner<T> | 
ClientQuerySegmentWalker.getQueryRunnerForSegments(Query<T> query,
                         Iterable<SegmentDescriptor> specs)  | 
void | 
QueryLifecycle.initialize(Query baseQuery)
Initializes this object to execute a specific query. 
 | 
void | 
QueryManager.registerQuery(Query query,
             com.google.common.util.concurrent.ListenableFuture future)  | 
<T> Sequence<T> | 
QueryLifecycle.runSimple(Query<T> query,
         AuthenticationResult authenticationResult,
         String remoteAddress)
For callers where simplicity is desiredĀ over flexibility. 
 | 
| Constructor and Description | 
|---|
RequestLogLine(org.joda.time.DateTime timestamp,
              String remoteAddr,
              Query query,
              QueryStats queryStats)  | 
| 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<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)  | 
<T> 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)  | 
<T> Server | 
QueryHostFinder.getServer(Query<T> query)  | 
Pair<String,Server> | 
TieredBrokerHostSelector.select(Query<T> query)  | 
| Modifier and Type | Method and Description | 
|---|---|
Query | 
DruidQuery.getQuery()  | 
| Modifier and Type | Method and Description | 
|---|---|
List<Map<String,Object>> | 
QueryResourceTestClient.query(String url,
     Query query)  | 
| Modifier and Type | Method and Description | 
|---|---|
Query | 
QueryWithResults.getQuery()  | 
| Constructor and Description | 
|---|
QueryWithResults(Query query,
                List<Map<String,Object>> expectedResults)  | 
Copyright © 2011–2018. All rights reserved.