| Modifier and Type | Class and Description | 
|---|---|
class  | 
MapBasedInputRow  | 
class  | 
MapBasedRow  | 
interface  | 
Row
A Row of data. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DimensionSchema  | 
class  | 
DimensionsSpec  | 
class  | 
TimestampSpec  | 
| Modifier and Type | Method and Description | 
|---|---|
DimensionSchema | 
DimensionsSpec.getSchema(String dimension)  | 
void | 
ParseSpec.verify(List<String> usedCols)  | 
DimensionsSpec | 
DimensionsSpec.withDimensions(List<DimensionSchema> dims)  | 
ParseSpec | 
ParseSpec.withTimestampSpec(TimestampSpec spec)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
Binders  | 
class  | 
ConditionalMultibind<T>
Provides the ability to conditionally bind an item to a set. 
 | 
class  | 
DruidGuiceExtensions  | 
class  | 
DruidScopes  | 
class  | 
Jerseys  | 
class  | 
JsonConfigProvider<T>
Provides a singleton value of type  
<T> from Properties bound in guice. | 
interface  | 
LazySingleton  | 
interface  | 
ManageLifecycle
Marks the object to be managed by  
Lifecycle
 This Scope gets defined by LifecycleModule | 
interface  | 
ManageLifecycleLast
Marks the object to be managed by  
Lifecycle and set to be on Stage.LAST
 This Scope gets defined by LifecycleModule | 
class  | 
PolyBind
Provides the ability to create "polymorphic" bindings. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ConditionalMultibind<T> | 
ConditionalMultibind.addConditionBinding(String property,
                   com.google.common.base.Predicate<String> condition,
                   com.google.inject.TypeLiteral<T> target)
Conditionally bind target to the set. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
interface  | 
EscalatedGlobal  | 
interface  | 
Global  | 
interface  | 
Json  | 
interface  | 
JSR311Resource  | 
interface  | 
Self  | 
interface  | 
Smile  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
ImmutableWorkerInfo
A snapshot of a Worker and its current state i.e tasks assigned to that worker. 
 | 
interface  | 
TaskRunner
Interface for handing off tasks. 
 | 
interface  | 
WorkerTaskRunner  | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
Provisioner  | 
interface  | 
ProvisioningService
The ProvisioningService decides if worker nodes should be provisioned or terminated
 based on the available tasks in the system and the state of the workers in the system. 
 | 
class  | 
ScalingStats  | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
WorkerSelectStrategy
The  
RemoteTaskRunner uses this class to select a worker to assign tasks to. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
Worker
A container for worker metadata. 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
JavaScriptConfig
Should be used by extension filters, aggregators, etc, that use JavaScript to determine if JavaScript is enabled
 or not. 
 | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
BySegmentResultValue<T>  | 
interface  | 
GenericQueryMetricsFactory
This factory is used for DI of custom  
QueryMetrics implementations for all query types, which don't (yet)
 need to emit custom dimensions and/or metrics, i. | 
class  | 
Queries  | 
class  | 
QueryContexts  | 
class  | 
QueryPlus<T>
An immutable composite object of  
Query + extra stuff needed in QueryRunners. | 
class  | 
Result<T>  | 
class  | 
ResultGranularTimestampComparator<T>  | 
class  | 
ResultMergeQueryRunner<T>  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
QueryMetrics.dataSource(QueryType query)
Sets  
Query.getDataSource() of the given query as dimension. | 
<T> QueryRunner<T> | 
IntervalChunkingQueryRunnerDecorator.decorate(QueryRunner<T> delegate,
        QueryToolChest<T,? extends Query<T>> toolChest)  | 
void | 
QueryMetrics.duration(QueryType query)
Sets  
Query.getDuration() of the given query as dimension. | 
void | 
QueryMetrics.hasFilters(QueryType query)
Sets  
Query.hasFilters() of the given query as dimension. | 
void | 
QueryMetrics.interval(QueryType query)
Sets  
Query.getIntervals() of the given query as dimension. | 
void | 
QueryMetrics.queryId(QueryType query)
Sets  
Query.getId() of the given query as dimension. | 
void | 
QueryMetrics.queryType(QueryType query)
Sets  
Query.getType() of the given query as dimension. | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
AggregatorUtil  | 
interface  | 
MetricManipulationFn  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
CacheKeyBuilder
CacheKeyBuilder is a tool for easily generating cache keys of  
Cacheable objects. | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
GroupByQueryMetrics.granularity(GroupByQuery query)
Sets the granularity of  
BaseQuery.getGranularity() of the given query as dimension. | 
void | 
GroupByQueryMetrics.numComplexMetrics(GroupByQuery query)
Sets the number of "complex" metrics of the given groupBy query as dimension. 
 | 
