Uses of Interface
org.apache.druid.java.util.common.Cacheable
-
-
Uses of Cacheable in org.apache.druid.frame.util
Classes in org.apache.druid.frame.util that implement Cacheable Modifier and Type Class Description classSettableLongVirtualColumnVirtual column that returns a changeable value, viaSettableLongVirtualColumn.setValue(long). -
Uses of Cacheable in org.apache.druid.java.util.common
Classes in org.apache.druid.java.util.common that implement Cacheable Modifier and Type Class Description classStringEncodingAn enum that provides a way for users to specify what encoding should be used when hashing strings. -
Uses of Cacheable in org.apache.druid.java.util.common.granularity
Classes in org.apache.druid.java.util.common.granularity that implement Cacheable Modifier and Type Class Description classAllGranularityAllGranularty buckets everything into a single bucketclassDurationGranularityDurationGranularity buckets data based on the length of a durationclassGranularityclassNoneGranularityNoneGranularity does not bucket dataclassPeriodGranularityPeriodGranularity buckets data based on any custom time period -
Uses of Cacheable in org.apache.druid.math.expr
Subinterfaces of Cacheable in org.apache.druid.math.expr Modifier and Type Interface Description interfaceExprBase interface of Druid expression language abstract syntax tree nodes.static interfaceExprMacroTable.ExprMacroFunctionExprstub interface to allowParser.flatten(Expr)a way to recognize macro functions that exend thisClasses in org.apache.druid.math.expr that implement Cacheable Modifier and Type Class Description static classExprMacroTable.BaseScalarMacroFunctionExprBase class for multi-argumentExprMacroTable.ExprMacrofunctionExprstatic classExprMacroTable.BaseScalarUnivariateMacroFunctionExprBase class for single argumentExprMacroTable.ExprMacrofunctionExpr -
Uses of Cacheable in org.apache.druid.query.aggregation
Subinterfaces of Cacheable in org.apache.druid.query.aggregation Modifier and Type Interface Description interfacePostAggregatorFunctionally similar to an Aggregator.Classes in org.apache.druid.query.aggregation that implement Cacheable Modifier and Type Class Description classAggregatorFactoryAggregatorFactory is a strategy (in the terms of Design Patterns) that represents column aggregation, e.g.classCountAggregatorFactoryclassDoubleMaxAggregatorFactoryclassDoubleMinAggregatorFactoryclassDoubleSumAggregatorFactoryclassExpressionLambdaAggregatorFactoryclassFilteredAggregatorFactoryclassFloatMaxAggregatorFactoryclassFloatMinAggregatorFactoryclassFloatSumAggregatorFactoryclassGroupingAggregatorFactoryThis class implementsgroupingfunction to determine the grouping that a row is part of.classHistogramAggregatorFactoryclassJavaScriptAggregatorFactoryclassLongMaxAggregatorFactoryclassLongMinAggregatorFactoryclassLongSumAggregatorFactoryclassNullableNumericAggregatorFactory<T extends BaseNullableColumnValueSelector>Abstract superclass for null-aware numeric aggregators.classSimpleDoubleAggregatorFactoryThis is an abstract class inherited by variousAggregatorFactoryimplementations that consume double input and produce double output on aggregation.classSimpleFloatAggregatorFactoryclassSimpleLongAggregatorFactoryThis is an abstract class inherited by variousAggregatorFactoryimplementations that consume long input and produce long output on aggregation.classSuppressedAggregatorFactoryThis AggregatorFactory is meant for wrapping delegate aggregators for optimization purposes. -
Uses of Cacheable in org.apache.druid.query.aggregation.any
Classes in org.apache.druid.query.aggregation.any that implement Cacheable Modifier and Type Class Description classDoubleAnyAggregatorFactoryclassFloatAnyAggregatorFactoryclassLongAnyAggregatorFactoryclassStringAnyAggregatorFactory -
Uses of Cacheable in org.apache.druid.query.aggregation.cardinality
Classes in org.apache.druid.query.aggregation.cardinality that implement Cacheable Modifier and Type Class Description classCardinalityAggregatorFactory -
Uses of Cacheable in org.apache.druid.query.aggregation.first
Classes in org.apache.druid.query.aggregation.first that implement Cacheable Modifier and Type Class Description classDoubleFirstAggregatorFactoryclassFloatFirstAggregatorFactoryclassLongFirstAggregatorFactoryclassStringFirstAggregatorFactoryclassStringFirstFoldingAggregatorFactoryFor backwards compatibility; equivalent to a regular StringFirstAggregatorFactory. -
Uses of Cacheable in org.apache.druid.query.aggregation.hyperloglog
Classes in org.apache.druid.query.aggregation.hyperloglog that implement Cacheable Modifier and Type Class Description classHyperUniqueFinalizingPostAggregatorclassHyperUniquesAggregatorFactory -
Uses of Cacheable in org.apache.druid.query.aggregation.last
Classes in org.apache.druid.query.aggregation.last that implement Cacheable Modifier and Type Class Description classDoubleLastAggregatorFactoryclassFloatLastAggregatorFactoryclassLongLastAggregatorFactoryclassStringLastAggregatorFactoryclassStringLastFoldingAggregatorFactoryFor backwards compatibility; equivalent to a regular StringLastAggregatorFactory. -
Uses of Cacheable in org.apache.druid.query.aggregation.mean
Classes in org.apache.druid.query.aggregation.mean that implement Cacheable Modifier and Type Class Description classDoubleMeanAggregatorFactory -
Uses of Cacheable in org.apache.druid.query.aggregation.post
Classes in org.apache.druid.query.aggregation.post that implement Cacheable Modifier and Type Class Description classArithmeticPostAggregatorclassConstantPostAggregatorclassDoubleGreatestPostAggregatorclassDoubleLeastPostAggregatorclassExpressionPostAggregatorclassFieldAccessPostAggregatorclassFinalizingFieldAccessPostAggregatorclassJavaScriptPostAggregatorclassLongGreatestPostAggregatorclassLongLeastPostAggregator -
Uses of Cacheable in org.apache.druid.query.cache
Methods in org.apache.druid.query.cache with parameters of type Cacheable Modifier and Type Method Description CacheKeyBuilderCacheKeyBuilder. appendCacheable(Cacheable input)Method parameters in org.apache.druid.query.cache with type arguments of type Cacheable Modifier and Type Method Description CacheKeyBuilderCacheKeyBuilder. appendCacheables(Collection<? extends Cacheable> input)Add a collection of Cacheables to the cache key.CacheKeyBuilderCacheKeyBuilder. appendCacheablesIgnoringOrder(Collection<? extends Cacheable> input)Add a collection of Cacheables to the cache key. -
Uses of Cacheable in org.apache.druid.query.dimension
Subinterfaces of Cacheable in org.apache.druid.query.dimension Modifier and Type Interface Description interfaceDimensionSpecProvides information about a dimension for a grouping query, like topN or groupBy.Classes in org.apache.druid.query.dimension that implement Cacheable Modifier and Type Class Description classBaseFilteredDimensionSpecclassDefaultDimensionSpecclassExtractionDimensionSpecclassLegacyDimensionSpecclassListFilteredDimensionSpecclassLookupDimensionSpecclassPrefixFilteredDimensionSpecclassRegexFilteredDimensionSpec -
Uses of Cacheable in org.apache.druid.query.expression
Classes in org.apache.druid.query.expression that implement Cacheable Modifier and Type Class Description static classTimestampFloorExprMacro.TimestampFloorDynamicExprstatic classTimestampFloorExprMacro.TimestampFloorExpr -
Uses of Cacheable in org.apache.druid.query.extraction
Subinterfaces of Cacheable in org.apache.druid.query.extraction Modifier and Type Interface Description interfaceExtractionFnAn ExtractionFn is a function that can be used to transform the values of a column (typically a dimension).Classes in org.apache.druid.query.extraction that implement Cacheable Modifier and Type Class Description classBucketExtractionFnclassCascadeExtractionFnclassDimExtractionFnclassFunctionalExtractionFunctional extraction uses a function to find the new value.classIdentityExtractionFnclassJavaScriptExtractionFnclassLowerExtractionFnclassMatchingDimExtractionFnclassRegexDimExtractionFnclassSearchQuerySpecDimExtractionFnclassStringFormatExtractionFnclassStrlenExtractionFnclassSubstringDimExtractionFnclassTimeDimExtractionFnclassTimeFormatExtractionFnclassUpperExtractionFn -
Uses of Cacheable in org.apache.druid.query.filter
Subinterfaces of Cacheable in org.apache.druid.query.filter Modifier and Type Interface Description interfaceDimFilterClasses in org.apache.druid.query.filter that implement Cacheable Modifier and Type Class Description classAbstractOptimizableDimFilterBase class for DimFilters that support optimization.classAndDimFilterclassBoundDimFilterclassColumnComparisonDimFilterclassEqualityFilterclassExpressionDimFilterclassExtractionDimFilterDeprecated.classFalseDimFilterclassInDimFilterclassIntervalDimFilterclassIsBooleanDimFilterAbstract SQL three-value logic wrapper for some childDimFilterto implement '{filter} IS TRUE' and '{filter} IS FALSE'.classIsFalseDimFilterclassIsTrueDimFilterclassJavaScriptDimFilterclassLikeDimFilterclassNotDimFilterclassNullFilterclassOrDimFilterclassRangeFilterclassRegexDimFilterclassSearchQueryDimFilterclassSelectorDimFilterclassSpatialDimFilterclassTrueDimFilter -
Uses of Cacheable in org.apache.druid.query.groupby.having
Subinterfaces of Cacheable in org.apache.druid.query.groupby.having Modifier and Type Interface Description interfaceHavingSpecA "having" clause that filters aggregated/dimension value.Classes in org.apache.druid.query.groupby.having that implement Cacheable Modifier and Type Class Description classAlwaysHavingSpecA "having" spec that always evaluates to trueclassAndHavingSpecThe logical "and" operator for the "having" clause.classDimensionSelectorHavingSpecclassDimFilterHavingSpecclassEqualToHavingSpecThe "=" operator in a "having" clause.classGreaterThanHavingSpecThe ">" operator in a "having" clause.classLessThanHavingSpecThe "<" operator in a "having" clause.classNeverHavingSpecA "having" spec that always evaluates to falseclassNotHavingSpecThe logical "not" operator for the "having" clause.classOrHavingSpecThe logical "or" operator for the "having" clause. -
Uses of Cacheable in org.apache.druid.query.groupby.orderby
Subinterfaces of Cacheable in org.apache.druid.query.groupby.orderby Modifier and Type Interface Description interfaceLimitSpecClasses in org.apache.druid.query.groupby.orderby that implement Cacheable Modifier and Type Class Description classDefaultLimitSpecclassNoopLimitSpec -
Uses of Cacheable in org.apache.druid.query.lookup
Classes in org.apache.druid.query.lookup that implement Cacheable Modifier and Type Class Description classLookupExtractionFnclassRegisteredLookupExtractionFn -
Uses of Cacheable in org.apache.druid.query.metadata.metadata
Subinterfaces of Cacheable in org.apache.druid.query.metadata.metadata Modifier and Type Interface Description interfaceColumnIncluderatorClasses in org.apache.druid.query.metadata.metadata that implement Cacheable Modifier and Type Class Description classAllColumnIncluderatorclassListColumnIncluderatorclassNoneColumnIncluderatorstatic classSegmentMetadataQuery.AnalysisType -
Uses of Cacheable in org.apache.druid.query.search
Subinterfaces of Cacheable in org.apache.druid.query.search Modifier and Type Interface Description interfaceSearchQuerySpecClasses in org.apache.druid.query.search that implement Cacheable Modifier and Type Class Description classAllSearchQuerySpecclassContainsSearchQuerySpecclassFragmentSearchQuerySpecclassInsensitiveContainsSearchQuerySpecclassRegexSearchQuerySpecclassSearchSortSpec -
Uses of Cacheable in org.apache.druid.query.topn
Subinterfaces of Cacheable in org.apache.druid.query.topn Modifier and Type Interface Description interfaceTopNMetricSpecClasses in org.apache.druid.query.topn that implement Cacheable Modifier and Type Class Description classAlphaNumericTopNMetricSpecclassDimensionTopNMetricSpecclassInvertedTopNMetricSpecclassLegacyTopNMetricSpecclassLexicographicTopNMetricSpecclassNumericTopNMetricSpec -
Uses of Cacheable in org.apache.druid.segment
Subinterfaces of Cacheable in org.apache.druid.segment Modifier and Type Interface Description interfaceVirtualColumnVirtual columns are "views" created over aColumnSelectorFactoryorColumnSelector.Classes in org.apache.druid.segment that implement Cacheable Modifier and Type Class Description classVirtualColumnsClass allowing lookup and usage of virtual columns. -
Uses of Cacheable in org.apache.druid.segment.virtual
Classes in org.apache.druid.segment.virtual that implement Cacheable Modifier and Type Class Description classExpressionVirtualColumnclassFallbackVirtualColumnA virtual column that picks one column or another based on whether they exist.classListFilteredVirtualColumnclassNestedFieldVirtualColumnOptimized virtual column that can make direct selectors into aNestedDataComplexColumnor any associated nested fields (NestedFieldDictionaryEncodedColumn) including using their indexes.
-