Uses of Interface
org.apache.druid.query.QueryMetrics
-
-
Uses of QueryMetrics in org.apache.druid.query
Classes in org.apache.druid.query that implement QueryMetrics Modifier and Type Class Description classDefaultQueryMetrics<QueryType extends Query<?>>DefaultQueryMetrics is unsafe for use from multiple threads.Methods in org.apache.druid.query that return QueryMetrics Modifier and Type Method Description QueryMetrics<?>QueryPlus. getQueryMetrics()QueryMetrics<Query<?>>DefaultGenericQueryMetricsFactory. makeMetrics()QueryMetrics<Query<?>>DefaultGenericQueryMetricsFactory. makeMetrics(Query<?> query)QueryMetrics<Query<?>>GenericQueryMetricsFactory. makeMetrics()Creates aQueryMetricswhich doesn't have predefined QueryMetrics subclass.QueryMetrics<Query<?>>GenericQueryMetricsFactory. makeMetrics(Query<?> query)Creates aQueryMetricsfor query, which doesn't have predefined QueryMetrics subclass.QueryMetrics<? super Query<Object>>QueryLogicCompatToolChest. makeMetrics(Query<Object> query)abstract QueryMetrics<? super QueryType>QueryToolChest. makeMetrics(QueryType query)Creates aQueryMetricsobject that is used to generate metrics for this specific query type.static <T> QueryMetrics<?>DruidMetrics. makeRequestMetrics(GenericQueryMetricsFactory queryMetricsFactory, QueryToolChest<T,Query<T>> toolChest, Query<T> query, String remoteAddr)QueryMetrics<QueryType>DefaultQueryMetrics. reportBackPressureTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportBackPressureTime(long timeNs)Registers "time that channel is unreadable (backpressure)" metric.QueryMetrics<QueryType>DefaultQueryMetrics. reportBitmapConstructionTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportBitmapConstructionTime(long timeNs)Reports the time spent constructing bitmap fromfilterBundle(FilterBundle.BundleInfo)of the query.QueryMetrics<QueryType>DefaultQueryMetrics. reportCpuTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportCpuTime(long timeNs)Registers "cpu time" metric.protected QueryMetrics<QueryType>DefaultQueryMetrics. reportMetric(String metricName, Number value)QueryMetrics<QueryType>DefaultQueryMetrics. reportNodeBytes(long byteCount)QueryMetrics<QueryType>QueryMetrics. reportNodeBytes(long byteCount)Registers "node bytes" metric.QueryMetrics<QueryType>DefaultQueryMetrics. reportNodeTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportNodeTime(long timeNs)Registers "node time" metric.QueryMetrics<QueryType>DefaultQueryMetrics. reportNodeTimeToFirstByte(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportNodeTimeToFirstByte(long timeNs)Registers "time to first byte" metric.QueryMetrics<QueryType>DefaultQueryMetrics. reportParallelMergeFastestPartitionTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportParallelMergeFastestPartitionTime(long timeNs)Reports broker "wall" time in nanoseconds for the fastest parallel merge sequence partition to be 'initialized', where 'initialized' is time to the first result batch is populated from data servers and merging can begin.QueryMetrics<QueryType>DefaultQueryMetrics. reportParallelMergeInputRows(long numRows)QueryMetrics<QueryType>QueryMetrics. reportParallelMergeInputRows(long numRows)Reports total number of input rows processed by the broker during parallel merge.QueryMetrics<QueryType>DefaultQueryMetrics. reportParallelMergeInputSequences(long numSequences)QueryMetrics<QueryType>QueryMetrics. reportParallelMergeInputSequences(long numSequences)Reports total number of input sequences processed by the broker during parallel merge.QueryMetrics<QueryType>DefaultQueryMetrics. reportParallelMergeOutputRows(long numRows)QueryMetrics<QueryType>QueryMetrics. reportParallelMergeOutputRows(long numRows)Reports broker total number of output rows after merging and combining input sequences (should be less than or equal to the value supplied toreportParallelMergeInputRows(long).QueryMetrics<QueryType>DefaultQueryMetrics. reportParallelMergeParallelism(int parallelism)QueryMetrics<QueryType>QueryMetrics. reportParallelMergeParallelism(int parallelism)Reports number of parallel tasks the broker used to process the query during parallel merge.QueryMetrics<QueryType>DefaultQueryMetrics. reportParallelMergeSlowestPartitionTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportParallelMergeSlowestPartitionTime(long timeNs)Reports broker "wall" time in nanoseconds for the slowest parallel merge sequence partition to be 'initialized', where 'initialized' is time to the first result batch is populated from data servers and merging can begin.QueryMetrics<QueryType>DefaultQueryMetrics. reportParallelMergeTaskCount(long numTasks)QueryMetrics<QueryType>QueryMetrics. reportParallelMergeTaskCount(long numTasks)Reports broker total number of fork join pool tasks required to complete queryQueryMetrics<QueryType>DefaultQueryMetrics. reportParallelMergeTotalCpuTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportParallelMergeTotalCpuTime(long timeNs)Reports broker total CPU time in nanoseconds where fork join merge combine tasks were doing workQueryMetrics<QueryType>DefaultQueryMetrics. reportParallelMergeTotalTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportParallelMergeTotalTime(long timeNs)Reports broker total "wall" time in nanoseconds from parallel merge start sequence creation to total consumption.QueryMetrics<QueryType>DefaultQueryMetrics. reportPreFilteredRows(long numRows)QueryMetrics<QueryType>QueryMetrics. reportPreFilteredRows(long numRows)Reports the number of rows to scan in the segment after applyingfilterBundle(FilterBundle.BundleInfo).QueryMetrics<QueryType>DefaultQueryMetrics. reportQueriedSegmentCount(long segmentCount)QueryMetrics<QueryType>QueryMetrics. reportQueriedSegmentCount(long segmentCount)Registers "segments queried count" metric.QueryMetrics<QueryType>DefaultQueryMetrics. reportQueryBytes(long byteCount)QueryMetrics<QueryType>QueryMetrics. reportQueryBytes(long byteCount)Registers "query bytes" metric.QueryMetrics<QueryType>DefaultQueryMetrics. reportQueryTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportQueryTime(long timeNs)Registers "query time" metric.QueryMetrics<QueryType>DefaultQueryMetrics. reportSegmentAndCacheTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportSegmentAndCacheTime(long timeNs)Registers "segmentAndCache time" metric.QueryMetrics<QueryType>DefaultQueryMetrics. reportSegmentRows(long numRows)QueryMetrics<QueryType>QueryMetrics. reportSegmentRows(long numRows)Reports the total number of rows in the processed segment.QueryMetrics<QueryType>DefaultQueryMetrics. reportSegmentTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportSegmentTime(long timeNs)Registers "segment time" metric.QueryMetrics<QueryType>DefaultQueryMetrics. reportWaitTime(long timeNs)QueryMetrics<QueryType>QueryMetrics. reportWaitTime(long timeNs)Registers "wait time" metric.Constructor parameters in org.apache.druid.query with type arguments of type QueryMetrics Constructor Description MetricsEmittingQueryRunner(ServiceEmitter emitter, QueryToolChest<T,? extends Query<T>> queryToolChest, QueryRunner<T> queryRunner, ObjLongConsumer<? super QueryMetrics<?>> reportMetric, Consumer<QueryMetrics<?>> applyCustomDimensions)MetricsEmittingQueryRunner(ServiceEmitter emitter, QueryToolChest<T,? extends Query<T>> queryToolChest, QueryRunner<T> queryRunner, ObjLongConsumer<? super QueryMetrics<?>> reportMetric, Consumer<QueryMetrics<?>> applyCustomDimensions) -
Uses of QueryMetrics in org.apache.druid.query.datasourcemetadata
Methods in org.apache.druid.query.datasourcemetadata that return QueryMetrics Modifier and Type Method Description QueryMetrics<Query<?>>DataSourceQueryQueryToolChest. makeMetrics(DataSourceMetadataQuery query) -
Uses of QueryMetrics in org.apache.druid.query.groupby
Subinterfaces of QueryMetrics in org.apache.druid.query.groupby Modifier and Type Interface Description interfaceGroupByQueryMetricsSpecialization ofQueryMetricsforGroupByQuery.Classes in org.apache.druid.query.groupby that implement QueryMetrics Modifier and Type Class Description classDefaultGroupByQueryMetricsMethods in org.apache.druid.query.groupby with parameters of type QueryMetrics Modifier and Type Method Description static CursorBuildSpecGroupingEngine. makeCursorBuildSpec(GroupByQuery query, QueryMetrics<?> queryMetrics) -
Uses of QueryMetrics in org.apache.druid.query.metadata
Methods in org.apache.druid.query.metadata that return QueryMetrics Modifier and Type Method Description QueryMetrics<Query<?>>SegmentMetadataQueryQueryToolChest. makeMetrics(SegmentMetadataQuery query) -
Uses of QueryMetrics in org.apache.druid.query.operator
Methods in org.apache.druid.query.operator that return QueryMetrics Modifier and Type Method Description QueryMetrics<? super WindowOperatorQuery>WindowOperatorQueryQueryToolChest. makeMetrics(WindowOperatorQuery query) -
Uses of QueryMetrics in org.apache.druid.query.scan
Methods in org.apache.druid.query.scan that return QueryMetrics Modifier and Type Method Description QueryMetrics<Query<?>>ScanQueryQueryToolChest. makeMetrics(ScanQuery query)Methods in org.apache.druid.query.scan with parameters of type QueryMetrics Modifier and Type Method Description static CursorBuildSpecScanQueryEngine. makeCursorBuildSpec(ScanQuery query, QueryMetrics<?> queryMetrics)Sequence<ScanResultValue>ScanQueryEngine. process(ScanQuery query, Segment segment, ResponseContext responseContext, QueryMetrics<?> queryMetrics) -
Uses of QueryMetrics in org.apache.druid.query.search
Subinterfaces of QueryMetrics in org.apache.druid.query.search Modifier and Type Interface Description interfaceSearchQueryMetricsClasses in org.apache.druid.query.search that implement QueryMetrics Modifier and Type Class Description classDefaultSearchQueryMetricsThis class is implemented with delegation to another QueryMetrics for compatibility, see "Making subinterfaces of QueryMetrics for emitting custom dimensions and/or metrics for specific query types" section inQueryMetricsjavadoc.Methods in org.apache.druid.query.search that return QueryMetrics Modifier and Type Method Description QueryMetricsDefaultSearchQueryMetrics. reportBackPressureTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportBitmapConstructionTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportCpuTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportNodeBytes(long byteCount)QueryMetricsDefaultSearchQueryMetrics. reportNodeTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportNodeTimeToFirstByte(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportParallelMergeFastestPartitionTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportParallelMergeInputRows(long numRows)QueryMetricsDefaultSearchQueryMetrics. reportParallelMergeInputSequences(long numSequences)QueryMetricsDefaultSearchQueryMetrics. reportParallelMergeOutputRows(long numRows)QueryMetricsDefaultSearchQueryMetrics. reportParallelMergeParallelism(int parallelism)QueryMetricsDefaultSearchQueryMetrics. reportParallelMergeSlowestPartitionTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportParallelMergeTaskCount(long numTasks)QueryMetricsDefaultSearchQueryMetrics. reportParallelMergeTotalCpuTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportParallelMergeTotalTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportPreFilteredRows(long numRows)QueryMetricsDefaultSearchQueryMetrics. reportQueriedSegmentCount(long segmentCount)QueryMetricsDefaultSearchQueryMetrics. reportQueryBytes(long byteCount)QueryMetricsDefaultSearchQueryMetrics. reportQueryTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportSegmentAndCacheTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportSegmentRows(long numRows)QueryMetricsDefaultSearchQueryMetrics. reportSegmentTime(long timeNs)QueryMetricsDefaultSearchQueryMetrics. reportWaitTime(long timeNs)Constructors in org.apache.druid.query.search with parameters of type QueryMetrics Constructor Description DefaultSearchQueryMetrics(QueryMetrics<Query<?>> queryMetrics) -
Uses of QueryMetrics in org.apache.druid.query.timeboundary
Methods in org.apache.druid.query.timeboundary that return QueryMetrics Modifier and Type Method Description QueryMetrics<Query<?>>TimeBoundaryQueryQueryToolChest. makeMetrics(TimeBoundaryQuery query) -
Uses of QueryMetrics in org.apache.druid.query.timeseries
Subinterfaces of QueryMetrics in org.apache.druid.query.timeseries Modifier and Type Interface Description interfaceTimeseriesQueryMetricsSpecialization ofQueryMetricsforTimeseriesQuery.Classes in org.apache.druid.query.timeseries that implement QueryMetrics Modifier and Type Class Description classDefaultTimeseriesQueryMetricsMethods in org.apache.druid.query.timeseries with parameters of type QueryMetrics Modifier and Type Method Description static CursorBuildSpecTimeseriesQueryEngine. makeCursorBuildSpec(TimeseriesQuery query, QueryMetrics<?> queryMetrics) -
Uses of QueryMetrics in org.apache.druid.query.topn
Subinterfaces of QueryMetrics in org.apache.druid.query.topn Modifier and Type Interface Description interfaceTopNQueryMetricsSpecialization ofQueryMetricsforTopNQuery.Classes in org.apache.druid.query.topn that implement QueryMetrics Modifier and Type Class Description classDefaultTopNQueryMetricsMethods in org.apache.druid.query.topn with parameters of type QueryMetrics Modifier and Type Method Description static CursorBuildSpecTopNQueryEngine. makeCursorBuildSpec(TopNQuery query, QueryMetrics<?> queryMetrics) -
Uses of QueryMetrics in org.apache.druid.segment
Methods in org.apache.druid.segment that return QueryMetrics Modifier and Type Method Description QueryMetrics<?>CursorBuildSpec. getQueryMetrics()Methods in org.apache.druid.segment with parameters of type QueryMetrics Modifier and Type Method Description default Sequence<Cursor>StorageAdapter. makeCursors(Filter filter, org.joda.time.Interval interval, VirtualColumns virtualColumns, Granularity gran, boolean descending, QueryMetrics<?> queryMetrics)Deprecated.UseSegment.asCursorFactory()and thenCursorFactory.makeCursorHolder(CursorBuildSpec)and callCursorHolder.asCursor()instead.default VectorCursorStorageAdapter. makeVectorCursor(Filter filter, org.joda.time.Interval interval, VirtualColumns virtualColumns, boolean descending, int vectorSize, QueryMetrics<?> queryMetrics)Deprecated.UseSegment.asCursorFactory()and thenCursorFactory.makeCursorHolder(CursorBuildSpec)and callCursorHolder.asVectorCursor()instead.CursorBuildSpec.CursorBuildSpecBuilderCursorBuildSpec.CursorBuildSpecBuilder. setQueryMetrics(QueryMetrics<?> queryMetrics)Constructors in org.apache.druid.segment with parameters of type QueryMetrics Constructor Description CursorBuildSpec(Filter filter, org.joda.time.Interval interval, Set<String> physicalColumns, VirtualColumns virtualColumns, List<String> groupingColumns, List<AggregatorFactory> aggregators, List<OrderBy> preferredOrdering, QueryContext queryContext, QueryMetrics<?> queryMetrics)
-