void | 
GroupByQueryMetrics.numDimensions(GroupByQuery query)
Sets the size of  
GroupByQuery.getDimensions() of the given query as dimension. | 
void | 
GroupByQueryMetrics.numMetrics(GroupByQuery query)
Sets the number of metrics of the given groupBy query as dimension. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
TimeseriesQueryMetrics.granularity(TimeseriesQuery query)
Sets the granularity of  
BaseQuery.getGranularity() of the given query as dimension. | 
void | 
TimeseriesQueryMetrics.numComplexMetrics(TimeseriesQuery query)
Sets the number of "complex" metrics of the given timeseries query as dimension. 
 | 
void | 
TimeseriesQueryMetrics.numMetrics(TimeseriesQuery query)
Sets the number of metrics of the given timeseries query as dimension. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
TopNQueryMetrics | 
TopNQueryMetrics.addProcessedRows(long numRows)
Called with the number of rows, processed via each cursor, processed for the query within the segment. 
 | 
void | 
TopNQueryMetrics.algorithm(TopNAlgorithm algorithm)  | 
void | 
TopNQueryMetrics.columnValueSelector(ColumnValueSelector columnValueSelector)
This method is called exactly once with the columnValueSelector object of each cursor, processed for the query. 
 | 
void | 
TopNQueryMetrics.cursor(Cursor cursor)
This method is called exactly once with each cursor, processed for the query. 
 | 
void | 
TopNQueryMetrics.dimension(TopNQuery query)
Sets  
TopNQuery.getDimensionSpec().getDimension() of the given query as dimension. | 
void | 
TopNQueryMetrics.dimensionCardinality(int cardinality)  | 
void | 
TopNQueryMetrics.granularity(TopNQuery query)
Sets the granularity of  
BaseQuery.getGranularity() of the given query as dimension. | 
void | 
TopNQueryMetrics.numComplexMetrics(TopNQuery query)
Sets the number of "complex" metrics of the given topN query as dimension. 
 | 
void | 
TopNQueryMetrics.numMetrics(TopNQuery query)
Sets the number of metrics of the given topN query as dimension. 
 | 
void | 
TopNQueryMetrics.numValuesPerPass(TopNParams params)
This method may set  
TopNParams.getNumValuesPerPass() of the query as dimension. | 
void | 
TopNQueryMetrics.threshold(TopNQuery query)
Sets  
TopNQuery.getThreshold() of the given query as dimension. | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
BaseDoubleColumnValueSelector
Double value selecting polymorphic "part" of the  
ColumnValueSelector interface. | 
interface  | 
BaseFloatColumnValueSelector
Float value selecting polymorphic "part" of the  
ColumnValueSelector interface. | 
interface  | 
BaseLongColumnValueSelector
Long value selecting polymorphic "part" of the  
ColumnValueSelector interface. | 
interface  | 
BaseObjectColumnValueSelector<T>
Object value selecting polymorphic "part" of the  
ColumnValueSelector interface. | 
interface  | 
ColumnSelectorFactory
Factory class for MetricSelectors 
 | 
interface  | 
ColumnValueSelector<T>
Base type for interfaces that manage column value selection, e.g. 
 | 
interface  | 
DimensionSelector  | 
class  | 
Metadata  | 
class  | 
NilColumnValueSelector
Represents "absent" column. 
 | 
interface  | 
Segment  | 
class  | 
SegmentUtils
Utility methods useful for implementing deep storage extensions. 
 | 
interface  | 
StorageAdapter  | 
| Modifier and Type | Method and Description | 
|---|---|
String | 
StorageAdapter.getSegmentIdentifier()  | 
| Modifier and Type | Interface and Description | 
|---|---|
interface  | 
Indexed<T>  | 
interface  | 
IndexedInts
Get a int an index (array or list lookup abstraction without boxing). 
 | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
SegmentLoadingException  | 
| Modifier and Type | Method and Description | 
|---|---|
static LargeColumnSupportedComplexColumnSerializer | 
LargeColumnSupportedComplexColumnSerializer.create(SegmentWriteOutMedium segmentWriteOutMedium,
      String filenameBase,
      ObjectStrategy strategy)  | 
static ComplexColumnSerializer | 
ComplexColumnSerializer.create(SegmentWriteOutMedium segmentWriteOutMedium,
      String filenameBase,
      ObjectStrategy strategy)  | 
| Modifier and Type | Class and Description | 
|---|---|
interface  | 
ExtraServiceDimensions
Annotation to inject extra dimensions, added to all events, emitted via  
EmitterModule.getServiceEmitter(com.google.common.base.Supplier<io.druid.server.DruidNode>, io.druid.java.util.emitter.core.Emitter, java.util.Map<java.lang.String, java.lang.String>). | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
DataSegment  | 
class  | 
DataSegmentUtils  | 
interface  | 
LogicalSegment  | 
| Modifier and Type | Method and Description | 
|---|---|
String | 
DataSegmentUtils.SegmentIdentifierParts.getDataSource()  | 
String | 
DataSegmentUtils.SegmentIdentifierParts.getVersion()  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
CompressionUtils  | 
class  | 
Runnables  | 
Copyright © 2011–2018. All rights reserved.